A B C D E F G H I J K L M N O P Q R S T U V W Y Z _
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- abort() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
- abort() - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
- abort() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
- abort() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
- abort() - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
- abort() - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
- abort() - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
- abort() - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
- abort() - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
- abort() - Method in interface org.apache.flink.runtime.operators.util.JoinTaskIterator
-
Aborts the matching process.
- abort(long, Throwable, boolean) - Method in interface org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter
-
Aborts the checkpoint and fails pending result for this checkpoint.
- abort(long, Throwable, boolean) - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter.NoOpChannelStateWriter
- abort(long, Throwable, boolean) - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriterImpl
- abort(CheckpointFailureReason, Throwable, CheckpointsCleaner, Runnable, Executor, CheckpointStatsTracker) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
Aborts a checkpoint with reason and cause.
- ABORT - org.apache.flink.runtime.taskmanager.Task.NotifyCheckpointOperation
- abortCheckpoint(long) - Method in class org.apache.flink.runtime.state.NoOpTaskLocalStateStoreImpl
- abortCheckpoint(long) - Method in interface org.apache.flink.runtime.state.TaskLocalStateStore
-
Notifies that the checkpoint with the given id was confirmed as aborted.
- abortCheckpoint(long) - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
- abortCheckpoint(long, CheckpointException) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
- abortCheckpoint(long, CheckpointException) - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
Abort the checkpoint.
- abortCheckpoint(long, CheckpointException) - Method in class org.apache.flink.runtime.io.network.partition.BufferWritingResultPartition
- abortCheckpoint(long, CheckpointException) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartition
- abortCheckpoint(long, CheckpointException) - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartition
- abortCheckpoint(long, CheckpointException) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
- abortCheckpoint(long, CheckpointException) - Method in class org.apache.flink.runtime.io.network.partition.SortMergeResultPartition
- abortCheckpoint(long, CheckpointException) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
- abortCheckpoint(long, CheckpointException) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- abortCheckpoint(ExecutionAttemptID, long, long, long) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- abortCheckpoint(ExecutionAttemptID, long, long, long) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Abort a checkpoint for the given task.
- abortCheckpoint(ExecutionAttemptID, long, long, long) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- abortCheckpointOnBarrier(long, CheckpointException) - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
- abortCheckpointOnBarrier(long, CheckpointException) - Method in interface org.apache.flink.runtime.jobgraph.tasks.CheckpointableTask
-
Aborts a checkpoint as the result of receiving possibly some checkpoint barriers, but at least one
CancelCheckpointMarker. - abortCheckpointOnBarrier(long, CheckpointException) - Method in class org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
- abortCheckpointOnBarrier(long, CheckpointException) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- abortCheckpointOnBarrier(long, CheckpointException, OperatorChain<?, ?>) - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
- abortCurrentTriggering() - Method in interface org.apache.flink.runtime.checkpoint.OperatorCoordinatorCheckpointContext
- abortCurrentTriggering() - Method in class org.apache.flink.runtime.operators.coordination.OperatorCoordinatorHolder
- abortPendingCheckpoints(CheckpointException) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Aborts all the pending checkpoints due to en exception.
- AbstractAccessExecutionGraphHandler<R extends ResponseBody,M extends JobMessageParameters> - Class in org.apache.flink.runtime.rest.handler.job
-
AbstractAccessExecutionGraphHandlerhandles requests that require accessing the job'sAccessExecutionGraph. - AbstractAccessExecutionGraphHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, R, M>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.AbstractAccessExecutionGraphHandler
- AbstractAggregatedMetricsHeaders<P extends AbstractAggregatedMetricsParameters<?>> - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
Based
MessageHeadersclass for aggregating metrics. - AbstractAggregatedMetricsHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsHeaders
- AbstractAggregatedMetricsParameters<M extends MessageQueryParameter<?>> - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
Base
MessageParametersclass for aggregating metrics. - AbstractAggregatingMetricsHandler<P extends AbstractAggregatedMetricsParameters<?>> - Class in org.apache.flink.runtime.rest.handler.job.metrics
-
Abstract request handler for querying aggregated metrics.
- AbstractAggregatingMetricsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, AbstractAggregatedMetricsHeaders<P>, Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.AbstractAggregatingMetricsHandler
- AbstractAggregatingState<K,N,IN,ACC,OUT> - Class in org.apache.flink.runtime.state.v2
-
The default implementation of
AggregatingState, which delegates all async requests toStateRequestHandler. - AbstractAggregatingState(StateRequestHandler, AggregatingStateDescriptor<IN, ACC, OUT>) - Constructor for class org.apache.flink.runtime.state.v2.AbstractAggregatingState
-
Creates a new AbstractKeyedState with the given asyncExecutionController and stateDescriptor.
- AbstractAsynchronousOperationHandlers<K extends OperationKey,R extends Serializable> - Class in org.apache.flink.runtime.rest.handler.async
-
HTTP handlers for asynchronous operations.
- AbstractAsynchronousOperationHandlers(Duration) - Constructor for class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers
- AbstractAsynchronousOperationHandlers.StatusHandler<T extends RestfulGateway,V,M extends MessageParameters> - Class in org.apache.flink.runtime.rest.handler.async
-
Handler which will be polled to retrieve the asynchronous operation's result.
- AbstractAsynchronousOperationHandlers.TriggerHandler<T extends RestfulGateway,B extends RequestBody,M extends MessageParameters> - Class in org.apache.flink.runtime.rest.handler.async
-
Handler which is responsible for triggering an asynchronous operation.
- AbstractAsyncStateStreamOperator<OUT> - Class in org.apache.flink.runtime.asyncprocessing.operators
-
This operator is an abstract class that give the
AbstractStreamOperatorthe ability to performAsyncStateProcessing. - AbstractAsyncStateStreamOperator() - Constructor for class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperator
- AbstractAsyncStateStreamOperatorV2<OUT> - Class in org.apache.flink.runtime.asyncprocessing.operators
-
This operator is an abstract class that give the
AbstractStreamOperatorV2the ability to performAsyncStateProcessing. - AbstractAsyncStateStreamOperatorV2(StreamOperatorParameters<OUT>, int) - Constructor for class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperatorV2
- AbstractAsyncStateUdfStreamOperator<OUT,F extends org.apache.flink.api.common.functions.Function> - Class in org.apache.flink.runtime.asyncprocessing.operators
-
This is used as the base class for operators that have a user-defined function.
- AbstractAsyncStateUdfStreamOperator(F) - Constructor for class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateUdfStreamOperator
- AbstractBlobCache - Class in org.apache.flink.runtime.blob
-
Abstract base class for permanent and transient BLOB files.
- AbstractBlobCache(Configuration, Reference<File>, BlobView, Logger, InetSocketAddress) - Constructor for class org.apache.flink.runtime.blob.AbstractBlobCache
- AbstractBroadcastStateTransformation<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.transformations
-
Base class for Broadcast State transformations.
- AbstractBroadcastStateTransformation(String, Transformation<IN1>, Transformation<IN2>, List<MapStateDescriptor<?, ?>>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
- AbstractBroadcastStateTransformation(String, Transformation<IN1>, Transformation<IN2>, List<MapStateDescriptor<?, ?>>, TypeInformation<OUT>, int, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
- AbstractBuffersUsageGauge - Class in org.apache.flink.runtime.io.network.metrics
-
Abstract gauge implementation for calculating the buffer usage percent.
- AbstractCachedBuildSideJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
- AbstractCachedBuildSideJoinDriver(int, int) - Constructor for class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
- AbstractChannelReaderInputView - Class in org.apache.flink.runtime.io.disk.iomanager
-
A
DataInputViewthat is backed by aFileIOChannel, making it effectively a data input stream. - AbstractChannelReaderInputView(int) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AbstractChannelReaderInputView
- AbstractChannelStateHandle<Info> - Class in org.apache.flink.runtime.state
-
Abstract channel state handle.
- AbstractChannelStateHandle.StateContentMetaInfo - Class in org.apache.flink.runtime.state
-
Describes the underlying content.
- AbstractChannelWriterOutputView - Class in org.apache.flink.runtime.io.disk.iomanager
-
A
DataOutputViewthat is backed by aFileIOChannel, making it effectively a data output stream. - AbstractChannelWriterOutputView(int, int) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
- AbstractCheckpointHandler<R extends ResponseBody,M extends CheckpointMessageParameters> - Class in org.apache.flink.runtime.rest.handler.job.checkpoints
-
Base class for checkpoint related REST handler.
- AbstractCheckpointHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, R, M>, Executor, Cache<JobID, CompletableFuture<CheckpointStatsSnapshot>>, CheckpointStatsCache) - Constructor for class org.apache.flink.runtime.rest.handler.job.checkpoints.AbstractCheckpointHandler
- AbstractCheckpointMessage - Class in org.apache.flink.runtime.messages.checkpoint
-
The base class of all checkpoint messages.
- AbstractCheckpointMessage(JobID, ExecutionAttemptID, long) - Constructor for class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
- AbstractCheckpointStats - Class in org.apache.flink.runtime.checkpoint
-
Base class for checkpoint statistics.
- AbstractCheckpointStatsHandler<R extends ResponseBody,M extends JobMessageParameters> - Class in org.apache.flink.runtime.rest.handler.job.checkpoints
-
Abstract class for checkpoint handlers that will cache the
CheckpointStatsSnapshotobject. - AbstractCheckpointStatsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, R, M>, Cache<JobID, CompletableFuture<CheckpointStatsSnapshot>>, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.checkpoints.AbstractCheckpointStatsHandler
- AbstractCollectResultBuffer<T> - Class in org.apache.flink.streaming.api.operators.collect
-
A buffer which encapsulates the logic of dealing with the response from the
CollectSinkFunction. - AbstractCollectResultBuffer(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
- AbstractCompleteCheckpointStore - Class in org.apache.flink.runtime.checkpoint
-
The abstract class of
CompletedCheckpointStore, which holds theSharedStateRegistryand provides the registration of shared state. - AbstractCompleteCheckpointStore(SharedStateRegistry) - Constructor for class org.apache.flink.runtime.checkpoint.AbstractCompleteCheckpointStore
- AbstractDispatcherLeaderProcess - Class in org.apache.flink.runtime.dispatcher.runner
-
A base
DispatcherLeaderProcess. - AbstractDispatcherLeaderProcess.DispatcherGatewayService - Interface in org.apache.flink.runtime.dispatcher.runner
-
An accessor of the
DispatcherGateway. - AbstractDispatcherLeaderProcess.DispatcherGatewayServiceFactory - Interface in org.apache.flink.runtime.dispatcher.runner
- AbstractDispatcherLeaderProcess.State - Enum in org.apache.flink.runtime.dispatcher.runner
-
The state of the
DispatcherLeaderProcess. - AbstractEvent - Class in org.apache.flink.runtime.event
-
This type of event can be used to exchange notification messages between different
TaskExecutorobjects at runtime using the communication channels. - AbstractEvent() - Constructor for class org.apache.flink.runtime.event.AbstractEvent
- AbstractExecutionGraphHandler<R extends ResponseBody,M extends JobMessageParameters> - Class in org.apache.flink.runtime.rest.handler.job
-
Base class for all
ExecutionGraphInfobased REST handlers. - AbstractExecutionGraphHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, R, M>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.AbstractExecutionGraphHandler
- AbstractFileIOChannel - Class in org.apache.flink.runtime.io.disk.iomanager
- AbstractFileIOChannel(FileIOChannel.ID, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
-
Creates a new channel to the path indicated by the given ID.
- AbstractFileStateBackend - Class in org.apache.flink.runtime.state.filesystem
-
Deprecated.State backends should no longer implement
CheckpointStoragefunctionality. Please inheritAbstractStateBackendinstead. Custom checkpoint storage can be additionally implemented as a separate class. - AbstractFileStateBackend(URI, URI) - Constructor for class org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
-
Deprecated.Creates a backend with the given optional checkpoint- and savepoint base directories.
- AbstractFileStateBackend(Path, Path) - Constructor for class org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
-
Deprecated.Creates a backend with the given optional checkpoint- and savepoint base directories.
- AbstractFileStateBackend(Path, Path, ReadableConfig) - Constructor for class org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
-
Deprecated.Creates a new backend using the given checkpoint-/savepoint directories, or the values defined in the given configuration.
- AbstractFsCheckpointStorageAccess - Class in org.apache.flink.runtime.state.filesystem
-
An implementation of durable checkpoint storage to file systems.
- AbstractFsCheckpointStorageAccess(JobID, Path) - Constructor for class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorageAccess
-
Creates a new checkpoint storage.
- AbstractHandler<T extends RestfulGateway,R extends RequestBody,M extends MessageParameters> - Class in org.apache.flink.runtime.rest.handler
-
Super class for netty-based handlers that work with
RequestBody. - AbstractHandler(GatewayRetriever<? extends T>, Duration, Map<String, String>, UntypedResponseMessageHeaders<R, M>) - Constructor for class org.apache.flink.runtime.rest.handler.AbstractHandler
- AbstractHaServices - Class in org.apache.flink.runtime.highavailability
-
Abstract high availability services based on distributed system(e.g.
- AbstractHaServices(Configuration, LeaderElectionDriverFactory, Executor, BlobStoreService, JobResultStore) - Constructor for class org.apache.flink.runtime.highavailability.AbstractHaServices
- AbstractHashTableProber<PT,BT> - Class in org.apache.flink.runtime.operators.hash
- AbstractHashTableProber(TypeComparator<PT>, TypePairComparator<PT, BT>) - Constructor for class org.apache.flink.runtime.operators.hash.AbstractHashTableProber
- AbstractHeapPriorityQueue<T extends HeapPriorityQueueElement> - Class in org.apache.flink.runtime.state.heap
-
Abstract base class for heap (object array) based implementations of priority queues, with support for fast deletes via
HeapPriorityQueueElement. - AbstractHeapPriorityQueue(int) - Constructor for class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
- AbstractHeapPriorityQueueElement - Class in org.apache.flink.runtime.state.heap
-
Abstract base class for
HeapPriorityQueueElement. - AbstractHeapPriorityQueueElement() - Constructor for class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueueElement
- AbstractHeapState<K,N,SV> - Class in org.apache.flink.runtime.state.heap
-
Base class for partitioned
Stateimplementations that are backed by a regular heap hash map. - AbstractIncrementalStateHandle - Class in org.apache.flink.runtime.state
-
Abstract superclass for all
IncrementalKeyedStateHandle. - AbstractIncrementalStateHandle(UUID, KeyGroupRange, long, List<IncrementalKeyedStateHandle.HandleAndLocalPath>, StreamStateHandle, StateHandleID) - Constructor for class org.apache.flink.runtime.state.AbstractIncrementalStateHandle
- AbstractInvokable - Class in org.apache.flink.runtime.jobgraph.tasks
-
A base implementation of
TaskInvokable,CheckpointableTask, andCoordinatedTaskwith most methods throwingUnsupportedOperationExceptionor doing nothing. - AbstractInvokable(Environment) - Constructor for class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Create an Invokable task and set its environment.
- AbstractIterativeTask<S extends org.apache.flink.api.common.functions.Function,OT> - Class in org.apache.flink.runtime.iterative.task
-
The abstract base class for all tasks able to participate in an iteration.
- AbstractIterativeTask(Environment) - Constructor for class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
Create an Invokable task and set its environment.
- AbstractJobManagerFileHandler<M extends MessageParameters> - Class in org.apache.flink.runtime.rest.handler.cluster
-
Base class for serving files from the JobManager.
- AbstractJobManagerFileHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, UntypedResponseMessageHeaders<EmptyRequestBody, M>) - Constructor for class org.apache.flink.runtime.rest.handler.cluster.AbstractJobManagerFileHandler
- AbstractJobVertexHandler<R extends ResponseBody,M extends JobVertexMessageParameters> - Class in org.apache.flink.runtime.rest.handler.job
-
Base class for request handlers whose response depends on a specific job vertex (defined via the "
JobVertexIdPathParameter.KEY" parameter) in a specific job, defined via (defined via the "JobIDPathParameter.KEY" parameter). - AbstractJobVertexHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, R, M>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.AbstractJobVertexHandler
-
Instantiates a new Abstract job vertex handler.
- AbstractKeyedState<K,N,V> - Class in org.apache.flink.runtime.state.v2
-
The
AbstractKeyedStateis the root of the abstract state implementation hierarchy, similar to theStatebeing the root of the public API state hierarchy. - AbstractKeyedState(StateRequestHandler, StateDescriptor<V>) - Constructor for class org.apache.flink.runtime.state.v2.AbstractKeyedState
-
Creates a new AbstractKeyedState with the given asyncExecutionController and stateDescriptor.
- AbstractKeyedStateBackend<K> - Class in org.apache.flink.runtime.state
-
Base implementation of KeyedStateBackend.
- AbstractKeyedStateBackend(TaskKvStateRegistry, TypeSerializer<K>, ClassLoader, ExecutionConfig, TtlTimeProvider, LatencyTrackingStateConfig, CloseableRegistry, InternalKeyContext<K>) - Constructor for class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- AbstractKeyedStateBackend(TaskKvStateRegistry, TypeSerializer<K>, ClassLoader, ExecutionConfig, TtlTimeProvider, LatencyTrackingStateConfig, CloseableRegistry, StreamCompressionDecorator, InternalKeyContext<K>) - Constructor for class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- AbstractKeyedStateBackend(AbstractKeyedStateBackend<K>) - Constructor for class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- AbstractKeyedStateBackend.PartitionStateFactory - Interface in org.apache.flink.runtime.state
- AbstractKeyedStateBackendBuilder<K> - Class in org.apache.flink.runtime.state
-
An abstract base implementation of the
StateBackendBuilderinterface. - AbstractKeyedStateBackendBuilder(TaskKvStateRegistry, TypeSerializer<K>, ClassLoader, int, KeyGroupRange, ExecutionConfig, TtlTimeProvider, LatencyTrackingStateConfig, Collection<KeyedStateHandle>, StreamCompressionDecorator, CloseableRegistry) - Constructor for class org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
- AbstractListState<K,N,V> - Class in org.apache.flink.runtime.state.v2
-
A default implementation of
ListStatewhich delegates all async requests toStateRequestHandler. - AbstractListState(StateRequestHandler, ListStateDescriptor<V>) - Constructor for class org.apache.flink.runtime.state.v2.AbstractListState
- AbstractManagedMemoryStateBackend - Class in org.apache.flink.runtime.state
-
Abstract base class for state backends that use managed memory.
- AbstractManagedMemoryStateBackend() - Constructor for class org.apache.flink.runtime.state.AbstractManagedMemoryStateBackend
- AbstractMapState<K,N,UK,V> - Class in org.apache.flink.runtime.state.v2
-
A default implementation of
MapStatewhich delegates all async requests toStateRequestHandler. - AbstractMapState(StateRequestHandler, MapStateDescriptor<UK, V>) - Constructor for class org.apache.flink.runtime.state.v2.AbstractMapState
- AbstractMergeInnerJoinIterator<T1,T2,O> - Class in org.apache.flink.runtime.operators.sort
-
An implementation of the
JoinTaskIteratorthat realizes the joining through a sort-merge join strategy. - AbstractMergeInnerJoinIterator(MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.AbstractMergeInnerJoinIterator
- AbstractMergeIterator<T1,T2,O> - Class in org.apache.flink.runtime.operators.sort
- AbstractMergeIterator(MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
- AbstractMergeOuterJoinIterator<T1,T2,O> - Class in org.apache.flink.runtime.operators.sort
-
An implementation of the
JoinTaskIteratorthat realizes the outer join through a sort-merge join strategy. - AbstractMergeOuterJoinIterator(OuterJoinOperatorBase.OuterJoinType, MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.AbstractMergeOuterJoinIterator
- AbstractMetricGroup<A extends AbstractMetricGroup<?>> - Class in org.apache.flink.runtime.metrics.groups
-
Abstract
MetricGroupthat contains key functionality for adding metrics and groups. - AbstractMetricGroup(MetricRegistry, String[], A) - Constructor for class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
- AbstractMetricGroup.ChildType - Enum in org.apache.flink.runtime.metrics.groups
-
Enum for indicating which child group should be created.
- AbstractMetricsHandler<M extends MessageParameters> - Class in org.apache.flink.runtime.rest.handler.job.metrics
-
Request handler that returns for a given task a list of all available metrics or the values for a set of metrics.
- AbstractMetricsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, MetricCollectionResponseBody, M>, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.AbstractMetricsHandler
- AbstractMetricsHeaders<M extends MessageParameters> - Class in org.apache.flink.runtime.rest.messages.job.metrics
- AbstractMetricsHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
- AbstractMultipleInputTransformation<OUT> - Class in org.apache.flink.streaming.api.transformations
-
Base class for transformations representing the application of a
MultipleInputStreamOperatorto inputTransformations. - AbstractMultipleInputTransformation(String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
- AbstractMultipleInputTransformation(String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
- AbstractMutableHashTable<T> - Class in org.apache.flink.runtime.operators.hash
- AbstractMutableHashTable(TypeSerializer<T>, TypeComparator<T>) - Constructor for class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
- AbstractNonHaServices - Class in org.apache.flink.runtime.highavailability.nonha
-
Abstract base class for non high-availability services.
- AbstractNonHaServices() - Constructor for class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
- AbstractOuterJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
-
The abstract outer join driver implements the logic of an outer join operator at runtime.
- AbstractOuterJoinDriver() - Constructor for class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
- AbstractPagedInputView - Class in org.apache.flink.runtime.memory
-
The base class for all input views that are backed by multiple memory pages.
- AbstractPagedInputView(int) - Constructor for class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Creates a new view that is initially not bound to a memory segment.
- AbstractPagedInputView(MemorySegment, int, int) - Constructor for class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Creates a new view that starts with the given segment.
- AbstractPagedOutputView - Class in org.apache.flink.runtime.memory
-
The base class for all output views that are backed by multiple memory pages.
- AbstractPagedOutputView(int, int) - Constructor for class org.apache.flink.runtime.memory.AbstractPagedOutputView
- AbstractPagedOutputView(MemorySegment, int, int) - Constructor for class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
Creates a new output view that writes initially to the given initial segment.
- AbstractPartitionTracker<K,M> - Class in org.apache.flink.runtime.io.network.partition
-
Base partition tracker implementation, providing underlying data-structures for storing partitions, their associated keys and meta-information.
- AbstractPartitionTracker() - Constructor for class org.apache.flink.runtime.io.network.partition.AbstractPartitionTracker
- AbstractPerWindowStateStore(KeyedStateBackend<?>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.AbstractPerWindowStateStore
- AbstractReader - Class in org.apache.flink.runtime.io.network.api.reader
-
A basic reader implementation, which wraps an input gate and handles events.
- AbstractReader(InputGate) - Constructor for class org.apache.flink.runtime.io.network.api.reader.AbstractReader
- AbstractReducingState<K,N,V> - Class in org.apache.flink.runtime.state.v2
-
A default implementation of
ReducingStatewhich delegates all async requests toStateRequestHandler. - AbstractReducingState(StateRequestHandler, ReducingStateDescriptor<V>) - Constructor for class org.apache.flink.runtime.state.v2.AbstractReducingState
- AbstractResourceManagerDriver<WorkerType extends ResourceIDRetrievable> - Class in org.apache.flink.runtime.resourcemanager.active
-
Abstract common base class for implementations of
ResourceManagerDriver. - AbstractResourceManagerDriver(Configuration, Configuration) - Constructor for class org.apache.flink.runtime.resourcemanager.active.AbstractResourceManagerDriver
- AbstractResourceManagerHandler<T extends RestfulGateway,R extends RequestBody,P extends ResponseBody,M extends MessageParameters> - Class in org.apache.flink.runtime.rest.handler.resourcemanager
-
Base class for REST handlers which need access to the
ResourceManager. - AbstractResourceManagerHandler(GatewayRetriever<? extends T>, Duration, Map<String, String>, MessageHeaders<R, P, M>, GatewayRetriever<ResourceManagerGateway>) - Constructor for class org.apache.flink.runtime.rest.handler.resourcemanager.AbstractResourceManagerHandler
- AbstractRestHandler<T extends RestfulGateway,R extends RequestBody,P extends ResponseBody,M extends MessageParameters> - Class in org.apache.flink.runtime.rest.handler
-
Super class for netty-based handlers that work with
RequestBodys andResponseBodys. - AbstractRestHandler(GatewayRetriever<? extends T>, Duration, Map<String, String>, MessageHeaders<R, P, M>) - Constructor for class org.apache.flink.runtime.rest.handler.AbstractRestHandler
- AbstractServiceConnectionManager<S> - Class in org.apache.flink.runtime.jobmaster.slotpool
-
Base class for service connection managers, taking care of the connection handling.
- AbstractServiceConnectionManager() - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.AbstractServiceConnectionManager
- AbstractSlotPoolServiceFactory - Class in org.apache.flink.runtime.jobmaster.slotpool
-
Abstract SlotPoolServiceFactory.
- AbstractSlotPoolServiceFactory(Clock, Duration, Duration, Duration, Duration, boolean) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.AbstractSlotPoolServiceFactory
- AbstractStateBackend - Class in org.apache.flink.runtime.state
-
An abstract base implementation of the
StateBackendinterface. - AbstractStateBackend() - Constructor for class org.apache.flink.runtime.state.AbstractStateBackend
- AbstractStateIterator<T> - Class in org.apache.flink.runtime.asyncprocessing
-
A
StateIteratorimplementation to facilitate async data load of iterator. - AbstractStateIterator(State, StateRequestType, StateRequestHandler, Collection<T>) - Constructor for class org.apache.flink.runtime.asyncprocessing.AbstractStateIterator
- AbstractStreamOperator<OUT> - Class in org.apache.flink.streaming.api.operators
-
Base class for all stream operators.
- AbstractStreamOperator() - Constructor for class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- AbstractStreamOperator(StreamOperatorParameters<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- AbstractStreamOperatorFactory<OUT> - Class in org.apache.flink.streaming.api.operators
-
Base class for all stream operator factories.
- AbstractStreamOperatorFactory() - Constructor for class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
- AbstractStreamOperatorV2<OUT> - Class in org.apache.flink.streaming.api.operators
-
New base class for all stream operators, intended to eventually replace
AbstractStreamOperator. - AbstractStreamOperatorV2(StreamOperatorParameters<OUT>, int) - Constructor for class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- AbstractStreamTaskNetworkInput<T,R extends RecordDeserializer<DeserializationDelegate<StreamElement>>> - Class in org.apache.flink.streaming.runtime.io
-
Base class for network-based StreamTaskInput where each channel has a designated
RecordDeserializerfor spanning records. - AbstractStreamTaskNetworkInput(CheckpointedInputGate, TypeSerializer<T>, StatusWatermarkValve, int, Map<InputChannelInfo, R>, StreamTask.CanEmitBatchOfRecordsChecker) - Constructor for class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
- AbstractSubtaskAttemptHandler<R extends ResponseBody,M extends SubtaskAttemptMessageParameters> - Class in org.apache.flink.runtime.rest.handler.job
-
Base class for request handlers whose response depends on a specific attempt (defined via the "
SubtaskAttemptPathParameter.KEY" of a specific subtask (defined via the "SubtaskIndexPathParameter.KEY" in a specific job vertex, (defined via the "JobVertexIdPathParameter.KEY" parameter) in a specific job, defined via (defined via the "JobIDPathParameter.KEY" parameter). - AbstractSubtaskAttemptHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, R, M>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.AbstractSubtaskAttemptHandler
-
Instantiates a new Abstract job vertex handler.
- AbstractSubtaskHandler<R extends ResponseBody,M extends SubtaskMessageParameters> - Class in org.apache.flink.runtime.rest.handler.job
-
Base class for request handlers whose response depends on a specific subtask (defined via the "
SubtaskIndexPathParameter.KEY" in a specific job vertex, (defined via the "JobVertexIdPathParameter.KEY" parameter) in a specific job, defined via (defined via the "JobIDPathParameter.KEY" parameter). - AbstractSubtaskHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, R, M>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.AbstractSubtaskHandler
-
Instantiates a new Abstract job vertex handler.
- AbstractTaskManagerFileHandler<M extends TaskManagerMessageParameters> - Class in org.apache.flink.runtime.rest.handler.taskmanager
-
Base class for serving files from the
TaskExecutor. - AbstractTaskManagerFileHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, UntypedResponseMessageHeaders<EmptyRequestBody, M>, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, Duration) - Constructor for class org.apache.flink.runtime.rest.handler.taskmanager.AbstractTaskManagerFileHandler
- AbstractThreadsafeJobResultStore - Class in org.apache.flink.runtime.highavailability
-
An abstract class for threadsafe implementations of the
JobResultStore. - AbstractThreadsafeJobResultStore(Executor) - Constructor for class org.apache.flink.runtime.highavailability.AbstractThreadsafeJobResultStore
- AbstractTwoInputStreamTask<IN1,IN2,OUT> - Class in org.apache.flink.streaming.runtime.tasks
-
Abstract class for executing a
TwoInputStreamOperator. - AbstractTwoInputStreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
-
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
- AbstractTwoInputTransformationTranslator<IN1,IN2,OUT,OP extends org.apache.flink.api.dag.Transformation<OUT>> - Class in org.apache.flink.streaming.runtime.translators
-
A base class with functionality used during translating
transformationswith two inputs. - AbstractTwoInputTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.AbstractTwoInputTransformationTranslator
- AbstractUdfStreamOperator<OUT,F extends org.apache.flink.api.common.functions.Function> - Class in org.apache.flink.streaming.api.operators
-
This is used as the base class for operators that have a user-defined function.
- AbstractUdfStreamOperator(F) - Constructor for class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
- AbstractUdfStreamOperator(StreamOperatorParameters<OUT>, F) - Constructor for class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
- AbstractUserClassPathJobGraphRetriever - Class in org.apache.flink.runtime.entrypoint.component
-
Abstract class for the JobGraphRetriever which supports getting user classpaths.
- AbstractUserClassPathJobGraphRetriever(File) - Constructor for class org.apache.flink.runtime.entrypoint.component.AbstractUserClassPathJobGraphRetriever
- AbstractValueState<K,N,V> - Class in org.apache.flink.runtime.state.v2
-
A default implementation of
ValueStatewhich delegates all async requests toAsyncExecutionController. - AbstractValueState(StateRequestHandler, ValueStateDescriptor<V>) - Constructor for class org.apache.flink.runtime.state.v2.AbstractValueState
- ACC_TASK_BACK_PRESSURED_TIME - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- ACC_TASK_BUSY_TIME - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- ACC_TASK_IDLE_TIME - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- acceptJsonFormatVisitor(JsonFormatVisitorWrapper, JavaType) - Method in class org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson.Serializer
- acceptsFileUploads() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
- acceptsFileUploads() - Method in interface org.apache.flink.runtime.rest.messages.UntypedResponseMessageHeaders
-
Returns whether this header allows file uploads.
- AccessExecution - Interface in org.apache.flink.runtime.executiongraph
-
Common interface for the runtime
ExecutionandArchivedExecution. - AccessExecutionGraph - Interface in org.apache.flink.runtime.executiongraph
-
Common interface for the runtime
DefaultExecutionGraphandArchivedExecutionGraph. - AccessExecutionJobVertex - Interface in org.apache.flink.runtime.executiongraph
-
Common interface for the runtime
ExecutionJobVertexandArchivedExecutionJobVertex. - AccessExecutionVertex - Interface in org.apache.flink.runtime.executiongraph
-
Common interface for the runtime
ExecutionVertexandArchivedExecutionVertex. - accumulate(ByteBuf, ByteBuf, int, int) - Static method in class org.apache.flink.runtime.io.network.netty.ByteBufUtils
-
Accumulates data from source to target.
- accumulateBackPressuredTime - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
- accumulateBusyTime - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
- accumulateFinalResults() - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
- accumulateIdleTime - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
- accumulatorMap - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The accumulator map used in the RuntimeContext.
- AccumulatorRegistry - Class in org.apache.flink.runtime.accumulators
-
Main accumulator registry which encapsulates user-defined accumulators.
- AccumulatorRegistry(JobID, ExecutionAttemptID) - Constructor for class org.apache.flink.runtime.accumulators.AccumulatorRegistry
- AccumulatorReport - Class in org.apache.flink.runtime.taskexecutor
-
A report about the current values of all accumulators of the TaskExecutor for a given job.
- AccumulatorReport(List<AccumulatorSnapshot>) - Constructor for class org.apache.flink.runtime.taskexecutor.AccumulatorReport
- accumulatorResults(Map<String, SerializedValue<OptionalFailure<Object>>>) - Method in class org.apache.flink.runtime.jobmaster.JobResult.Builder
- AccumulatorsIncludeSerializedValueQueryParameter - Class in org.apache.flink.runtime.rest.messages
-
Query parameter for job's accumulator handler
JobAccumulatorsHandler. - AccumulatorsIncludeSerializedValueQueryParameter() - Constructor for class org.apache.flink.runtime.rest.messages.AccumulatorsIncludeSerializedValueQueryParameter
- AccumulatorSnapshot - Class in org.apache.flink.runtime.accumulators
-
This class encapsulates a map of accumulators for a single task.
- AccumulatorSnapshot(JobID, ExecutionAttemptID, Map<String, Accumulator<?, ?>>) - Constructor for class org.apache.flink.runtime.accumulators.AccumulatorSnapshot
- Acknowledge - Class in org.apache.flink.runtime.messages
-
A generic acknowledgement message.
- acknowledgeAllDataProcessed() - Method in class org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionDirectTransferReader
- acknowledgeAllDataProcessed() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.TieredStorageResultSubpartitionView
- acknowledgeAllDataProcessed() - Method in class org.apache.flink.runtime.io.network.partition.NoOpResultSubpartitionView
- acknowledgeAllDataProcessed() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartition
- acknowledgeAllDataProcessed() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartitionView
- acknowledgeAllDataProcessed() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
- acknowledgeAllDataProcessed() - Method in class org.apache.flink.runtime.io.network.partition.UnionResultSubpartitionView
- acknowledgeAllRecordsProcessed() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
Acknowledges all the user records are processed.
- acknowledgeAllRecordsProcessed() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
When received
EndOfDatafrom one channel, it need to acknowledge after this event get processed. - acknowledgeAllRecordsProcessed() - Method in class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
- acknowledgeAllRecordsProcessed() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RecoveredInputChannel
- acknowledgeAllRecordsProcessed() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- acknowledgeAllRecordsProcessed(InputChannelInfo) - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
- acknowledgeAllRecordsProcessed(InputChannelInfo) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- acknowledgeAllRecordsProcessed(InputChannelInfo) - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
- acknowledgeAllRecordsProcessed(InputChannelInfo) - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
- acknowledgeAllRecordsProcessed(RemoteInputChannel) - Method in class org.apache.flink.runtime.io.network.netty.NettyPartitionRequestClient
- acknowledgeAllRecordsProcessed(RemoteInputChannel) - Method in interface org.apache.flink.runtime.io.network.PartitionRequestClient
-
Acknowledges all user records are processed for this channel.
- acknowledgeCheckpoint(long, CheckpointMetrics) - Method in interface org.apache.flink.runtime.execution.Environment
-
Confirms that the invokable has successfully completed all steps it needed to for the checkpoint with the give checkpoint-ID.
- acknowledgeCheckpoint(long, CheckpointMetrics) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- acknowledgeCheckpoint(long, CheckpointMetrics, TaskStateSnapshot) - Method in interface org.apache.flink.runtime.execution.Environment
-
Confirms that the invokable has successfully completed all required steps for the checkpoint with the give checkpoint-ID.
- acknowledgeCheckpoint(long, CheckpointMetrics, TaskStateSnapshot) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Method in class org.apache.flink.runtime.scheduler.ExecutionGraphHandler
- acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
- acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcCheckpointResponder
- acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Method in interface org.apache.flink.runtime.taskmanager.CheckpointResponder
-
Acknowledges the given checkpoint.
- acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, SerializedValue<TaskStateSnapshot>) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointCoordinatorGateway
- acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, SerializedValue<TaskStateSnapshot>) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- AcknowledgeCheckpoint - Class in org.apache.flink.runtime.messages.checkpoint
-
This message is sent from the
TaskExecutorto theJobMasterto signal that the checkpoint of an individual task is completed. - AcknowledgeCheckpoint(JobID, ExecutionAttemptID, long) - Constructor for class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
- AcknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Constructor for class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
- AcknowledgeCheckpointEvent - Class in org.apache.flink.runtime.operators.coordination
-
An
OperatorEventsent from a subtask to itsOperatorCoordinatorto signal that the checkpoint of an individual task is completed. - AcknowledgeCheckpointEvent(long) - Constructor for class org.apache.flink.runtime.operators.coordination.AcknowledgeCheckpointEvent
- acknowledgeCoordinatorState(OperatorInfo, ByteStreamStateHandle) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
- acknowledgeMasterState(String, MasterState) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
Acknowledges a master state (state generated on the checkpoint coordinator) to the pending checkpoint.
- acknowledgeTask(ExecutionAttemptID, TaskStateSnapshot, CheckpointMetrics) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
Acknowledges the task with the given execution attempt id and the given subtask state.
- acquireLease() - Method in class org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
-
Returns a
ResourceGuard.Leasethat prevents closing this stream. - AcrossCheckpointFileMergingSnapshotManager - Class in org.apache.flink.runtime.checkpoint.filemerging
-
A
FileMergingSnapshotManagerthat merging files across checkpoints. - AcrossCheckpointFileMergingSnapshotManager(String, long, PhysicalFilePool.Type, float, Executor, MetricGroup) - Constructor for class org.apache.flink.runtime.checkpoint.filemerging.AcrossCheckpointFileMergingSnapshotManager
- ACTIVE - Static variable in class org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
- ACTIVE_STATUS - Static variable in class org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
- ActiveResourceManager<WorkerType extends ResourceIDRetrievable> - Class in org.apache.flink.runtime.resourcemanager.active
-
An active implementation of
ResourceManager. - ActiveResourceManager(ResourceManagerDriver<WorkerType>, Configuration, RpcService, UUID, ResourceID, HeartbeatServices, DelegationTokenManager, SlotManager, ResourceManagerPartitionTrackerFactory, BlocklistHandler.Factory, JobLeaderIdService, ClusterInformation, FatalErrorHandler, ResourceManagerMetricGroup, ThresholdMeter, Duration, Duration, Duration, Executor) - Constructor for class org.apache.flink.runtime.resourcemanager.active.ActiveResourceManager
- ActiveResourceManagerFactory<WorkerType extends ResourceIDRetrievable> - Class in org.apache.flink.runtime.resourcemanager.active
-
Factory class for creating
ActiveResourceManagerwith various implementations ofResourceManagerDriver. - ActiveResourceManagerFactory() - Constructor for class org.apache.flink.runtime.resourcemanager.active.ActiveResourceManagerFactory
- AdaptiveBatchScheduler - Class in org.apache.flink.runtime.scheduler.adaptivebatch
-
This scheduler decides the parallelism of JobVertex according to the data volume it consumes.
- AdaptiveBatchScheduler(Logger, JobGraph, Executor, Configuration, Consumer<ComponentMainThreadExecutor>, ScheduledExecutor, ClassLoader, CheckpointsCleaner, CheckpointRecoveryFactory, JobManagerJobMetricGroup, SchedulingStrategyFactory, FailoverStrategy.Factory, RestartBackoffTimeStrategy, ExecutionOperations, ExecutionVertexVersioner, ExecutionSlotAllocatorFactory, long, ComponentMainThreadExecutor, JobStatusListener, Collection<FailureEnricher>, ExecutionGraphFactory, ShuffleMaster<?>, Duration, VertexParallelismAndInputInfosDecider, int, BlocklistOperations, JobManagerOptions.HybridPartitionDataConsumeConstraint, Map<JobVertexID, ForwardGroup>, BatchJobRecoveryHandler) - Constructor for class org.apache.flink.runtime.scheduler.adaptivebatch.AdaptiveBatchScheduler
- AdaptiveBatchSchedulerFactory - Class in org.apache.flink.runtime.scheduler.adaptivebatch
-
Factory for
AdaptiveBatchScheduler. - AdaptiveBatchSchedulerFactory() - Constructor for class org.apache.flink.runtime.scheduler.adaptivebatch.AdaptiveBatchSchedulerFactory
- AdaptiveScheduler - Class in org.apache.flink.runtime.scheduler.adaptive
-
A
SchedulerNGimplementation that uses the declarative resource management and automatically adapts the parallelism in case not enough resource could be acquired to run at the configured parallelism, as described in FLIP-160. - AdaptiveScheduler(AdaptiveScheduler.Settings, JobGraph, JobResourceRequirements, Configuration, DeclarativeSlotPool, SlotAllocator, Executor, ClassLoader, CheckpointsCleaner, CheckpointRecoveryFactory, JobManagerJobMetricGroup, RestartBackoffTimeStrategy, long, ComponentMainThreadExecutor, FatalErrorHandler, JobStatusListener, Collection<FailureEnricher>, ExecutionGraphFactory) - Constructor for class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- AdaptiveScheduler.Settings - Class in org.apache.flink.runtime.scheduler.adaptive
-
Consolidated settings for the adaptive scheduler.
- AdaptiveSchedulerFactory - Class in org.apache.flink.runtime.scheduler.adaptive
-
Factory for the adaptive scheduler.
- AdaptiveSchedulerFactory() - Constructor for class org.apache.flink.runtime.scheduler.adaptive.AdaptiveSchedulerFactory
- add(boolean) - Method in class org.apache.flink.runtime.util.BooleanArrayList
- add(int) - Method in class org.apache.flink.runtime.util.IntArrayList
- add(long) - Method in class org.apache.flink.runtime.util.LongArrayList
- add(IN) - Method in class org.apache.flink.runtime.state.v2.AbstractAggregatingState
- add(IN) - Method in class org.apache.flink.runtime.state.v2.adaptor.MergingStateAdaptor
- add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction
- add(Map<ResourceProfile, Integer>) - Method in class org.apache.flink.runtime.util.ResourceCounter
-
Adds the given increment to this resource counter value and returns the resulting value.
- add(ResourceProfile, int) - Method in class org.apache.flink.runtime.util.ResourceCounter
-
Adds increment to the count of resourceProfile and returns the new value.
- add(BufferConsumer) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
- add(BufferConsumer, int) - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartition
- add(BufferConsumer, int) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
Adds the given buffer.
- add(NettyPayload) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyPayloadManager
- add(MetricDump) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
- add(StateObject.StateObjectLocation, long) - Method in class org.apache.flink.runtime.state.StateObject.StateObjectSizeStatsCollector
- add(ResourceCounter) - Method in class org.apache.flink.runtime.util.ResourceCounter
-
Adds increment to this resource counter value and returns the resulting value.
- add(S) - Method in class org.apache.flink.runtime.state.PartitionableListState
- add(T) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- add(T) - Method in class org.apache.flink.runtime.io.network.partition.DeduplicatedQueue
- add(T) - Method in class org.apache.flink.runtime.io.network.partition.PrioritizedDeque
-
Adds a non-priority element to this deque, which will be polled last.
- add(T) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
- add(T) - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueSet
-
Adds the element to the queue.
- add(T) - Method in class org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
- add(T) - Method in interface org.apache.flink.runtime.state.InternalPriorityQueue
-
Adds the given element to the set, if it is not already contained.
- add(T) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
Add the given task to the task slot.
- add(T) - Method in class org.apache.flink.runtime.util.BoundedFIFOQueue
-
Adds an element to the end of the queue.
- add(T) - Method in class org.apache.flink.streaming.api.operators.util.SimpleVersionedListState
- add(T) - Method in class org.apache.flink.streaming.runtime.watermarkstatus.HeapPriorityQueue
- add(T, boolean, boolean) - Method in class org.apache.flink.runtime.io.network.partition.PrioritizedDeque
-
Convenience method for adding an element with optional priority and prior removal.
- add(V) - Method in class org.apache.flink.runtime.state.v2.AbstractListState
- add(V) - Method in class org.apache.flink.runtime.state.v2.AbstractReducingState
- add(V) - Method in class org.apache.flink.runtime.state.v2.adaptor.ListStateAdaptor
- ADD_BUFFER_ERROR_CODE - Static variable in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
- addAll(Collection<? extends T>) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- addAll(Collection<? extends T>) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
- addAll(Collection<? extends T>) - Method in class org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
- addAll(Collection<? extends T>) - Method in interface org.apache.flink.runtime.state.InternalPriorityQueue
-
Adds all the given elements to the set.
- addAll(List<S>) - Method in class org.apache.flink.runtime.state.PartitionableListState
- addAll(List<T>) - Method in interface org.apache.flink.runtime.state.internal.InternalListState
-
Updates the operator state accessible by
AppendingState.get()by adding the given values to existing list of values. - addAll(List<T>) - Method in class org.apache.flink.streaming.api.operators.util.SimpleVersionedListState
- addAll(List<V>) - Method in class org.apache.flink.runtime.state.v2.AbstractListState
- addAll(List<V>) - Method in class org.apache.flink.runtime.state.v2.adaptor.ListStateAdaptor
- addAllocationOnPendingResource(JobID, PendingTaskManagerId, ResourceProfile) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceAllocationResult.Builder
- addAllocationOnRegisteredResource(JobID, InstanceID, ResourceProfile) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceAllocationResult.Builder
- addAndLock(String, T) - Method in interface org.apache.flink.runtime.persistence.StateHandleStore
-
Persist the state to distributed storage(e.g.
- addAndLock(String, T) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Creates a state handle, stores it in ZooKeeper and locks it.
- addAny(String, T) - Method in class org.apache.flink.runtime.rest.handler.router.Router
- addAppConfigurationEntry(String, AppConfigurationEntry...) - Method in class org.apache.flink.runtime.security.DynamicConfiguration
-
Add entries for the given application name.
- addBroadcastInputToGroup(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- addBufferListener(BufferListener) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
Adds a buffer availability listener to the buffer provider.
- addBufferListener(BufferListener) - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
- addChainedTask(Class<? extends ChainedDriver>, TaskConfig, String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- addCheckpointAndSubsumeOldestOne(CompletedCheckpoint, CheckpointsCleaner, Runnable) - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
Adds a
CompletedCheckpointinstance to the list of completed checkpoints. - addCheckpointAndSubsumeOldestOne(CompletedCheckpoint, CheckpointsCleaner, Runnable) - Method in enum org.apache.flink.runtime.checkpoint.DeactivatedCheckpointCompletedCheckpointStore
- addCheckpointAndSubsumeOldestOne(CompletedCheckpoint, CheckpointsCleaner, Runnable) - Method in class org.apache.flink.runtime.checkpoint.DefaultCompletedCheckpointStore
-
Synchronously writes the new checkpoints to state handle store and asynchronously removes older ones.
- addCheckpointAndSubsumeOldestOne(CompletedCheckpoint, CheckpointsCleaner, Runnable) - Method in class org.apache.flink.runtime.checkpoint.EmbeddedCompletedCheckpointStore
- addCheckpointAndSubsumeOldestOne(CompletedCheckpoint, CheckpointsCleaner, Runnable) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
- addClasspaths(Collection<URL>) - Method in class org.apache.flink.runtime.jobgraph.JobGraphBuilder
- addConcurrentExceptions(Iterable<Execution>) - Method in class org.apache.flink.runtime.scheduler.exceptionhistory.RootExceptionHistoryEntry
- addConnect(String, T) - Method in class org.apache.flink.runtime.rest.handler.router.Router
- addConsumedPartitionGroup(ConsumedPartitionGroup) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- addConsumer(JobEdge) - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
- addConsumers(ConsumerVertexGroup) - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
- addCoOperator(Integer, String, String, StreamOperatorFactory<OUT>, TypeInformation<IN1>, TypeInformation<IN2>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- addCredit(int) - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
The credits from consumer are added in incremental way.
- addCustomHeader(HttpHeader) - Method in class org.apache.flink.runtime.rest.messages.CustomHeadersDecorator
-
Adds a custom header to the message.
- addDelete(String, T) - Method in class org.apache.flink.runtime.rest.handler.router.Router
- addDurationMetric(String, long) - Method in class org.apache.flink.runtime.checkpoint.SubTaskInitializationMetricsBuilder
-
This adds a custom "duration" type metric, handled and aggregated by the
JobInitializationMetricsBuilder. - addEdge(Integer, Integer, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- addEdge(Integer, Integer, int, IntermediateDataSetID) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- addFeedbackEdge(Transformation<F>) - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
Adds a feedback edge.
- addFeedbackEdge(Transformation<T>) - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
Adds a feedback edge.
- addFileUploadRoute(String) - Method in class org.apache.flink.runtime.rest.handler.router.MultipartRoutes.Builder
- addGet(String, T) - Method in class org.apache.flink.runtime.rest.handler.router.Router
- addGlobalCommitter(DataStream<CommittableMessage<CommT>>, SerializableSupplier<Committer<CommT>>, SerializableSupplier<SimpleVersionedSerializer<CommT>>) - Static method in class org.apache.flink.streaming.api.connector.sink2.StandardSinkTopologies
-
Adds a global committer to the pipeline that runs as final operator with a parallelism of one.
- addGroup(String) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
- addGroup(String) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
- addGroup(String, String) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
- addGroup(String, String) - Method in class org.apache.flink.runtime.metrics.groups.GenericKeyMetricGroup
- addGroup(String, String) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
- addHash(int) - Method in class org.apache.flink.runtime.operators.util.BloomFilter
- addHead(String, T) - Method in class org.apache.flink.runtime.rest.handler.router.Router
- addInEdge(StreamEdge) - Method in class org.apache.flink.streaming.api.graph.StreamNode
- addInput(Transformation<?>) - Method in class org.apache.flink.streaming.api.transformations.MultipleInputTransformation
- addInput(Transformation<?>, KeySelector<?, ?>) - Method in class org.apache.flink.streaming.api.transformations.KeyedMultipleInputTransformation
- addInputChannel(RemoteInputChannel) - Method in interface org.apache.flink.runtime.io.network.NetworkClientHandler
- addInputData(long, InputChannelInfo, int, CloseableIterator<Buffer>) - Method in interface org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter
-
Add in-flight buffers from the
InputChannel. - addInputData(long, InputChannelInfo, int, CloseableIterator<Buffer>) - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter.NoOpChannelStateWriter
- addInputData(long, InputChannelInfo, int, CloseableIterator<Buffer>) - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriterImpl
- addInputFormat(OperatorID, InputFormat<?, ?>) - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
- addInputFormat(OperatorID, UserCodeWrapper<? extends InputFormat<?, ?>>) - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
- addInputFormat(OperatorID, UserCodeWrapper<? extends InputFormat<?, ?>>) - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer.FormatUserCodeTable
- addInputRequirement(int, StreamConfig.InputRequirement) - Method in class org.apache.flink.streaming.api.graph.StreamNode
- addInputToGroup(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- addIntermediateDataSetIdToConsume(IntermediateDataSetID) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- addInternal(T) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
-
Implements how to add an element to the queue.
- addInternal(T) - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueue
- addIOMetrics(AccessExecution, MetricFetcher, String, String) - Method in class org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
-
Adds the IO metrics for the given attempt to this object.
- addIterationAggregator(String, Aggregator<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- addIterationAggregators(Collection<AggregatorWithName<?>>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- addJar(Path) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Adds the path of a JAR file required to run the job on a task manager.
- addJars(List<URL>) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Adds the given jar files to the
JobGraphviaJobGraph.addJar(org.apache.flink.core.fs.Path). - addJob(JobID) - Method in class org.apache.flink.runtime.resourcemanager.DefaultJobLeaderIdService
- addJob(JobID) - Method in interface org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
Add a job to be monitored to retrieve the job leader id.
- addJob(JobID, String) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
- addJob(JobID, String) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
- addJob(JobID, String) - Method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredJobManagerMetricGroup
- addJob(JobID, String) - Method in class org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService
- addJob(JobID, String) - Method in interface org.apache.flink.runtime.taskexecutor.JobLeaderService
-
Add the given job to be monitored.
- addJobVertex(JobVertex) - Method in class org.apache.flink.runtime.jobgraph.JobGraphBuilder
- addJobVertices(Collection<? extends JobVertex>) - Method in class org.apache.flink.runtime.jobgraph.JobGraphBuilder
- addLegacySource(Integer, String, String, StreamOperatorFactory<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- addLineageEdge(LineageEdge) - Method in class org.apache.flink.streaming.api.lineage.DefaultLineageGraph.LineageGraphBuilder
- addLineageEdges(LineageEdge...) - Method in class org.apache.flink.streaming.api.lineage.DefaultLineageGraph.LineageGraphBuilder
- addMasterHook(MasterTriggerRestoreHook<?>) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Adds the given master hook to the checkpoint coordinator.
- addMessage(CommittableMessage<CommT>) - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
-
Adds a
CommittableMessageto the collector to hold it until emission. - addMetric(String, long) - Method in interface org.apache.flink.runtime.state.StateBackend.CustomInitializationMetrics
- addMetric(String, Metric) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Adds the given metric to the group and registers it at the registry, if the group is not yet closed, and if no metric with the same name has been registered before.
- addMetric(String, Metric, AbstractMetricGroup) - Method in class org.apache.flink.runtime.metrics.dump.MetricQueryService
- addMultipleInputOperator(Integer, String, String, StreamOperatorFactory<OUT>, List<TypeInformation<?>>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- addNewBlockedNodes(Collection<BlockedNode>) - Method in interface org.apache.flink.runtime.blocklist.BlocklistHandler
-
Add new blocked node records.
- addNewBlockedNodes(Collection<BlockedNode>) - Method in interface org.apache.flink.runtime.blocklist.BlocklistOperations
-
Add new blocked node records.
- addNewBlockedNodes(Collection<BlockedNode>) - Method in interface org.apache.flink.runtime.blocklist.BlocklistTracker
-
Add new blocked node records.
- addNewBlockedNodes(Collection<BlockedNode>) - Method in class org.apache.flink.runtime.blocklist.DefaultBlocklistHandler
- addNewBlockedNodes(Collection<BlockedNode>) - Method in class org.apache.flink.runtime.blocklist.DefaultBlocklistTracker
- addNewBlockedNodes(Collection<BlockedNode>) - Method in class org.apache.flink.runtime.blocklist.NoOpBlocklistHandler
- addNode(Integer, String, String, Class<? extends TaskInvokable>, StreamOperatorFactory<?>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- addOperator(Integer, String, String, StreamOperatorFactory<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- addOperator(Transformation<?>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Adds an operator to the list of operators that should be executed when calling
StreamExecutionEnvironment.execute(). - addOperatorCoordinator(SerializedValue<OperatorCoordinator.Provider>) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- addOptions(String, T) - Method in class org.apache.flink.runtime.rest.handler.router.Router
- addOutEdge(StreamEdge) - Method in class org.apache.flink.streaming.api.graph.StreamNode
- addOutputData(long, ResultSubpartitionInfo, int, Buffer...) - Method in interface org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter
-
Add in-flight buffers from the
ResultSubpartition. - addOutputData(long, ResultSubpartitionInfo, int, Buffer...) - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter.NoOpChannelStateWriter
- addOutputData(long, ResultSubpartitionInfo, int, Buffer...) - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriterImpl
- addOutputDataFuture(long, ResultSubpartitionInfo, int, CompletableFuture<List<Buffer>>) - Method in interface org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter
-
Add in-flight bufferFuture from the
ResultSubpartition. - addOutputDataFuture(long, ResultSubpartitionInfo, int, CompletableFuture<List<Buffer>>) - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter.NoOpChannelStateWriter
- addOutputDataFuture(long, ResultSubpartitionInfo, int, CompletableFuture<List<Buffer>>) - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriterImpl
- addOutputFormat(OperatorID, OutputFormat<?>) - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
- addOutputFormat(OperatorID, UserCodeWrapper<? extends OutputFormat<?>>) - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
- addOutputFormat(OperatorID, UserCodeWrapper<? extends OutputFormat<?>>) - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer.FormatUserCodeTable
- addOutputShipStrategy(ShipStrategyType) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- addParameters(OperatorID, String, String) - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
- addParameters(OperatorID, Configuration) - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
- addPartialBuffer(Buffer) - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- addPartitionAndGetShuffleDescriptor(JobID, ResultPartitionID) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredInternalShuffleMaster
- addPartitionAndGetShuffleDescriptor(JobID, ResultPartitionID) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMasterClient
- addPartitionAndGetShuffleDescriptor(JobID, ResultPartitionID) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.NoOpMasterAgent
- addPartitionAndGetShuffleDescriptor(JobID, ResultPartitionID) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierMasterAgent
- addPartitionAndGetShuffleDescriptor(JobID, ResultPartitionID) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierMasterAgent
-
Add a new tiered storage partition and get the
TierShuffleDescriptor. - addPatch(String, T) - Method in class org.apache.flink.runtime.rest.handler.router.Router
- addPendingTaskManager(PendingTaskManager) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- addPendingTaskManagerAllocate(PendingTaskManager) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceAllocationResult.Builder
- addPendingTaskManagerToAllocate(PendingTaskManager) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceReconcileResult.Builder
- addPendingTaskManagerToRelease(PendingTaskManager) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceReconcileResult.Builder
- addPost(String, T) - Method in class org.apache.flink.runtime.rest.handler.router.Router
- addPostCommitTopology(DataStream<CommittableMessage<CommittableT>>) - Method in interface org.apache.flink.streaming.api.connector.sink2.SupportsPostCommitTopology
-
Adds a custom post-commit topology where all committables can be processed.
- addPostRoute(String) - Method in class org.apache.flink.runtime.rest.handler.router.MultipartRoutes.Builder
- addPreCommitTopology(DataStream<CommittableMessage<WriterResultT>>) - Method in interface org.apache.flink.streaming.api.connector.sink2.SupportsPreCommitTopology
-
Intercepts and modifies the committables sent on checkpoint or at end of input.
- addPreWriteTopology(DataStream<InputT>) - Method in interface org.apache.flink.streaming.api.connector.sink2.SupportsPreWriteTopology
-
Adds an arbitrary topology before the writer.
- addPriorityElement(T) - Method in class org.apache.flink.runtime.io.network.partition.PrioritizedDeque
-
Adds a priority element to this deque, such that it will be polled after all existing priority elements but before any non-priority element.
- addProcessedBytes(int) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
- addPut(String, T) - Method in class org.apache.flink.runtime.rest.handler.router.Router
- addRecord(IN) - Method in class org.apache.flink.streaming.api.operators.MapPartitionIterator
- addRecord(T) - Method in class org.apache.flink.runtime.operators.sort.LargeRecordHandler
- addRecovered(int, BufferConsumer) - Method in interface org.apache.flink.runtime.io.network.partition.CheckpointedResultPartition
- addRecovered(int, BufferConsumer) - Method in class org.apache.flink.runtime.io.network.partition.PipelinedResultPartition
- addRequest(R) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
- address() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
Returns the network address the instance's task manager binds its sockets to.
- addressString() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
Gets the IP address where the TaskManager operates.
- addRoute(HttpMethod, String, T) - Method in class org.apache.flink.runtime.rest.handler.router.Router
-
Add route.
- addShuffleDescriptors(Map<ResultPartitionID, ShuffleDescriptor>) - Method in class org.apache.flink.runtime.io.network.partition.DataSetMetaInfo
- addSink(Integer, String, String, StreamOperatorFactory<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- addSink(SinkFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Adds the given sink to this DataStream.
- addSink(SinkFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
- addSlots(Collection<AllocatedSlot>, long) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotPool
-
Adds the given collection of slots to the slot pool.
- addSlots(Collection<AllocatedSlot>, long) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultAllocatedSlotPool
- addSource(Integer, String, String, SourceOperatorFactory<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- addSource(SourceFunction<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Deprecated.This method relies on the
SourceFunctionAPI, which is due to be removed. Use theStreamExecutionEnvironment.fromSource(Source, WatermarkStrategy, String)method based on the newSourceAPI instead. - addSource(SourceFunction<OUT>, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Deprecated.This method relies on the
SourceFunctionAPI, which is due to be removed. Use theStreamExecutionEnvironment.fromSource(Source, WatermarkStrategy, String)method based on the newSourceAPI instead. - addSource(SourceFunction<OUT>, String, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Deprecated.This method relies on the
SourceFunctionAPI, which is due to be removed. Use theStreamExecutionEnvironment.fromSource(Source, WatermarkStrategy, String, TypeInformation)method based on the newSourceAPI instead. - addSource(SourceFunction<OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Deprecated.This method relies on the
SourceFunctionAPI, which is due to be removed. Use theStreamExecutionEnvironment.fromSource(Source, WatermarkStrategy, String, TypeInformation)method based on the newSourceAPI instead. - addSpan(SpanBuilder) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
- addSpan(SpanBuilder) - Method in class org.apache.flink.runtime.metrics.groups.JobMetricGroup
- addSpan(SpanBuilder) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
- addSpan(SpanBuilder) - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
-
Add and log a
Span. - addSpan(SpanBuilder) - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
- addSpan(SpanBuilder) - Method in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
- AddSplitEvent<SplitT> - Class in org.apache.flink.runtime.source.event
-
A source event that adds splits to a source reader.
- AddSplitEvent(List<SplitT>, SimpleVersionedSerializer<SplitT>) - Constructor for class org.apache.flink.runtime.source.event.AddSplitEvent
- addSubsumedCheckpoint(CompletedCheckpoint) - Method in class org.apache.flink.runtime.checkpoint.CheckpointsCleaner
-
Add one subsumed checkpoint to CheckpointsCleaner, the subsumed checkpoint would be discarded at
CheckpointsCleaner.cleanSubsumedCheckpoints(long, Set, Runnable, Executor). - addTask(ExecutionAttemptID, String) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
- addTask(ExecutionAttemptID, String) - Method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredTaskManagerJobMetricGroup
- addTask(T) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Add the given task to the slot identified by the task's allocation id.
- addTask(T) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- addTaskManager(TaskExecutorConnection, ResourceProfile, ResourceProfile) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- addTaskManagerToRelease(TaskManagerInfo) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceReconcileResult.Builder
- addToken(String, byte[]) - Method in class org.apache.flink.runtime.security.token.DelegationTokenContainer
- addToMessageDigest(MessageDigest) - Method in class org.apache.flink.runtime.blob.BlobKey
-
Adds the BLOB key to the given
MessageDigest. - addToSubpartition(int, BufferConsumer, int) - Method in class org.apache.flink.runtime.io.network.partition.BufferWritingResultPartition
- addTrace(String, T) - Method in class org.apache.flink.runtime.rest.handler.router.Router
- addUnfulfillableJob(JobID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceAllocationResult.Builder
- addUnWantedTaskManager(InstanceID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- addUserArtifact(String, DistributedCache.DistributedCacheEntry) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Adds the path of a custom file required to run the job on a task manager.
- addUserArtifacts(Map<String, DistributedCache.DistributedCacheEntry>) - Method in class org.apache.flink.runtime.jobgraph.JobGraphBuilder
- addUserJarBlobKey(PermanentBlobKey) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Adds the BLOB referenced by the key to the JobGraph's dependencies.
- addVertex(JobVertex) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Adds a new task vertex to the job graph if it is not already included.
- addVertex(JobVertex) - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroupImpl
- addVertexToGroup(JobVertexID) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
- addVirtualPartitionNode(Integer, Integer, StreamPartitioner<?>, StreamExchangeMode) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Adds a new virtual node that is used to connect a downstream vertex to an input with a certain partitioning.
- addVirtualSideOutputNode(Integer, Integer, OutputTag) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Adds a new virtual node that is used to connect a downstream vertex to only the outputs with the selected side-output
OutputTag. - addWindow(W, MergingWindowSet.MergeFunction<W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
-
Adds a new
Windowto the set of in-flight windows. - adjustForLocalExecution(Configuration) - Static method in class org.apache.flink.runtime.taskexecutor.TaskExecutorResourceUtils
- adjustModifiedElement(T) - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueue
- adjustModifiedElement(T) - Method in class org.apache.flink.streaming.runtime.watermarkstatus.HeapPriorityQueue
- adjustTop() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
-
Should be called when the Object at top changes values.
- advance() - Method in class org.apache.flink.runtime.io.disk.iomanager.HeaderlessChannelReaderInputView
- advance() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Advances the view to the next memory segment.
- advance() - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
Moves the output view to the next page.
- advanceLastCheckpointId(long) - Method in class org.apache.flink.runtime.checkpoint.filemerging.LogicalFile
-
A logical file may share across checkpoints (especially for shared state).
- advanceToEndOfEventTime() - Method in class org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
- advanceToEndOfEventTime() - Method in class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask
- advanceToEndOfEventTime() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
Deprecated.
- advanceToEndOfEventTime() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Emits the
MAX_WATERMARKso that all registered timers are fired. - advanceWatermark(long) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceAsyncImpl
-
Advance one watermark, this will fire some event timers.
- advanceWatermark(long) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
- advanceWatermark(Watermark) - Method in interface org.apache.flink.streaming.api.operators.InternalTimeServiceManager
-
Advances the Watermark of all managed
timer services, potentially firing event time timers. - advanceWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManagerImpl
- advanceWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeServiceManager
- afterInvoke() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- aggregate(AggregateFunction<T, ACC, R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given
AggregateFunctionto each window. - aggregate(AggregateFunction<T, ACC, R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedPartitionWindowedStream
- aggregate(AggregateFunction<T, ACC, R>) - Method in class org.apache.flink.streaming.api.datastream.NonKeyedPartitionWindowedStream
- aggregate(AggregateFunction<T, ACC, R>) - Method in interface org.apache.flink.streaming.api.datastream.PartitionWindowedStream
-
Applies an aggregate transformation on the records of the window.
- aggregate(AggregateFunction<T, ACC, R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given aggregation function to each window.
- aggregate(AggregateFunction<T, ACC, R>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given
AggregateFunctionto each window. - aggregate(AggregateFunction<T, ACC, R>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given aggregation function to each window.
- aggregate(AggregateFunction<T, ACC, V>, AllWindowFunction<V, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- aggregate(AggregateFunction<T, ACC, V>, AllWindowFunction<V, R, W>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- aggregate(AggregateFunction<T, ACC, V>, ProcessAllWindowFunction<V, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- aggregate(AggregateFunction<T, ACC, V>, ProcessAllWindowFunction<V, R, W>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- aggregate(AggregateFunction<T, ACC, V>, ProcessWindowFunction<V, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- aggregate(AggregateFunction<T, ACC, V>, ProcessWindowFunction<V, R, K, W>, TypeInformation<ACC>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
- aggregate(AggregateFunction<T, ACC, V>, ProcessWindowFunction<V, R, K, W>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- aggregate(AggregateFunction<T, ACC, V>, WindowFunction<V, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- aggregate(AggregateFunction<T, ACC, V>, WindowFunction<V, R, K, W>, TypeInformation<ACC>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
- aggregate(AggregateFunction<T, ACC, V>, WindowFunction<V, R, K, W>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- aggregate(AggregationFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
- AggregateApplyAllWindowFunction<W extends Window,T,ACC,V,R> - Class in org.apache.flink.streaming.api.functions.windowing
- AggregateApplyAllWindowFunction(AggregateFunction<T, ACC, V>, AllWindowFunction<V, R, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.AggregateApplyAllWindowFunction
- AggregateApplyWindowFunction<K,W extends Window,T,ACC,V,R> - Class in org.apache.flink.streaming.api.functions.windowing
- AggregateApplyWindowFunction(AggregateFunction<T, ACC, V>, WindowFunction<V, R, K, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.AggregateApplyWindowFunction
- AggregatedJobMetricsHeaders - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
Headers for aggregating job metrics.
- AggregatedJobMetricsParameters - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
Parameters for aggregating job metrics.
- AggregatedJobMetricsParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedJobMetricsParameters
- AggregatedMetric - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
Response type for aggregated metrics.
- AggregatedMetric(String) - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
- AggregatedMetric(String, Double, Double, Double, Double, Double) - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
- AggregatedMetricsResponseBody - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
Response type for a collection of aggregated metrics.
- AggregatedMetricsResponseBody(Collection<AggregatedMetric>) - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetricsResponseBody
- AggregatedMetricsResponseBody.Deserializer - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
JSON deserializer for
AggregatedMetricsResponseBody. - AggregatedMetricsResponseBody.Serializer - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
JSON serializer for
AggregatedMetricsResponseBody. - AggregatedSubtaskMetricsHeaders - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
Headers for aggregating subtask metrics.
- AggregatedSubtaskMetricsParameters - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
Parameters for aggregating subtask metrics.
- AggregatedSubtaskMetricsParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedSubtaskMetricsParameters
- AggregatedTaskDetailsInfo - Class in org.apache.flink.runtime.rest.messages
-
Aggregated info of a set of tasks.
- AggregatedTaskDetailsInfo(Map<String, Map<String, Long>>, Map<String, Map<String, Long>>) - Constructor for class org.apache.flink.runtime.rest.messages.AggregatedTaskDetailsInfo
- AggregatedTaskManagerMetricsHeaders - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
Headers for aggregating task manager metrics.
- aggregateFunction - Variable in class org.apache.flink.runtime.state.v2.AbstractAggregatingState
- AggregateTaskManagerMetricsParameters - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
Parameters for aggregating task manager metrics.
- AggregateTaskManagerMetricsParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.AggregateTaskManagerMetricsParameters
- aggregateUserAccumulators() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- aggregateUserAccumulators() - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Merges all accumulator results from the tasks previously executed in the Executions.
- AGGREGATING - org.apache.flink.runtime.state.v2.StateDescriptor.Type
- AGGREGATING_ADD - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Add element to aggregating state by
AppendingState.asyncAdd(Object). - AGGREGATING_GET - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Get value from aggregating state by
AppendingState.asyncGet(). - AGGREGATING_REMOVE - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Remove element from aggregate state.
- AggregatingJobsMetricsHandler - Class in org.apache.flink.runtime.rest.handler.job.metrics
-
Request handler that returns, aggregated across jobs, a list of all available metrics or the values for a set of metrics.
- AggregatingJobsMetricsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.AggregatingJobsMetricsHandler
- AggregatingStateAdaptor<K,N,IN,ACC,OUT> - Class in org.apache.flink.runtime.state.v2.adaptor
-
An adaptor that transforms
InternalAggregatingStateintoInternalAggregatingState. - AggregatingStateAdaptor(InternalAggregatingState<K, N, IN, ACC, OUT>) - Constructor for class org.apache.flink.runtime.state.v2.adaptor.AggregatingStateAdaptor
- AggregatingStateDescriptor<IN,ACC,OUT> - Class in org.apache.flink.runtime.state.v2
-
A
StateDescriptorforAggregatingState. - AggregatingStateDescriptor(String, AggregateFunction<IN, ACC, OUT>, TypeInformation<ACC>) - Constructor for class org.apache.flink.runtime.state.v2.AggregatingStateDescriptor
-
Create a new state descriptor with the given name, function, and type.
- AggregatingStateDescriptor(String, AggregateFunction<IN, ACC, OUT>, TypeInformation<ACC>, SerializerConfig) - Constructor for class org.apache.flink.runtime.state.v2.AggregatingStateDescriptor
-
Create a new state descriptor with the given name, function, and type.
- AggregatingSubtasksMetricsHandler - Class in org.apache.flink.runtime.rest.handler.job.metrics
-
Request handler that returns, aggregated across subtasks, a list of all available metrics or the values for a set of metrics.
- AggregatingSubtasksMetricsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.AggregatingSubtasksMetricsHandler
- AggregatingTaskManagersMetricsHandler - Class in org.apache.flink.runtime.rest.handler.job.metrics
-
Request handler that returns, aggregated across task managers, a list of all available metrics or the values for a set of metrics.
- AggregatingTaskManagersMetricsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.AggregatingTaskManagersMetricsHandler
- AggregationFunction<T> - Class in org.apache.flink.streaming.api.functions.aggregation
-
Holder class for aggregation types that can be used on a windowed stream or keyed stream.
- AggregationFunction() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.AggregationFunction
- AggregationFunction.AggregationType - Enum in org.apache.flink.streaming.api.functions.aggregation
-
Aggregation types that can be used on a windowed stream or keyed stream.
- AGGREGATOR_NAME - Static variable in class org.apache.flink.runtime.iterative.convergence.WorksetEmptyConvergenceCriterion
- AirBlockCompressor - Class in org.apache.flink.runtime.io.compression
-
Flink compressor that wraps
Compressor. - AirBlockCompressor(Compressor) - Constructor for class org.apache.flink.runtime.io.compression.AirBlockCompressor
- AirBlockDecompressor - Class in org.apache.flink.runtime.io.compression
-
Flink decompressor that wraps
Decompressor. - AirBlockDecompressor(Decompressor) - Constructor for class org.apache.flink.runtime.io.compression.AirBlockDecompressor
- AirCompressorFactory - Class in org.apache.flink.runtime.io.compression
- AirCompressorFactory(Compressor, Decompressor) - Constructor for class org.apache.flink.runtime.io.compression.AirCompressorFactory
- aligned(String, CheckpointableTask, Clock, int, BarrierAlignmentUtil.DelayableTimer, boolean, CheckpointableInput...) - Static method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
- ALIGNED - org.apache.flink.runtime.checkpoint.CheckpointOptions.AlignmentType
- ALIGNED - org.apache.flink.streaming.api.windowing.assigners.WindowStagger
-
Default mode, all panes fire at the same time across all partitions.
- ALIGNED_CHECKPOINT_BARRIER - org.apache.flink.runtime.io.network.buffer.Buffer.DataType
-
Buffer.DataType.ALIGNED_CHECKPOINT_BARRIERindicates that this buffer represents a serialized checkpoint barrier of aligned exactly-once checkpoint mode. - alignedBarrierTimeout(long) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
- alignedBarrierTimeout(long) - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
Timeout the aligned barrier to unaligned barrier.
- alignedBarrierTimeout(long) - Method in class org.apache.flink.runtime.io.network.partition.BufferWritingResultPartition
- alignedBarrierTimeout(long) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartition
- alignedBarrierTimeout(long) - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartition
- alignedBarrierTimeout(long) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
- alignedBarrierTimeout(long) - Method in class org.apache.flink.runtime.io.network.partition.SortMergeResultPartition
- alignedBarrierTimeout(long) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
- alignedBarrierTimeout(long) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- alignedNoTimeout(SnapshotType, CheckpointStorageLocationReference) - Static method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
- alignedWithTimeout(SnapshotType, CheckpointStorageLocationReference, long) - Static method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
- ALL - org.apache.flink.runtime.jobmanager.scheduler.LocationPreferenceConstraint
- ALL - Static variable in class org.apache.flink.streaming.api.operators.InputSelection
-
The
InputSelectioninstance which indicates to select all inputs. - ALL_DATA_PRODUCED - org.apache.flink.runtime.scheduler.strategy.ResultPartitionState
-
Partition has produced all data.
- ALL_EDGES_BLOCKING - org.apache.flink.streaming.api.graph.GlobalStreamExchangeMode
-
Set all job edges to be
ResultPartitionType.BLOCKING. - ALL_EDGES_HYBRID_FULL - org.apache.flink.streaming.api.graph.GlobalStreamExchangeMode
-
Set all job edges
ResultPartitionType.HYBRID_FULL. - ALL_EDGES_HYBRID_SELECTIVE - org.apache.flink.streaming.api.graph.GlobalStreamExchangeMode
-
Set all job edges
ResultPartitionType.HYBRID_SELECTIVE. - ALL_EDGES_PIPELINED - org.apache.flink.streaming.api.graph.GlobalStreamExchangeMode
-
Set all job edges
ResultPartitionType.PIPELINED_BOUNDED. - ALL_EDGES_PIPELINED_APPROXIMATE - org.apache.flink.streaming.api.graph.GlobalStreamExchangeMode
-
Set all job edges
ResultPartitionType.PIPELINED_APPROXIMATE. - ALL_GROUP_COMBINE - org.apache.flink.runtime.operators.DriverStrategy
- ALL_GROUP_REDUCE - org.apache.flink.runtime.operators.DriverStrategy
- ALL_GROUP_REDUCE_COMBINE - org.apache.flink.runtime.operators.DriverStrategy
- ALL_REDUCE - org.apache.flink.runtime.operators.DriverStrategy
- ALL_TO_ALL - org.apache.flink.runtime.jobgraph.DistributionPattern
-
Each producing sub task is connected to each sub task of the consuming task.
- allActionsCompleted() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.MailboxDefaultAction.Controller
-
This method must be called to end the stream task when all actions for the tasks have been performed.
- allActionsCompleted() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
This method must be called to end the stream task when all actions for the tasks have been performed.
- allActionsCompleted() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.MailboxController
- allAllowedMethods() - Method in class org.apache.flink.runtime.rest.handler.router.Router
-
Returns all methods that this router handles.
- allChannelsRecovered() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
- allChannelsRecovered() - Method in interface org.apache.flink.streaming.runtime.io.checkpointing.UpstreamRecoveryTracker
- allFieldsNoLessThan(ResourceProfile) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Check whether all fields of this resource profile are no less than the given resource profile.
- AllFinishedInputConsumableDecider - Class in org.apache.flink.runtime.scheduler.strategy
-
AllFinishedInputConsumableDecideris a specialInputConsumableDecider. - AllFinishedInputConsumableDecider() - Constructor for class org.apache.flink.runtime.scheduler.strategy.AllFinishedInputConsumableDecider
- AllFinishedInputConsumableDecider.Factory - Class in org.apache.flink.runtime.scheduler.strategy
-
Factory for
AllFinishedInputConsumableDecider. - AllGroupCombineDriver<IN,OUT> - Class in org.apache.flink.runtime.operators
-
Non-chained driver for the partial group reduce operator that acts like a combiner with a custom output type OUT.
- AllGroupCombineDriver() - Constructor for class org.apache.flink.runtime.operators.AllGroupCombineDriver
- AllGroupReduceDriver<IT,OT> - Class in org.apache.flink.runtime.operators
-
GroupReduceDriver task which is executed by a Task Manager.
- AllGroupReduceDriver() - Constructor for class org.apache.flink.runtime.operators.AllGroupReduceDriver
- alloc() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- ALLOC - org.apache.flink.runtime.rest.messages.ProfilingInfo.ProfilingMode
- allocateAndConfigureBuffer(int) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.index.FileRegionWriteReadUtils
-
Allocate a buffer with specific size and configure it to native order.
- allocateAvailableSlot(SlotRequestId, AllocationID, ResourceProfile) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolBridge
- allocateAvailableSlot(SlotRequestId, AllocationID, ResourceProfile) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Allocates the available slot with the given allocation id under the given request id for the given requirement profile.
- allocatedHeaderBuffer() - Static method in class org.apache.flink.runtime.io.network.partition.BufferReaderWriterUtil
- AllocatedSlotActions - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
Interface for components which have to perform actions on allocated slots.
- AllocatedSlotInfo - Class in org.apache.flink.runtime.jobmaster
-
Information about an allocated slot which is owned by a JobMaster.
- AllocatedSlotInfo(int, AllocationID) - Constructor for class org.apache.flink.runtime.jobmaster.AllocatedSlotInfo
- AllocatedSlotPool - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
The slot pool is responsible for maintaining a set of
AllocatedSlots. - AllocatedSlotPool.AllocatedSlotsAndReservationStatus - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
A collection of
AllocatedSlotsand their reservation status. - AllocatedSlotPool.FreeSlotInfo - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
Information about a free slot.
- AllocatedSlotReport - Class in org.apache.flink.runtime.jobmaster
-
The report of currently allocated slots from a given TaskExecutor by a JobMaster.
- AllocatedSlotReport(JobID, Collection<AllocatedSlotInfo>) - Constructor for class org.apache.flink.runtime.jobmaster.AllocatedSlotReport
- allocateFromPhysicalSlot(SlotRequestId, PhysicalSlot, Locality, SlotOwner, boolean) - Static method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
- allocatePages(Object, int) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Allocates a set of memory segments from this memory manager.
- allocatePages(Object, Collection<MemorySegment>, int) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Allocates a set of memory segments from this memory manager.
- allocatePhysicalSlots(Collection<PhysicalSlotRequest>) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlotProvider
-
Submit requests to allocate physical slots.
- allocatePhysicalSlots(Collection<PhysicalSlotRequest>) - Method in class org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlotProviderImpl
- allocateSegments(int) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
attempts to allocate specified number of segments and should only be used by compaction partition fails silently if not enough segments are available since next compaction could still succeed
- allocateSlot(int, JobID, AllocationID, Duration) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Allocate the slot with the given index for the given job and allocation id.
- allocateSlot(int, JobID, AllocationID, Duration) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- allocateSlot(int, JobID, AllocationID, ResourceProfile, Duration) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Allocate the slot with the given index for the given job and allocation id.
- allocateSlot(int, JobID, AllocationID, ResourceProfile, Duration) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- allocateSlot(InstanceID, JobID, String, ResourceProfile) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.DefaultSlotStatusSyncer
- allocateSlot(InstanceID, JobID, String, ResourceProfile) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotStatusSyncer
-
Allocate a slot from the task manager.
- allocateSlotsAndDeploy(List<Execution>, Map<ExecutionVertexID, ExecutionVertexVersion>) - Method in class org.apache.flink.runtime.scheduler.DefaultExecutionDeployer
- allocateSlotsAndDeploy(List<Execution>, Map<ExecutionVertexID, ExecutionVertexVersion>) - Method in interface org.apache.flink.runtime.scheduler.ExecutionDeployer
-
Allocate slots and deploy executions.
- allocateSlotsAndDeploy(List<ExecutionVertexID>) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.AdaptiveBatchScheduler
- allocateSlotsAndDeploy(List<ExecutionVertexID>) - Method in class org.apache.flink.runtime.scheduler.DefaultScheduler
- allocateSlotsAndDeploy(List<ExecutionVertexID>) - Method in interface org.apache.flink.runtime.scheduler.SchedulerOperations
-
Allocate slots and deploy the vertex when slots are returned.
- allocateSlotsFor(List<ExecutionAttemptID>) - Method in interface org.apache.flink.runtime.scheduler.ExecutionSlotAllocator
-
Allocate slots for the given executions.
- allocateSlotsFor(List<ExecutionAttemptID>) - Method in class org.apache.flink.runtime.scheduler.SimpleExecutionSlotAllocator
- ALLOCATION_DIR_PREFIX - Static variable in class org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager
- allocationBaseDirectory(long) - Method in interface org.apache.flink.runtime.state.LocalSnapshotDirectoryProvider
-
Returns the local state allocation base directory for given checkpoint id w.r.t. our rotation over all available allocation base directories.
- allocationBaseDirectory(long) - Method in class org.apache.flink.runtime.state.LocalSnapshotDirectoryProviderImpl
- allocationBaseDirsCount() - Method in interface org.apache.flink.runtime.state.LocalSnapshotDirectoryProvider
-
Returns the total number of allocation base directories.
- allocationBaseDirsCount() - Method in class org.apache.flink.runtime.state.LocalSnapshotDirectoryProviderImpl
- allocationID - Variable in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
AllocationID of the owning slot.
- AllocationID - Class in org.apache.flink.runtime.clusterframework.types
-
Unique identifier for a physical slot allocated by a JobManager via the ResourceManager from a TaskManager.
- AllocationID() - Constructor for class org.apache.flink.runtime.clusterframework.types.AllocationID
-
Constructs a new random AllocationID.
- AllocationID(long, long) - Constructor for class org.apache.flink.runtime.clusterframework.types.AllocationID
-
Constructs a new AllocationID with the given parts.
- allowedLateness - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
The allowed lateness for elements.
- allowedLateness - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorFactory
- allowedLateness(Duration) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Sets the time by which elements are allowed to be late.
- allowedLateness(Duration) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
-
Sets the time by which elements are allowed to be late.
- allowedLateness(Duration) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Sets the time by which elements are allowed to be late.
- allowedLateness(Duration) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Sets the time by which elements are allowed to be late.
- allowedLateness(Duration) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
- allowedMethods(String) - Method in class org.apache.flink.runtime.rest.handler.router.Router
-
Returns allowed methods for a specific URI.
- allowNonRestoredState() - Method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
-
Returns whether non restored state is allowed if the savepoint contains state that cannot be mapped back to the job.
- AllReduceDriver<T> - Class in org.apache.flink.runtime.operators
-
Reduce task which is executed by a Task Manager.
- AllReduceDriver() - Constructor for class org.apache.flink.runtime.operators.AllReduceDriver
- AllToAllBlockingResultInfo - Class in org.apache.flink.runtime.scheduler.adaptivebatch
-
Information of All-To-All result.
- AllWindowedStream<T,W extends Window> - Class in org.apache.flink.streaming.api.datastream
-
A
AllWindowedStreamrepresents a data stream where the stream of elements is split into windows based on aWindowAssigner. - AllWindowedStream(DataStream<T>, WindowAssigner<? super T, W>) - Constructor for class org.apache.flink.streaming.api.datastream.AllWindowedStream
- AllWindowFunction<IN,OUT,W extends Window> - Interface in org.apache.flink.streaming.api.functions.windowing
-
Base interface for functions that are evaluated over non-keyed windows.
- AllWorkersDoneEvent - Class in org.apache.flink.runtime.iterative.event
-
Event sent by the
IterationSynchronizationSinkTaskto eachIterationHeadsignaling to start a new superstep. - AllWorkersDoneEvent() - Constructor for class org.apache.flink.runtime.iterative.event.AllWorkersDoneEvent
- AllWorkersDoneEvent(Map<String, Aggregator<?>>) - Constructor for class org.apache.flink.runtime.iterative.event.AllWorkersDoneEvent
- ALREADY_COMMITTED_COMMITTABLES - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- AlreadyExistException(String) - Constructor for exception org.apache.flink.runtime.persistence.StateHandleStore.AlreadyExistException
-
Creates a new Exception with the given message and null cause.
- AlreadyExistException(String, Throwable) - Constructor for exception org.apache.flink.runtime.persistence.StateHandleStore.AlreadyExistException
-
Creates a new Exception with the given message and cause.
- alternating(String, CheckpointableTask, SubtaskCheckpointCoordinator, Clock, int, BarrierAlignmentUtil.DelayableTimer, boolean, CheckpointableInput...) - Static method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
- ALWAYS - org.apache.flink.streaming.api.operators.ChainingStrategy
-
Operators will be eagerly chained whenever possible.
- alwaysRunning() - Static method in interface org.apache.flink.streaming.runtime.tasks.StreamTaskCancellationContext
-
Factory for a context that always returns
falsewhenStreamTaskCancellationContext.isCancelled()is called. - and(CompletableFuture<?>) - Method in class org.apache.flink.runtime.io.AvailabilityProvider.AvailabilityHelper
- and(CompletableFuture<?>, CompletableFuture<?>) - Static method in interface org.apache.flink.runtime.io.AvailabilityProvider
- and(AvailabilityProvider) - Method in class org.apache.flink.runtime.io.AvailabilityProvider.AvailabilityHelper
- announceBufferSize(int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- ANY - org.apache.flink.runtime.jobmanager.scheduler.LocationPreferenceConstraint
- ANY - Static variable in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
A ResourceProfile that indicates infinite resource that matches any resource requirement.
- anyOf(int, CompletableFuture<?>) - Method in class org.apache.flink.streaming.runtime.io.MultipleFuturesAvailabilityHelper
-
Combine
availabilityFutureusing anyOf logic with other previously registered futures. - append(int, byte[]) - Method in interface org.apache.flink.runtime.state.changelog.StateChangelogWriter
-
Appends the provided data to this log.
- append(ByteBuffer) - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
Append as many data as possible from
source. - append(ByteBuffer, int, Buffer.DataType) - Method in interface org.apache.flink.runtime.io.network.partition.DataBuffer
-
Appends data of the specified subpartition to this
DataBufferand returns true if thisDataBufferis full. - append(ByteBuffer, int, Buffer.DataType) - Method in class org.apache.flink.runtime.io.network.partition.HashBasedDataBuffer
-
Partial data of the target record can be written if this
HashBasedDataBufferis full. - append(ByteBuffer, int, Buffer.DataType) - Method in class org.apache.flink.runtime.io.network.partition.SortBuffer
-
No partial record will be written to this
SortBasedDataBuffer, which means that either all data of target record will be written or nothing will be written. - append(ByteBuffer, Buffer.DataType) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.HashSubpartitionBufferAccumulator
- appendAndCommit(ByteBuffer) - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
Same as
BufferBuilder.append(ByteBuffer)but additionallyBufferBuilder.commit()the appending. - appendMeta(byte[]) - Method in interface org.apache.flink.runtime.state.changelog.StateChangelogWriter
-
Appends the provided **metadata** to this log.
- appendOrOverwriteRegion(int, T) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.index.FileDataIndexSpilledRegionManager
-
Write this region to index file.
- appendOrOverwriteRegion(int, T) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.index.FileDataIndexSpilledRegionManagerImpl
- appendRecord(T) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
Inserts the given object into the current buffer.
- applicationStatus(ApplicationStatus) - Method in class org.apache.flink.runtime.jobmaster.JobResult.Builder
- ApplicationStatus - Enum in org.apache.flink.runtime.clusterframework
-
The status of an application.
- apply(Object, Function<Object, R>) - Method in interface org.apache.flink.runtime.operators.coordination.CoordinatorStore
- apply(Object, Function<Object, R>) - Method in class org.apache.flink.runtime.operators.coordination.CoordinatorStoreImpl
- apply(KEY, W, Iterable<IN>, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.windowing.WindowFunction
-
Evaluates the window and outputs none or several elements.
- apply(K, W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.AggregateApplyWindowFunction
- apply(K, W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyWindowFunction
- apply(K, W, Iterable<T>, Collector<T>) - Method in class org.apache.flink.streaming.api.functions.windowing.PassThroughWindowFunction
- apply(CoGroupFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
-
Completes the co-group operation with the user function that is executed for windowed groups.
- apply(CoGroupFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
-
Completes the co-group operation with the user function that is executed for windowed groups.
- apply(FlatJoinFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Completes the join operation with the user function that is executed for each combination of elements with the same key in a window.
- apply(FlatJoinFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Completes the join operation with the user function that is executed for each combination of elements with the same key in a window.
- apply(JoinFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Completes the join operation with the user function that is executed for each combination of elements with the same key in a window.
- apply(JoinFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Completes the join operation with the user function that is executed for each combination of elements with the same key in a window.
- apply(JobID, String, SavepointFormatType, TriggerSavepointMode, Duration) - Method in interface org.apache.flink.runtime.dispatcher.TriggerSavepointFunction
- apply(JobID, CheckpointType, Duration) - Method in interface org.apache.flink.runtime.dispatcher.TriggerCheckpointFunction
- apply(AllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- apply(AllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- apply(WindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- apply(WindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
- apply(WindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- apply(S, T) - Method in interface org.apache.flink.runtime.state.StateTransformationFunction
-
Binary function that applies a given value to the given old state to compute the new state.
- apply(W, Iterable<IN>, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.windowing.AllWindowFunction
-
Evaluates the window and outputs none or several elements.
- apply(W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.AggregateApplyAllWindowFunction
- apply(W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyAllWindowFunction
- apply(W, Iterable<T>, Collector<T>) - Method in class org.apache.flink.streaming.api.functions.windowing.PassThroughAllWindowFunction
- applyBatchExecutionSettings(int, TransformationTranslator.Context, StreamConfig.InputRequirement...) - Static method in class org.apache.flink.streaming.runtime.translators.BatchExecutionUtils
- applyJobResourceRequirements(VertexParallelismStore, JobResourceRequirements) - Static method in class org.apache.flink.runtime.scheduler.DefaultVertexParallelismStore
-
Create a new
VertexParallelismStorethat reflects givenJobResourceRequirements. - applyRepartitioner(OperatorStateRepartitioner<T>, List<List<T>>, int, int) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
-
Repartitions the given operator state using the given
OperatorStateRepartitionerwith respect to the new parallelism. - applyRepartitioner(OperatorID, OperatorStateRepartitioner<T>, List<List<T>>, int, int) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
- applyToAllKeys(N, TypeSerializer<N>, StateDescriptor<S, T>, KeyedStateFunction<K, S>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- applyToAllKeys(N, TypeSerializer<N>, StateDescriptor<S, T>, KeyedStateFunction<K, S>) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
-
Applies the provided
KeyedStateFunctionto the state with the providedStateDescriptorof all the currently active keys. - applyToAllKeys(N, TypeSerializer<N>, StateDescriptor<S, T>, KeyedStateFunction<K, S>) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
- applyToAllKeys(N, TypeSerializer<N>, StateDescriptor<S, T>, KeyedStateFunction<K, S>, AbstractKeyedStateBackend.PartitionStateFactory) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- applyToAllKeys(N, TypeSerializer<N>, StateDescriptor<S, T>, KeyedStateFunction<K, S>, AbstractKeyedStateBackend.PartitionStateFactory) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
- applyToKeyedState(StateDescriptor<S, VS>, KeyedStateFunction<KS, S>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.Context
-
Applies the provided
functionto the state associated with the providedstate descriptor. - applyWithShuffleTypeCheck(Class<SD>, ShuffleDescriptor, Function<UnknownShuffleDescriptor, T>, Function<SD, T>) - Static method in class org.apache.flink.runtime.shuffle.ShuffleUtils
-
Apply different functions to known and unknown
ShuffleDescriptors. - ARBITRARY - org.apache.flink.runtime.io.network.api.writer.SubtaskStateMapper
-
Extra state is redistributed to other subtasks without any specific guarantee (only that up- and downstream are matched).
- ArbitraryWorkerResourceSpecFactory - Class in org.apache.flink.runtime.resourcemanager
-
Implementation of
WorkerResourceSpecFactorythat creates arbitraryWorkerResourceSpec. - archive() - Method in class org.apache.flink.runtime.executiongraph.Execution
- archive() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- archive() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- archive() - Method in class org.apache.flink.runtime.executiongraph.SpeculativeExecutionVertex
- ArchivedExecution - Class in org.apache.flink.runtime.executiongraph
-
ArchivedExecutionis a readonly representation ofExecution. - ArchivedExecution(StringifiedAccumulatorResult[], IOMetrics, ExecutionAttemptID, ExecutionState, ErrorInfo, TaskManagerLocation, AllocationID, long[], long[]) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecution
- ArchivedExecution(Execution) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecution
- ArchivedExecutionGraph - Class in org.apache.flink.runtime.executiongraph
-
An archived execution graph represents a serializable form of an
ExecutionGraph. - ArchivedExecutionGraph(JobID, String, Map<JobVertexID, ArchivedExecutionJobVertex>, List<ArchivedExecutionJobVertex>, long[], JobStatus, JobType, ErrorInfo, String, StringifiedAccumulatorResult[], Map<String, SerializedValue<OptionalFailure<Object>>>, ArchivedExecutionConfig, boolean, CheckpointCoordinatorConfiguration, CheckpointStatsSnapshot, String, String, TernaryBoolean, String) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
- ArchivedExecutionJobVertex - Class in org.apache.flink.runtime.executiongraph
- ArchivedExecutionJobVertex(ArchivedExecutionVertex[], JobVertexID, String, int, int, SlotSharingGroup, ResourceProfile, StringifiedAccumulatorResult[]) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
- ArchivedExecutionJobVertex(ExecutionJobVertex) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
- ArchivedExecutionVertex - Class in org.apache.flink.runtime.executiongraph
-
ArchivedExecutionVertexis a readonly representation ofExecutionVertex. - ArchivedExecutionVertex(int, String, ArchivedExecution, ExecutionHistory) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
- ArchivedExecutionVertex(ExecutionVertex) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
- ArchivedJson - Class in org.apache.flink.runtime.webmonitor.history
-
A simple container for a handler's JSON response and the REST URLs for which the response would've been returned.
- ArchivedJson(String, String) - Constructor for class org.apache.flink.runtime.webmonitor.history.ArchivedJson
- ArchivedJson(String, ResponseBody) - Constructor for class org.apache.flink.runtime.webmonitor.history.ArchivedJson
- archiveExecutionGraph(ExecutionGraphInfo) - Method in interface org.apache.flink.runtime.dispatcher.HistoryServerArchivist
-
Archives the given
ExecutionGraphInfoon the history server. - archiveExecutionGraph(ExecutionGraphInfo) - Method in enum org.apache.flink.runtime.dispatcher.VoidHistoryServerArchivist
- archiveFailedExecution(ExecutionAttemptID) - Method in class org.apache.flink.runtime.executiongraph.SpeculativeExecutionVertex
-
Remove execution from currentExecutions if it is failed.
- archiveFailure(RootExceptionHistoryEntry) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- archiveFromFailureHandlingResult(FailureHandlingResultSnapshot) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- archiveGlobalFailure(Throwable, CompletableFuture<Map<String, String>>) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- archiveJob(Path, JobID, Collection<ArchivedJson>) - Static method in class org.apache.flink.runtime.history.FsJobArchivist
-
Writes the given
AccessExecutionGraphto theFileSystempointed to byJobManagerOptions.ARCHIVE_DIR. - archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointConfigHandler
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointingStatisticsHandler
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointStatisticDetailsHandler
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.TaskCheckpointStatisticDetailsHandler
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobAccumulatorsHandler
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobConfigHandler
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobDetailsHandler
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobPlanHandler
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobsOverviewHandler
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobVertexDetailsHandler
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobVertexTaskManagersHandler
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.SubtaskExecutionAttemptAccumulatorsHandler
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.SubtaskExecutionAttemptDetailsHandler
- archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.SubtasksTimesHandler
- archiveJsonWithPath(AccessExecutionGraph) - Method in interface org.apache.flink.runtime.webmonitor.history.OnlyExecutionGraphJsonArchivist
-
Returns a
CollectionofArchivedJsons containing JSON responses and their respective REST URL for a given job. - archiveJsonWithPath(ExecutionGraphInfo) - Method in class org.apache.flink.runtime.rest.handler.job.JobExceptionsHandler
- archiveJsonWithPath(ExecutionGraphInfo) - Method in class org.apache.flink.runtime.rest.handler.job.JobManagerJobConfigurationHandler
- archiveJsonWithPath(ExecutionGraphInfo) - Method in class org.apache.flink.runtime.rest.handler.job.JobManagerJobEnvironmentHandler
- archiveJsonWithPath(ExecutionGraphInfo) - Method in interface org.apache.flink.runtime.webmonitor.history.JsonArchivist
-
Returns a
CollectionofArchivedJsons containing JSON responses and their respective REST URL for a given job. - archiveJsonWithPath(ExecutionGraphInfo) - Method in interface org.apache.flink.runtime.webmonitor.history.OnlyExecutionGraphJsonArchivist
- archiveJsonWithPath(ExecutionGraphInfo) - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
- areAllDataInputsFinished() - Method in class org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
- areAllInputsFinished() - Method in class org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
- areAllInputsSelected() - Method in class org.apache.flink.streaming.api.operators.InputSelection
-
Tests if all inputs are selected.
- areAllPartitionsFinished() - Method in class org.apache.flink.runtime.scheduler.strategy.ConsumedPartitionGroup
- areAllTasksEndOfData() - Method in class org.apache.flink.runtime.scheduler.VertexEndOfDataListener
- areAllTasksOfJobVertexEndOfData(JobVertexID) - Method in class org.apache.flink.runtime.scheduler.VertexEndOfDataListener
- areExplicitEnvironmentsAllowed() - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Checks whether it is currently permitted to explicitly instantiate a LocalEnvironment or a RemoteEnvironment.
- array() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- ArrayListSerializer<T> - Class in org.apache.flink.runtime.state
- ArrayListSerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.state.ArrayListSerializer
- ArrayListSerializerSnapshot<T> - Class in org.apache.flink.runtime.state
-
Snapshot class for the
ArrayListSerializer. - ArrayListSerializerSnapshot() - Constructor for class org.apache.flink.runtime.state.ArrayListSerializerSnapshot
-
Constructor for read instantiation.
- ArrayListSerializerSnapshot(ArrayListSerializer<T>) - Constructor for class org.apache.flink.runtime.state.ArrayListSerializerSnapshot
-
Constructor for creating the snapshot for writing.
- arrayOffset() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- arrayToMap(String[]) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
- artifactFileNames - Variable in class org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody
- asByteBuf() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
- asByteBuf() - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- asByteBuf() - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- asByteBuf() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- asByteBuf() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- asBytesIfInMemory() - Method in class org.apache.flink.runtime.state.filemerging.DirectoryStreamStateHandle
- asBytesIfInMemory() - Method in class org.apache.flink.runtime.state.filemerging.SegmentFileStateHandle
- asBytesIfInMemory() - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
- asBytesIfInMemory() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
- asBytesIfInMemory() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
- asBytesIfInMemory() - Method in class org.apache.flink.runtime.state.OperatorStreamStateHandle
- asBytesIfInMemory() - Method in class org.apache.flink.runtime.state.PlaceholderStreamStateHandle
- asBytesIfInMemory() - Method in class org.apache.flink.runtime.state.RetrievableStreamStateHandle
- asBytesIfInMemory() - Method in class org.apache.flink.runtime.state.SharedStateRegistryImpl.EmptyDiscardStateObjectForRegister
- asBytesIfInMemory() - Method in interface org.apache.flink.runtime.state.StreamStateHandle
- asConnection() - Method in interface org.apache.flink.runtime.taskexecutor.JobTable.Job
-
Returns the associated
JobTable.Connectionif the job is connected to a JobManager. - asCuratorFramework() - Method in class org.apache.flink.runtime.highavailability.zookeeper.CuratorFrameworkWithUnhandledErrorListener
- asJobResourceRequirements() - Method in class org.apache.flink.runtime.rest.messages.job.JobResourceRequirementsBody
- asLatencyMarker() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Casts this element into a LatencyMarker.
- asList() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- asMapKey() - Method in class org.apache.flink.runtime.state.RegisteredStateMetaInfoBase
-
Returns a wrapper that can be used as a key in
Map. - asQueryableState(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Deprecated.The Queryable State feature is deprecated since Flink 1.18, and will be removed in a future Flink major version.
- asQueryableState(String, ReducingStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Deprecated.The Queryable State feature is deprecated since Flink 1.18, and will be removed in a future Flink major version.
- asQueryableState(String, ValueStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Deprecated.The Queryable State feature is deprecated since Flink 1.18, and will be removed in a future Flink major version.
- asRecord() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Casts this element into a StreamRecord.
- asRecordAttributes() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Casts this element into a RecordAttributes.
- assembleCompleteStats(long) - Method in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator.PendingStatsRequest
-
A method that is called when responses from all tasks were collected successfully.
- assertHasBeenStarted() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolService
- assertNoException(Runnable) - Static method in class org.apache.flink.runtime.util.Runnables
-
Asserts that the given
Runnabledoes not throw exceptions. - assignKeyToParallelOperator(Object, int, int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
-
Assigns the given key to a parallel operator index.
- assignPartition(int, byte) - Static method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Assigns a partition to a bucket.
- AssignRangeIndex<IN> - Class in org.apache.flink.runtime.operators.udf
-
This mapPartition function require a DataSet with RangeBoundaries as broadcast input, it generate Tuple2 which includes range index and record itself as output.
- AssignRangeIndex(TypeComparatorFactory<IN>) - Constructor for class org.apache.flink.runtime.operators.udf.AssignRangeIndex
- assignSlots(JobInformation, Collection<? extends SlotInfo>, VertexParallelism, JobAllocationsInformation) - Method in class org.apache.flink.runtime.scheduler.adaptive.allocator.DefaultSlotAssigner
- assignSlots(JobInformation, Collection<? extends SlotInfo>, VertexParallelism, JobAllocationsInformation) - Method in interface org.apache.flink.runtime.scheduler.adaptive.allocator.SlotAssigner
- assignSlots(JobInformation, Collection<? extends SlotInfo>, VertexParallelism, JobAllocationsInformation) - Method in class org.apache.flink.runtime.scheduler.adaptive.allocator.StateLocalitySlotAssigner
- assignSplits(SplitsAssignment<SplitT>) - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinatorContext
- assignStates() - Method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
- assignTimestampsAndWatermarks(WatermarkStrategy<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Assigns timestamps to the elements in the data stream and generates watermarks to signal event time progress.
- assignToKeyGroup(Object, int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
-
Assigns the given key to a key-group index.
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
- assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
- assignWindows(T, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
-
Returns a
Collectionof windows that should be assigned to the element. - asSlotInfo() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotPool.FreeSlotInfo
- asUnaligned() - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
- asUnmodifiableCollection() - Method in class org.apache.flink.runtime.io.network.partition.PrioritizedDeque
-
Returns an unmodifiable collection view.
- asVariable(String) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
Formats the given string to resemble a scope variable.
- asWatermark() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Casts this element into a Watermark.
- asWatermarkStatus() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Casts this element into a WatermarkStatus.
- asyncAdd(IN) - Method in class org.apache.flink.runtime.state.v2.AbstractAggregatingState
- asyncAdd(IN) - Method in class org.apache.flink.runtime.state.v2.adaptor.MergingStateAdaptor
- asyncAdd(V) - Method in class org.apache.flink.runtime.state.v2.AbstractListState
- asyncAdd(V) - Method in class org.apache.flink.runtime.state.v2.AbstractReducingState
- asyncAdd(V) - Method in class org.apache.flink.runtime.state.v2.adaptor.ListStateAdaptor
- asyncAddAll(List<V>) - Method in class org.apache.flink.runtime.state.v2.AbstractListState
- asyncAddAll(List<V>) - Method in class org.apache.flink.runtime.state.v2.adaptor.ListStateAdaptor
- asyncClear() - Method in class org.apache.flink.runtime.state.v2.AbstractKeyedState
- asyncClear() - Method in class org.apache.flink.runtime.state.v2.adaptor.StateAdaptor
- asyncContains(UK) - Method in class org.apache.flink.runtime.state.v2.AbstractMapState
- asyncContains(UK) - Method in class org.apache.flink.runtime.state.v2.adaptor.MapStateAdaptor
- AsyncDataOutputToOutput(Output<StreamRecord<T>>, InternalSourceReaderMetricGroup, WatermarkGauge) - Constructor for class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask.AsyncDataOutputToOutput
- asyncEntries() - Method in class org.apache.flink.runtime.state.v2.AbstractMapState
- asyncEntries() - Method in class org.apache.flink.runtime.state.v2.adaptor.MapStateAdaptor
- AsyncExceptionHandler - Interface in org.apache.flink.runtime.taskmanager
-
An interface marking a task as capable of handling exceptions thrown by different threads, other than the one executing the task itself.
- AsyncExecutionController<K> - Class in org.apache.flink.runtime.asyncprocessing
-
The Async Execution Controller (AEC) receives processing requests from operators, and put them into execution according to some strategies.
- AsyncExecutionController(MailboxExecutor, StateFutureImpl.AsyncFrameworkExceptionHandler, StateExecutor, int, int, long, int, AsyncExecutionController.SwitchContextListener<K>) - Constructor for class org.apache.flink.runtime.asyncprocessing.AsyncExecutionController
- AsyncExecutionController.SwitchContextListener<K> - Interface in org.apache.flink.runtime.asyncprocessing
-
A listener listens the key context switch.
- asyncGet() - Method in class org.apache.flink.runtime.state.v2.AbstractAggregatingState
- asyncGet() - Method in class org.apache.flink.runtime.state.v2.AbstractListState
- asyncGet() - Method in class org.apache.flink.runtime.state.v2.AbstractReducingState
- asyncGet() - Method in class org.apache.flink.runtime.state.v2.adaptor.AggregatingStateAdaptor
- asyncGet() - Method in class org.apache.flink.runtime.state.v2.adaptor.ListStateAdaptor
- asyncGet() - Method in class org.apache.flink.runtime.state.v2.adaptor.ReducingStateAdaptor
- asyncGet(UK) - Method in class org.apache.flink.runtime.state.v2.AbstractMapState
- asyncGet(UK) - Method in class org.apache.flink.runtime.state.v2.adaptor.MapStateAdaptor
- asyncGetAccumulator() - Method in class org.apache.flink.runtime.state.v2.AbstractAggregatingState
- ASYNCHRONOUS - org.apache.flink.runtime.state.SnapshotExecutionType
- AsynchronousBlockReader - Class in org.apache.flink.runtime.io.disk.iomanager
-
A reader that reads data in blocks from a file channel.
- AsynchronousBlockReader(FileIOChannel.ID, RequestQueue<ReadRequest>, LinkedBlockingQueue<MemorySegment>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockReader
-
Creates a new block channel reader for the given channel.
- AsynchronousBlockWriter - Class in org.apache.flink.runtime.io.disk.iomanager
- AsynchronousBlockWriter(FileIOChannel.ID, RequestQueue<WriteRequest>, LinkedBlockingQueue<MemorySegment>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockWriter
-
Creates a new block channel writer for the given channel.
- AsynchronousBlockWriterWithCallback - Class in org.apache.flink.runtime.io.disk.iomanager
-
An asynchronous implementation of the
BlockChannelWriterWithCallbackthat queues I/O requests and calls a callback once they have been handled. - AsynchronousBlockWriterWithCallback(FileIOChannel.ID, RequestQueue<WriteRequest>, RequestDoneCallback<MemorySegment>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockWriterWithCallback
-
Creates a new asynchronous block writer for the given channel.
- AsynchronousBufferFileReader - Class in org.apache.flink.runtime.io.disk.iomanager
- AsynchronousBufferFileReader(FileIOChannel.ID, RequestQueue<ReadRequest>, RequestDoneCallback<Buffer>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileReader
- AsynchronousBufferFileSegmentReader - Class in org.apache.flink.runtime.io.disk.iomanager
- AsynchronousBufferFileSegmentReader(FileIOChannel.ID, RequestQueue<ReadRequest>, RequestDoneCallback<FileSegment>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileSegmentReader
- AsynchronousBufferFileWriter - Class in org.apache.flink.runtime.io.disk.iomanager
- AsynchronousBufferFileWriter(FileIOChannel.ID, RequestQueue<WriteRequest>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileWriter
- AsynchronousBulkBlockReader - Class in org.apache.flink.runtime.io.disk.iomanager
- AsynchronousBulkBlockReader(FileIOChannel.ID, RequestQueue<ReadRequest>, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBulkBlockReader
- AsynchronousException - Exception in org.apache.flink.runtime.taskmanager
-
An exception for wrapping exceptions that are thrown by an operator in threads other than the main compute thread of that operator.
- AsynchronousException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskmanager.AsynchronousException
- AsynchronousException(Throwable) - Constructor for exception org.apache.flink.runtime.taskmanager.AsynchronousException
- AsynchronousFileIOChannel<T,R extends org.apache.flink.runtime.io.disk.iomanager.IORequest> - Class in org.apache.flink.runtime.io.disk.iomanager
-
A base class for readers and writers that accept read or write requests for whole blocks.
- AsynchronousFileIOChannel(FileIOChannel.ID, RequestQueue<R>, RequestDoneCallback<T>, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
Creates a new channel access to the path indicated by the given ID.
- AsynchronousJobOperationKey - Class in org.apache.flink.runtime.rest.handler.job
-
A pair of
JobIDandTriggerIdused as a key to a hash based collection. - AsynchronouslyCreatedResource<T> - Interface in org.apache.flink.runtime.rest.messages.queue
-
Interface for REST resources that are created asynchronously.
- AsynchronousOperationInfo - Class in org.apache.flink.runtime.rest.handler.async
-
Basic information object for asynchronous operations.
- AsynchronousOperationResult<V> - Class in org.apache.flink.runtime.rest.handler.async
-
Result of an asynchronous operation.
- AsynchronousOperationStatusMessageHeaders<V,M extends MessageParameters> - Class in org.apache.flink.runtime.rest.handler.async
-
Message headers for the status polling of an asynchronous operation.
- AsynchronousOperationStatusMessageHeaders() - Constructor for class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationStatusMessageHeaders
- AsynchronousOperationTriggerMessageHeaders<R extends RequestBody,M extends MessageParameters> - Class in org.apache.flink.runtime.rest.handler.async
-
Message headers for the triggering of an asynchronous operation.
- AsynchronousOperationTriggerMessageHeaders() - Constructor for class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationTriggerMessageHeaders
- asynchronousSnapshots - Variable in class org.apache.flink.runtime.state.DefaultOperatorStateBackendBuilder
-
Flag to de/activate asynchronous snapshots.
- asyncIsEmpty() - Method in class org.apache.flink.runtime.state.v2.AbstractMapState
- asyncIsEmpty() - Method in class org.apache.flink.runtime.state.v2.adaptor.MapStateAdaptor
- asyncKeyedStateBackend() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
-
Returns the async keyed state backend for the stream operator.
- AsyncKeyedStateBackend<K> - Interface in org.apache.flink.runtime.state
-
An async keyed state backend provides methods supporting to access keyed state asynchronously and in batch.
- AsyncKeyedStateBackendAdaptor<K> - Class in org.apache.flink.runtime.state.v2.adaptor
-
A adaptor that transforms
KeyedStateBackendintoAsyncKeyedStateBackend. - AsyncKeyedStateBackendAdaptor(CheckpointableKeyedStateBackend<K>) - Constructor for class org.apache.flink.runtime.state.v2.adaptor.AsyncKeyedStateBackendAdaptor
- asyncKeys() - Method in class org.apache.flink.runtime.state.v2.AbstractMapState
- asyncKeys() - Method in class org.apache.flink.runtime.state.v2.adaptor.MapStateAdaptor
- asyncMergeNamespaces(N, Collection<N>) - Method in class org.apache.flink.runtime.state.v2.AbstractAggregatingState
- asyncMergeNamespaces(N, Collection<N>) - Method in class org.apache.flink.runtime.state.v2.AbstractReducingState
- asyncMergeNamespaces(N, Collection<N>) - Method in class org.apache.flink.runtime.state.v2.adaptor.MergingStateAdaptor
- asyncMergeNamespaces(N, Collection<N>) - Method in interface org.apache.flink.runtime.state.v2.internal.InternalMergingState
-
Merges the state of the current key for the given source namespaces into the state of the target namespace.
- asyncProcessWithKey(K, ThrowingRunnable<Exception>) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperator
- asyncProcessWithKey(K, ThrowingRunnable<Exception>) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperatorV2
- asyncProcessWithKey(K, ThrowingRunnable<Exception>) - Method in interface org.apache.flink.streaming.runtime.operators.asyncprocessing.AsyncStateProcessingOperator
-
Asynchronously process a code with a key provided.
- asyncPut(UK, UV) - Method in class org.apache.flink.runtime.state.v2.adaptor.MapStateAdaptor
- asyncPut(UK, V) - Method in class org.apache.flink.runtime.state.v2.AbstractMapState
- asyncPutAll(Map<UK, UV>) - Method in class org.apache.flink.runtime.state.v2.adaptor.MapStateAdaptor
- asyncPutAll(Map<UK, V>) - Method in class org.apache.flink.runtime.state.v2.AbstractMapState
- asyncRemove(UK) - Method in class org.apache.flink.runtime.state.v2.AbstractMapState
- asyncRemove(UK) - Method in class org.apache.flink.runtime.state.v2.adaptor.MapStateAdaptor
- asyncSnapshot(FullSnapshotResources<K>, long, long, CheckpointStreamFactory, CheckpointOptions) - Method in class org.apache.flink.runtime.state.SavepointSnapshotStrategy
- asyncSnapshot(SR, long, long, CheckpointStreamFactory, CheckpointOptions) - Method in interface org.apache.flink.runtime.state.SnapshotStrategy
-
Operation that writes a snapshot into a stream that is provided by the given
CheckpointStreamFactoryand returns a @SupplierWithExceptionthat gives a state handle to the snapshot. - AsyncSnapshotCallable<T> - Class in org.apache.flink.runtime.state
-
Base class that outlines the strategy for asynchronous snapshots.
- AsyncSnapshotCallable() - Constructor for class org.apache.flink.runtime.state.AsyncSnapshotCallable
- AsyncSnapshotCallable.AsyncSnapshotTask - Class in org.apache.flink.runtime.state
-
FutureTaskthat wraps aAsyncSnapshotCallableand connects it with cancellation and closing. - AsyncStateException - Exception in org.apache.flink.runtime.asyncprocessing
-
An exception for wrapping exceptions that are thrown by
StateFuturecallback framework. - AsyncStateException(String, Throwable) - Constructor for exception org.apache.flink.runtime.asyncprocessing.AsyncStateException
- AsyncStateException(Throwable) - Constructor for exception org.apache.flink.runtime.asyncprocessing.AsyncStateException
- AsyncStateProcessing - Interface in org.apache.flink.streaming.runtime.operators.asyncprocessing
-
This class defines the basic interfaces to process a state in operator/input layer.
- AsyncStateProcessingOperator - Interface in org.apache.flink.streaming.runtime.operators.asyncprocessing
-
A more detailed interface based on
AsyncStateProcessing, which gives the essential methods for an operator to perform async state processing. - asyncUpdate(List<V>) - Method in class org.apache.flink.runtime.state.v2.AbstractListState
- asyncUpdate(List<V>) - Method in class org.apache.flink.runtime.state.v2.adaptor.ListStateAdaptor
- asyncUpdate(V) - Method in class org.apache.flink.runtime.state.v2.AbstractValueState
- asyncUpdate(V) - Method in class org.apache.flink.runtime.state.v2.adaptor.ValueStateAdaptor
- asyncValue() - Method in class org.apache.flink.runtime.state.v2.AbstractValueState
- asyncValue() - Method in class org.apache.flink.runtime.state.v2.adaptor.ValueStateAdaptor
- asyncValues() - Method in class org.apache.flink.runtime.state.v2.AbstractMapState
- asyncValues() - Method in class org.apache.flink.runtime.state.v2.adaptor.MapStateAdaptor
- AT_LEAST_ONCE - org.apache.flink.runtime.checkpoint.CheckpointOptions.AlignmentType
- AT_LEAST_ONCE - org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingMode
- AT_LEAST_ONCE - org.apache.flink.streaming.api.CheckpointingMode
-
Deprecated.Sets the checkpointing mode to "at least once".
- attachJobGraph(List<JobVertex>, JobManagerJobMetricGroup) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- attachJobGraph(List<JobVertex>, JobManagerJobMetricGroup) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- attemptNumber - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
- attemptNumber - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
- attemptNumber() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
- AUTO - org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionType
-
Selects the BoundedBlockingSubpartition type based on the current memory architecture.
- availabilityHelper - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
- AvailabilityHelper() - Constructor for class org.apache.flink.runtime.io.AvailabilityProvider.AvailabilityHelper
- AvailabilityNotifier - Interface in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage
-
AvailabilityNotifieris used to notify that the data from the specific partition and subpartition in tiered storage is available. - AvailabilityProvider - Interface in org.apache.flink.runtime.io
-
Interface defining couple of essential methods for listening on data availability using
CompletableFuture. - AvailabilityProvider.AvailabilityHelper - Class in org.apache.flink.runtime.io
-
A availability implementation for providing the helpful functions of resetting the available/unavailable states.
- AvailabilityWithBacklog(boolean, int) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultSubpartitionView.AvailabilityWithBacklog
- available() - Method in class org.apache.flink.runtime.state.BoundedInputStream
- available() - Method in class org.apache.flink.runtime.util.ForwardingInputStream
- AVAILABLE - Static variable in interface org.apache.flink.runtime.io.AvailabilityProvider
-
Constant that allows to avoid volatile checks
CompletableFuture.isDone(). - availableMemory - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The free memory segments currently available to the hash join.
- availableMemory() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Returns the available amount of memory handled by this memory manager.
- AVG - org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter.AggregationMode
- awaitStartOfSuperstepOrTermination(int) - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
B
- back() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.UnmatchedBuildIterator
- BackendBuildingException - Exception in org.apache.flink.runtime.state
-
Exceptions which indicate that a state backend building has failed.
- BackendBuildingException(String) - Constructor for exception org.apache.flink.runtime.state.BackendBuildingException
- BackendBuildingException(String, Throwable) - Constructor for exception org.apache.flink.runtime.state.BackendBuildingException
- backendIdentifier - Variable in class org.apache.flink.runtime.state.AbstractIncrementalStateHandle
-
UUID to identify the backend which created this state handle.
- BackendRestorerProcedure<T extends Closeable & org.apache.flink.util.Disposable,S extends StateObject> - Class in org.apache.flink.streaming.api.operators
-
This class implements the logic that creates (and potentially restores) a state backend.
- BackendRestorerProcedure(FunctionWithException<Collection<S>, T, Exception>, CloseableRegistry, String) - Constructor for class org.apache.flink.streaming.api.operators.BackendRestorerProcedure
-
Creates a new backend restorer using the given backend supplier and the closeable registry.
- BackendWritableBroadcastState<K,V> - Interface in org.apache.flink.runtime.state
-
An interface with methods related to the interplay between the
Broadcast Stateand theOperatorStateBackend. - BACKUP_AND_RECOVERY_DISABLED - Static variable in class org.apache.flink.runtime.state.LocalRecoveryConfig
- backupAndRecoveryEnabled(LocalSnapshotDirectoryProvider) - Static method in class org.apache.flink.runtime.state.LocalRecoveryConfig
- BarrierAlignmentUtil - Class in org.apache.flink.streaming.runtime.io.checkpointing
-
Utility for barrier alignment.
- BarrierAlignmentUtil() - Constructor for class org.apache.flink.streaming.runtime.io.checkpointing.BarrierAlignmentUtil
- BarrierAlignmentUtil.Cancellable - Interface in org.apache.flink.streaming.runtime.io.checkpointing
-
A handle to a delayed action which can be cancelled.
- BarrierAlignmentUtil.DelayableTimer - Interface in org.apache.flink.streaming.runtime.io.checkpointing
-
It can register a task to be executed some time later.
- BaseBroadcastProcessFunction - Class in org.apache.flink.streaming.api.functions.co
-
The base class containing the functionality available to all broadcast process function.
- BaseBroadcastProcessFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction
- BaseBroadcastProcessFunction.Context - Class in org.apache.flink.streaming.api.functions.co
-
A base
contextavailable to the broadcasted stream side of aBroadcastConnectedStream. - BaseBroadcastProcessFunction.ReadOnlyContext - Class in org.apache.flink.streaming.api.functions.co
-
A
contextavailable to the non-broadcasted stream side of aBroadcastConnectedStream. - BaseTopology<VID extends VertexID,RID extends ResultID,V extends Vertex<VID,RID,V,R>,R extends Result<VID,RID,V,R>> - Interface in org.apache.flink.runtime.topology
-
Base topology for all logical and execution topologies.
- BashJavaUtils - Class in org.apache.flink.runtime.util.bash
-
Utility class for using java utilities in bash scripts.
- BashJavaUtils.Command - Enum in org.apache.flink.runtime.util.bash
-
Commands that BashJavaUtils supports.
- BATCH - org.apache.flink.runtime.jobgraph.JobType
-
Batch jobs are finite jobs, potentially consisting of multiple pipelined regions.
- BATCH - org.apache.flink.streaming.api.transformations.StreamExchangeMode
-
The producer first produces its entire result and finishes.
- BATCH_CHECKPOINT_ID - Static variable in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator
-
The checkpoint ID passed to the restore methods when batch scenarios.
- BatchCallbackRunner - Class in org.apache.flink.runtime.asyncprocessing
-
A
StateFutureImpl.CallbackRunnerthat put one mail inMailboxExecutorbut run multiple callbacks within one mail. - BatchCoBroadcastWithKeyedOperator<KS,IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
A
TwoInputStreamOperatorfor executingKeyedBroadcastProcessFunctionsinRuntimeExecutionMode.BATCHexecution mode. - BatchCoBroadcastWithKeyedOperator(KeyedBroadcastProcessFunction<KS, IN1, IN2, OUT>, List<MapStateDescriptor<?, ?>>) - Constructor for class org.apache.flink.streaming.api.operators.co.BatchCoBroadcastWithKeyedOperator
- BatchCoBroadcastWithNonKeyedOperator<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
A
TwoInputStreamOperatorfor executingBroadcastProcessFunctionsinRuntimeExecutionMode.BATCHexecution mode. - BatchCoBroadcastWithNonKeyedOperator(BroadcastProcessFunction<IN1, IN2, OUT>, List<MapStateDescriptor<?, ?>>) - Constructor for class org.apache.flink.streaming.api.operators.co.BatchCoBroadcastWithNonKeyedOperator
- BatchExecutionCheckpointStorage - Class in org.apache.flink.streaming.api.operators.sorted.state
-
A simple
CheckpointStoragewhich is used in a BATCH style execution. - BatchExecutionCheckpointStorage() - Constructor for class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionCheckpointStorage
- BatchExecutionInternalTimeService<K,N> - Class in org.apache.flink.streaming.api.operators.sorted.state
-
An implementation of a
InternalTimerServicethat manages timers with a single active key at a time. - BatchExecutionInternalTimeServiceManager<K> - Class in org.apache.flink.streaming.api.operators.sorted.state
-
An implementation of a
InternalTimeServiceManagerthat manages timers with a single active key at a time. - BatchExecutionInternalTimeServiceManager(ProcessingTimeService) - Constructor for class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeServiceManager
- BatchExecutionKeyedStateBackend<K> - Class in org.apache.flink.streaming.api.operators.sorted.state
-
A
CheckpointableKeyedStateBackendwhich keeps values for a single key at a time. - BatchExecutionKeyedStateBackend(TypeSerializer<K>, KeyGroupRange, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
- BatchExecutionStateBackend - Class in org.apache.flink.streaming.api.operators.sorted.state
-
A simple
StateBackendwhich is used in a BATCH style execution. - BatchExecutionStateBackend() - Constructor for class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionStateBackend
- BatchExecutionUtils - Class in org.apache.flink.streaming.runtime.translators
-
A utility class for applying sorting inputs.
- BatchGroupedReduceOperator<IN,KEY> - Class in org.apache.flink.streaming.api.operators
-
A
StreamOperatorfor executing aReduceFunctionon aKeyedStreamin aRuntimeExecutionMode.BATCHmode. - BatchGroupedReduceOperator(ReduceFunction<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.streaming.api.operators.BatchGroupedReduceOperator
- BatchJobRecoveryContext - Interface in org.apache.flink.runtime.scheduler.adaptivebatch
-
Context for batch job recovery.
- BatchJobRecoveryHandler - Interface in org.apache.flink.runtime.scheduler.adaptivebatch
-
Interface for handling batch job recovery.
- BatchShuffleReadBufferPool - Class in org.apache.flink.runtime.io.disk
-
A fixed-size
MemorySegmentpool used by batch shuffle for shuffle data read (currently only used by sort-merge blocking shuffle). - BatchShuffleReadBufferPool(long, int) - Constructor for class org.apache.flink.runtime.io.disk.BatchShuffleReadBufferPool
- batchShuffleReadMemoryBytes() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- batchSlotTimeout - Variable in class org.apache.flink.runtime.jobmaster.slotpool.AbstractSlotPoolServiceFactory
- BatchTask<S extends org.apache.flink.api.common.functions.Function,OT> - Class in org.apache.flink.runtime.operators
-
The base class for all batch tasks.
- BatchTask(Environment) - Constructor for class org.apache.flink.runtime.operators.BatchTask
-
Create an Invokable task and set its environment.
- bestEffortDiscardAllStateObjects(Iterable<? extends StateObject>) - Static method in class org.apache.flink.runtime.state.StateUtil
-
Iterates through the passed state handles and calls discardState() on each handle that is not null.
- bestEffortGetNumOfUsedBuffers() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
Returns the number of used buffers of this buffer pool.
- bestEffortGetNumOfUsedBuffers() - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
- between(Duration, Duration) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoin
-
Specifies the time boundaries over which the join operation works, so that
- BINARY_NO_OP - org.apache.flink.runtime.operators.DriverStrategy
- bindVariables(String[], String[]) - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
- bitSet - Variable in class org.apache.flink.runtime.operators.util.BloomFilter
- BitSet - Class in org.apache.flink.runtime.operators.util
- BitSet(int) - Constructor for class org.apache.flink.runtime.operators.util.BitSet
- bitSize() - Method in class org.apache.flink.runtime.operators.util.BitSet
-
Number of bits
- BLOB_PATH_NAME - Static variable in class org.apache.flink.runtime.blob.FileSystemBlobStore
-
The name of the blob path.
- BlobCacheService - Class in org.apache.flink.runtime.blob
-
The BLOB cache provides access to BLOB services for permanent and transient BLOBs.
- BlobCacheService(Configuration, File, BlobView, InetSocketAddress) - Constructor for class org.apache.flink.runtime.blob.BlobCacheService
- BlobCacheService(Configuration, Reference<File>, BlobView, InetSocketAddress) - Constructor for class org.apache.flink.runtime.blob.BlobCacheService
-
Instantiates a new BLOB cache.
- BlobCacheService(PermanentBlobCache, TransientBlobCache) - Constructor for class org.apache.flink.runtime.blob.BlobCacheService
-
Instantiates a new BLOB cache.
- BlobCacheSizeTracker - Class in org.apache.flink.runtime.blob
-
BlobCacheSizeTracker uses
LinkedHashMapto maintain the LRU order for the files in the cache. - BlobCacheSizeTracker(long) - Constructor for class org.apache.flink.runtime.blob.BlobCacheSizeTracker
- BlobClient - Class in org.apache.flink.runtime.blob
-
The BLOB client can communicate with the BLOB server and either upload (PUT), download (GET), or delete (DELETE) BLOBs.
- BlobClient(InetSocketAddress, Configuration) - Constructor for class org.apache.flink.runtime.blob.BlobClient
-
Instantiates a new BLOB client.
- blobClientConfig - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
-
Configuration for the blob client like ssl parameters required to connect to the blob server.
- BlobKey - Class in org.apache.flink.runtime.blob
-
A BLOB key uniquely identifies a BLOB.
- BlobKey(BlobKey.BlobType) - Constructor for class org.apache.flink.runtime.blob.BlobKey
-
Constructs a new BLOB key.
- BlobKey(BlobKey.BlobType, byte[]) - Constructor for class org.apache.flink.runtime.blob.BlobKey
-
Constructs a new BLOB key from the given byte array.
- BlobKey(BlobKey.BlobType, byte[], byte[]) - Constructor for class org.apache.flink.runtime.blob.BlobKey
-
Constructs a new BLOB key from the given byte array.
- BlobLibraryCacheManager - Class in org.apache.flink.runtime.execution.librarycache
-
Provides facilities to download a set of libraries (typically JAR files) for a job from a
PermanentBlobServiceand create a class loader with references to them. - BlobLibraryCacheManager(PermanentBlobService, BlobLibraryCacheManager.ClassLoaderFactory, boolean) - Constructor for class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
- BlobLibraryCacheManager.ClassLoaderFactory - Interface in org.apache.flink.runtime.execution.librarycache
- BlobServer - Class in org.apache.flink.runtime.blob
-
This class implements the BLOB server.
- BlobServer(Configuration, File, BlobStore) - Constructor for class org.apache.flink.runtime.blob.BlobServer
- BlobServer(Configuration, Reference<File>, BlobStore) - Constructor for class org.apache.flink.runtime.blob.BlobServer
-
Instantiates a new BLOB server and binds it to a free network port.
- BlobServerProtocol - Class in org.apache.flink.runtime.blob
- BlobService - Interface in org.apache.flink.runtime.blob
-
A simple store and retrieve binary large objects (BLOBs).
- BlobStore - Interface in org.apache.flink.runtime.blob
-
A blob store.
- BlobStoreService - Interface in org.apache.flink.runtime.blob
-
Service interface for the BlobStore which allows to close and clean up its data.
- BlobUtils - Class in org.apache.flink.runtime.blob
-
Utility class to work with blob data.
- blobView - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
-
Blob store for distributed file storage, e.g. in HA.
- BlobView - Interface in org.apache.flink.runtime.blob
-
View on blobs stored in a
BlobStore. - BlobWriter - Interface in org.apache.flink.runtime.blob
-
BlobWriter is used to upload data to the BLOB store.
- BlockChannelReader<T> - Interface in org.apache.flink.runtime.io.disk.iomanager
-
A reader that reads data in blocks from a file channel.
- BlockChannelWriter<T> - Interface in org.apache.flink.runtime.io.disk.iomanager
-
A writer that writes data in blocks to a file channel.
- BlockChannelWriterWithCallback<T> - Interface in org.apache.flink.runtime.io.disk.iomanager
- BlockCompressionFactory - Interface in org.apache.flink.runtime.io.compression
-
Each compression codec has a implementation of
BlockCompressionFactoryto create compressors and decompressors. - BlockCompressor - Interface in org.apache.flink.runtime.io.compression
-
A compressor which compresses a whole byte array each time.
- blockConsumption(InputChannelInfo) - Method in interface org.apache.flink.runtime.io.network.partition.consumer.CheckpointableInput
- blockConsumption(InputChannelInfo) - Method in class org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate
- blockConsumption(InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
- BlockDecompressor - Interface in org.apache.flink.runtime.io.compression
-
A decompressor which decompresses a block each time.
- BlockedNode - Class in org.apache.flink.runtime.blocklist
-
This class represents a blocked node record.
- BlockedNode(String, String, long) - Constructor for class org.apache.flink.runtime.blocklist.BlockedNode
- BlockedNodeRetriever - Interface in org.apache.flink.runtime.blocklist
-
This class helps to retrieve the blocked nodes.
- BlockedTaskManagerChecker - Interface in org.apache.flink.runtime.blocklist
-
This checker helps to query whether a given task manager is blocked.
- blockHeadCopy - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
- BLOCKING - org.apache.flink.runtime.checkpoint.filemerging.PhysicalFilePool.Type
- BLOCKING - org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
Blocking partitions represent blocking data exchanges, where the data stream is first fully produced and then consumed.
- BLOCKING_OUTPUT_EXIST - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- BLOCKING_PERSISTENT - org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
BLOCKING_PERSISTENT partitions are similar to
ResultPartitionType.BLOCKINGpartitions, but have a user-specified life cycle. - BlockingBackChannel - Class in org.apache.flink.runtime.iterative.concurrent
-
A concurrent datastructure that establishes a backchannel buffer between an iteration head and an iteration tail.
- BlockingBackChannel(SerializedUpdateBuffer) - Constructor for class org.apache.flink.runtime.iterative.concurrent.BlockingBackChannel
- BlockingBackChannelBroker - Class in org.apache.flink.runtime.iterative.concurrent
-
Singleton class for the threadsafe handover of
BlockingBackChannels from iteration heads to iteration tails. - BlockingPhysicalFilePool - Class in org.apache.flink.runtime.checkpoint.filemerging
-
A Blocking
PhysicalFilePoolwhich may block when polling physical files. - BlockingPhysicalFilePool(long, PhysicalFile.PhysicalFileCreator) - Constructor for class org.apache.flink.runtime.checkpoint.filemerging.BlockingPhysicalFilePool
- BlockingQueueBroker - Class in org.apache.flink.streaming.runtime.io
-
Brokerfor theBlockingQueueused inStreamIterationHeadandStreamIterationTailfor implementing feedback streams. - BlockingResultInfo - Interface in org.apache.flink.runtime.scheduler.adaptivebatch
-
The blocking result info, which will be used to calculate the vertex parallelism and input infos.
- BlocklistContext - Interface in org.apache.flink.runtime.blocklist
-
This class is responsible for blocking and unblocking resources.
- BlocklistDeclarativeSlotPool - Class in org.apache.flink.runtime.jobmaster.slotpool
-
A
DeclarativeSlotPoolimplementation that supports blocklist. - BlocklistDeclarativeSlotPoolFactory - Class in org.apache.flink.runtime.jobmaster.slotpool
-
Factory for
BlocklistDeclarativeSlotPool. - BlocklistDeclarativeSlotPoolFactory(BlockedTaskManagerChecker) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.BlocklistDeclarativeSlotPoolFactory
- blocklistHandler - Variable in class org.apache.flink.runtime.resourcemanager.ResourceManager
- BlocklistHandler - Interface in org.apache.flink.runtime.blocklist
-
This class is responsible for managing all
BlockedNodes and performing them on resources. - BlocklistHandler.Factory - Interface in org.apache.flink.runtime.blocklist
-
Factory to instantiate
BlocklistHandler. - BlocklistListener - Interface in org.apache.flink.runtime.blocklist
-
A listener that want to be notified when blocklist changes.
- BlocklistOperations - Interface in org.apache.flink.runtime.blocklist
-
Operations to perform on the blocklist.
- BlocklistTracker - Interface in org.apache.flink.runtime.blocklist
-
A tracker for blocklist.
- BlocklistUtils - Class in org.apache.flink.runtime.blocklist
-
Utility class for blocklist.
- BlockResettableMutableObjectIterator<T> - Class in org.apache.flink.runtime.operators.resettable
-
Implementation of an iterator that fetches a block of data into main memory and offers resettable access to the data in that block.
- BlockResettableMutableObjectIterator(MemoryManager, MutableObjectIterator<T>, TypeSerializer<T>, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
- blockResources(Collection<BlockedNode>) - Method in interface org.apache.flink.runtime.blocklist.BlocklistContext
-
Block resources on the nodes.
- blockUntil(CompletableFuture<?>) - Method in class org.apache.flink.streaming.runtime.io.StreamTaskExternallyInducedSourceInput
- BloomFilter - Class in org.apache.flink.runtime.operators.util
-
BloomFilter is a probabilistic data structure for set membership check.
- BloomFilter(int, int) - Constructor for class org.apache.flink.runtime.operators.util.BloomFilter
- BooleanArrayList - Class in org.apache.flink.runtime.util
-
Minimal implementation of an array-backed list of booleans
- BooleanArrayList(int) - Constructor for class org.apache.flink.runtime.util.BooleanArrayList
- BootstrapTools - Class in org.apache.flink.runtime.clusterframework
-
Tools for starting JobManager and TaskManager processes.
- BoundedBlockingResultPartition - Class in org.apache.flink.runtime.io.network.partition
-
A output data result of an individual task (one partition of an intermediate result), produced and communicated in a batch manner: The result must be produced completely before it can be consumed.
- BoundedBlockingResultPartition(String, int, ResultPartitionID, ResultPartitionType, ResultSubpartition[], int, ResultPartitionManager, BufferCompressor, SupplierWithException<BufferPool, IOException>) - Constructor for class org.apache.flink.runtime.io.network.partition.BoundedBlockingResultPartition
- BoundedBlockingSubpartitionDirectTransferReader - Class in org.apache.flink.runtime.io.network.partition
-
The reader (read view) of a BoundedBlockingSubpartition based on
FileRegion. - BoundedBlockingSubpartitionType - Enum in org.apache.flink.runtime.io.network.partition
-
The type of the BoundedBlockingSubpartition.
- BoundedFIFOQueue<T> - Class in org.apache.flink.runtime.util
-
BoundedFIFOQueuecollects elements up to given amount. - BoundedFIFOQueue(int) - Constructor for class org.apache.flink.runtime.util.BoundedFIFOQueue
-
Creates a
BoundedFIFOQueuewith the given maximum size. - BoundedInputStream - Class in org.apache.flink.runtime.state
-
Wrapper around a FSDataInputStream to limit the maximum read offset.
- BoundedInputStream(FSDataInputStream, long) - Constructor for class org.apache.flink.runtime.state.BoundedInputStream
- BoundedMultiInput - Interface in org.apache.flink.streaming.api.operators
-
Interface for multi-input operators that need to be notified about the logical/semantical end of input.
- boundedness() - Method in interface org.apache.flink.streaming.api.lineage.SourceLineageVertex
-
The boundedness for the source connector, users can get boundedness for each sources in the lineage and determine the job execution mode with RuntimeExecutionMode.
- BoundedOneInput - Interface in org.apache.flink.streaming.api.operators
-
Interface for one-input operators that need to be notified about the logical/semantical end of input.
- broadcast() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStreamso that the output elements are broadcasted to every parallel instance of the next operation. - broadcast(MapStateDescriptor<?, ?>...) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStreamso that the output elements are broadcasted to every parallel instance of the next operation. - BROADCAST - org.apache.flink.runtime.operators.shipping.ShipStrategyType
-
Replicating the data set to all instances.
- BROADCAST - org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.BackendStateType
- BROADCAST - org.apache.flink.runtime.state.OperatorStateHandle.Mode
- BroadcastConnectedStream<IN1,IN2> - Class in org.apache.flink.streaming.api.datastream
-
A BroadcastConnectedStream represents the result of connecting a keyed or non-keyed stream, with a
BroadcastStreamwithbroadcast state(s). - BroadcastConnectedStream(StreamExecutionEnvironment, DataStream<IN1>, BroadcastStream<IN2>, List<MapStateDescriptor<?, ?>>) - Constructor for class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
- broadcastEmit(T) - Method in class org.apache.flink.runtime.io.network.api.writer.BroadcastRecordWriter
- broadcastEmit(T) - Method in class org.apache.flink.runtime.io.network.api.writer.ChannelSelectorRecordWriter
- broadcastEmit(T) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
This is used to broadcast streaming Watermarks in-band with records.
- broadcastEvent(AbstractEvent) - Method in class org.apache.flink.runtime.io.network.api.writer.MultipleRecordWriters
- broadcastEvent(AbstractEvent) - Method in class org.apache.flink.runtime.io.network.api.writer.NonRecordWriter
- broadcastEvent(AbstractEvent) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
- broadcastEvent(AbstractEvent) - Method in interface org.apache.flink.runtime.io.network.api.writer.RecordWriterDelegate
-
Broadcasts the provided event to all the internal record writer instances.
- broadcastEvent(AbstractEvent) - Method in class org.apache.flink.runtime.io.network.api.writer.SingleRecordWriter
- broadcastEvent(AbstractEvent) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- broadcastEvent(AbstractEvent, boolean) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
- broadcastEvent(AbstractEvent, boolean) - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
Writes the given
AbstractEventto all subpartitions. - broadcastEvent(AbstractEvent, boolean) - Method in class org.apache.flink.runtime.io.network.partition.BufferWritingResultPartition
- broadcastEvent(AbstractEvent, boolean) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartition
- broadcastEvent(AbstractEvent, boolean) - Method in class org.apache.flink.runtime.io.network.partition.SortMergeResultPartition
- broadcastEvent(AbstractEvent, boolean) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
- broadcastEvent(AbstractEvent, boolean) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- broadcastInputReaders - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The input readers for the configured broadcast variables for this task.
- broadcastInputSerializers - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The serializers for the broadcast input data types.
- BroadcastPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that selects all the output channels.
- BroadcastPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
- BroadcastProcessFunction<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
-
A function to be applied to a
BroadcastConnectedStreamthat connectsBroadcastStream, i.e. - BroadcastProcessFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.BroadcastProcessFunction
- BroadcastProcessFunction.Context - Class in org.apache.flink.streaming.api.functions.co
-
A
contextavailable to the broadcast side of aBroadcastConnectedStream. - BroadcastProcessFunction.ReadOnlyContext - Class in org.apache.flink.streaming.api.functions.co
-
A
contextavailable to the non-keyed side of aBroadcastConnectedStream(if any). - broadcastRecord(ByteBuffer) - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
Writes the given serialized record to all subpartitions.
- broadcastRecord(ByteBuffer) - Method in class org.apache.flink.runtime.io.network.partition.BufferWritingResultPartition
- broadcastRecord(ByteBuffer) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartition
- broadcastRecord(ByteBuffer) - Method in class org.apache.flink.runtime.io.network.partition.SortMergeResultPartition
- BroadcastRecordWriter<T extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.writer
-
A special record-oriented runtime result writer only for broadcast mode.
- BroadcastStateTransformation<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.transformations
-
A non-keyed
AbstractBroadcastStateTransformation. - BroadcastStateTransformation(String, Transformation<IN1>, Transformation<IN2>, BroadcastProcessFunction<IN1, IN2, OUT>, List<MapStateDescriptor<?, ?>>, TypeInformation<OUT>, int, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.BroadcastStateTransformation
- BroadcastStateTransformationTranslator<IN1,IN2,OUT> - Class in org.apache.flink.streaming.runtime.translators
- BroadcastStateTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.BroadcastStateTransformationTranslator
- BroadcastStream<T> - Class in org.apache.flink.streaming.api.datastream
-
A
BroadcastStreamis a stream withbroadcast state(s). - BroadcastStream(StreamExecutionEnvironment, DataStream<T>, MapStateDescriptor<?, ?>...) - Constructor for class org.apache.flink.streaming.api.datastream.BroadcastStream
- BroadcastVariableKey - Class in org.apache.flink.runtime.broadcast
-
An identifier for a
BroadcastVariableMaterializationbased on the task'sJobVertexID, broadcast variable name and iteration superstep. - BroadcastVariableKey(JobVertexID, String, int) - Constructor for class org.apache.flink.runtime.broadcast.BroadcastVariableKey
- BroadcastVariableManager - Class in org.apache.flink.runtime.broadcast
-
The BroadcastVariableManager is used to manage the materialization of broadcast variables.
- BroadcastVariableManager() - Constructor for class org.apache.flink.runtime.broadcast.BroadcastVariableManager
- BroadcastVariableMaterialization<T,C> - Class in org.apache.flink.runtime.broadcast
-
This class represents a single materialization of a broadcast variable and maintains a reference count for it.
- BroadcastVariableMaterialization(BroadcastVariableKey) - Constructor for class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
- Broker<V> - Class in org.apache.flink.runtime.iterative.concurrent
-
A concurrent data structure that allows the hand-over of an object between a pair of threads.
- Broker() - Constructor for class org.apache.flink.runtime.iterative.concurrent.Broker
- brokerKey() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
- buckets - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The array of memory segments that contain the buckets which form the actual hash-table of hash-codes and pointers to the elements.
- bucketsPerSegmentBits - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The number of bits that describe the position of a bucket in a memory segment.
- bucketsPerSegmentMask - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The number of hash table buckets in a single memory segment - 1.
- buffer - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
- buffer - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
- buffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel.BufferAndAvailability
- buffer() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition.BufferAndBacklog
- Buffer - Interface in org.apache.flink.runtime.io.network.buffer
-
Wrapper for pooled
MemorySegmentinstances with reference counting. - Buffer.DataType - Enum in org.apache.flink.runtime.io.network.buffer
-
Used to identify the type of data contained in the
Bufferso that we can get the information without deserializing the serialized data. - BufferAccumulator - Interface in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage
-
Accumulates received records into buffers.
- BufferAndAvailability(Buffer, Buffer.DataType, int, int) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputChannel.BufferAndAvailability
- BufferAndBacklog(Buffer, int, Buffer.DataType, int) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultSubpartition.BufferAndBacklog
- BufferAvailabilityListener - Interface in org.apache.flink.runtime.io.network.partition
-
Listener interface implemented by consumers of
ResultSubpartitionViewthat want to be notified of availability of further buffers. - BufferBuilder - Class in org.apache.flink.runtime.io.network.buffer
-
Not thread safe class for filling in the content of the
MemorySegment. - BufferBuilder(MemorySegment, BufferRecycler) - Constructor for class org.apache.flink.runtime.io.network.buffer.BufferBuilder
- BufferCompressionException - Exception in org.apache.flink.runtime.io.compression
-
A
BufferCompressionExceptionis thrown when the target data cannot be compressed, such as insufficient target buffer space for compression, etc. - BufferCompressionException() - Constructor for exception org.apache.flink.runtime.io.compression.BufferCompressionException
- BufferCompressionException(String) - Constructor for exception org.apache.flink.runtime.io.compression.BufferCompressionException
- BufferCompressionException(String, Throwable) - Constructor for exception org.apache.flink.runtime.io.compression.BufferCompressionException
- BufferCompressionException(Throwable) - Constructor for exception org.apache.flink.runtime.io.compression.BufferCompressionException
- bufferCompressor - Variable in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Used to compress buffer to reduce IO.
- BufferCompressor - Class in org.apache.flink.runtime.io.network.buffer
-
Compressor for
Buffer. - BufferCompressor(int, NettyShuffleEnvironmentOptions.CompressionCodec) - Constructor for class org.apache.flink.runtime.io.network.buffer.BufferCompressor
- BufferConsumer - Class in org.apache.flink.runtime.io.network.buffer
-
Not thread safe class for producing
Buffer. - BufferConsumer(Buffer, int) - Constructor for class org.apache.flink.runtime.io.network.buffer.BufferConsumer
-
Constructs
BufferConsumerinstance with static content of a certain size. - BufferConsumer(Buffer, BufferBuilder.PositionMarker, int) - Constructor for class org.apache.flink.runtime.io.network.buffer.BufferConsumer
- BufferConsumerWithPartialRecordLength - Class in org.apache.flink.runtime.io.network.buffer
-
BufferConsumer with partial record length if a record is spanning over buffers
- BufferConsumerWithPartialRecordLength(BufferConsumer, int) - Constructor for class org.apache.flink.runtime.io.network.buffer.BufferConsumerWithPartialRecordLength
- BufferDebloatConfiguration - Class in org.apache.flink.runtime.throughput
-
Configuration for
BufferDebloater. - BufferDebloater - Class in org.apache.flink.runtime.throughput
-
Class for automatic calculation of the buffer size based on the current throughput and configuration.
- BufferDebloater(String, int, long, int, int, int, long) - Constructor for class org.apache.flink.runtime.throughput.BufferDebloater
- BufferDecompressionException - Exception in org.apache.flink.runtime.io.compression
-
A
BufferDecompressionExceptionis thrown when the target data cannot be decompressed, such as data corruption, insufficient target buffer space for decompression, etc. - BufferDecompressionException() - Constructor for exception org.apache.flink.runtime.io.compression.BufferDecompressionException
- BufferDecompressionException(String) - Constructor for exception org.apache.flink.runtime.io.compression.BufferDecompressionException
- BufferDecompressionException(String, Throwable) - Constructor for exception org.apache.flink.runtime.io.compression.BufferDecompressionException
- BufferDecompressionException(Throwable) - Constructor for exception org.apache.flink.runtime.io.compression.BufferDecompressionException
- BufferDecompressor - Class in org.apache.flink.runtime.io.network.buffer
-
Decompressor for compressed
Buffer. - BufferDecompressor(int, NettyShuffleEnvironmentOptions.CompressionCodec) - Constructor for class org.apache.flink.runtime.io.network.buffer.BufferDecompressor
- BufferEntry(T, boolean) - Constructor for class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntry
- BufferEntrySerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
- BufferEntrySerializerSnapshot() - Constructor for class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializerSnapshot
- BufferFileChannelReader - Class in org.apache.flink.runtime.io.disk.iomanager
-
Helper class to read
Buffers from files into objects. - BufferFileReader - Interface in org.apache.flink.runtime.io.disk.iomanager
- BufferFileSegmentReader - Interface in org.apache.flink.runtime.io.disk.iomanager
- BufferFileWriter - Interface in org.apache.flink.runtime.io.disk.iomanager
- BufferHeader - Class in org.apache.flink.runtime.io.network.buffer
-
Header fields of a
Buffer. - BufferHeader(boolean, int, Buffer.DataType) - Constructor for class org.apache.flink.runtime.io.network.buffer.BufferHeader
- BufferListener - Interface in org.apache.flink.runtime.io.network.buffer
-
Interface of the availability of buffers.
- bufferManager - Variable in class org.apache.flink.runtime.io.network.partition.consumer.RecoveredInputChannel
- BufferManager - Class in org.apache.flink.runtime.io.network.partition.consumer
-
The general buffer manager used by
InputChannelto request/recycle exclusive or floating buffers. - BufferManager(MemorySegmentProvider, InputChannel, int) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.BufferManager
- BufferOrEvent - Class in org.apache.flink.runtime.io.network.partition.consumer
-
Either type for
BufferorAbstractEventinstances tagged with the channel index, from which they were received. - BufferOrEvent(AbstractEvent, boolean, InputChannelInfo, boolean, int, boolean) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
- BufferOrEvent(AbstractEvent, InputChannelInfo) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
- BufferOrEvent(Buffer, InputChannelInfo) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
- BufferOrEvent(Buffer, InputChannelInfo, boolean, boolean) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
- bufferPool - Variable in class org.apache.flink.runtime.io.network.partition.ResultPartition
- BufferPool - Interface in org.apache.flink.runtime.io.network.buffer
-
A dynamically sized buffer pool.
- BufferPoolFactory - Interface in org.apache.flink.runtime.io.network.buffer
-
A factory for buffer pools.
- BufferProvider - Interface in org.apache.flink.runtime.io.network.buffer
-
A buffer provider to request buffers from in a synchronous or asynchronous fashion.
- BufferReaderWriterUtil - Class in org.apache.flink.runtime.io.network.partition
-
Putting and getting of a sequence of buffers to/from a FileChannel or a ByteBuffer.
- BufferReaderWriterUtil() - Constructor for class org.apache.flink.runtime.io.network.partition.BufferReaderWriterUtil
- bufferRecycler - Variable in class org.apache.flink.runtime.io.network.partition.SortBuffer
-
BufferRecyclerused to recycleSortBuffer.freeSegments. - BufferRecycler - Interface in org.apache.flink.runtime.io.network.buffer
-
Interface for recycling
MemorySegments. - BufferRecycler.DummyBufferRecycler - Class in org.apache.flink.runtime.io.network.buffer
-
The buffer recycler does nothing for recycled segment.
- buffersInBacklog() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel.BufferAndAvailability
- buffersInBacklog() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition.BufferAndBacklog
- bufferSize(int) - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartition
- bufferSize(int) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
- BufferSizeEMA - Class in org.apache.flink.runtime.throughput
-
Implementation of 'Exponential moving average' algorithm.
- BufferSizeEMA(int, int, long) - Constructor for class org.apache.flink.runtime.throughput.BufferSizeEMA
- BufferWithSubpartition - Class in org.apache.flink.runtime.io.network.partition
-
Buffer and the corresponding subpartition index.
- BufferWithSubpartition(Buffer, int) - Constructor for class org.apache.flink.runtime.io.network.partition.BufferWithSubpartition
- BufferWritingResultPartition - Class in org.apache.flink.runtime.io.network.partition
-
A
ResultPartitionwhich writes buffers directly toResultSubpartitions. - BufferWritingResultPartition(String, int, ResultPartitionID, ResultPartitionType, ResultSubpartition[], int, ResultPartitionManager, BufferCompressor, SupplierWithException<BufferPool, IOException>) - Constructor for class org.apache.flink.runtime.io.network.partition.BufferWritingResultPartition
- build() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetricsBuilder
- build() - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBuilder
-
Create file-merging snapshot manager based on configuration.
- build() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState.Builder
- build() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState.Builder
- build() - Method in class org.apache.flink.runtime.checkpoint.SubTaskInitializationMetricsBuilder
- build() - Method in class org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpecBuilder
- build() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
- build() - Method in class org.apache.flink.runtime.dispatcher.cleanup.DefaultResourceCleaner.Builder
- build() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
- build() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumerWithPartialRecordLength
- build() - Method in class org.apache.flink.runtime.jobgraph.JobGraphBuilder
- build() - Method in class org.apache.flink.runtime.jobgraph.JobResourceRequirements.Builder
- build() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration.CheckpointCoordinatorConfigurationBuilder
- build() - Method in class org.apache.flink.runtime.jobmaster.JobResult.Builder
- build() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
- build() - Method in class org.apache.flink.runtime.operators.sort.ExternalSorterBuilder
-
Creates a push-based
PushSorter. - build() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceAllocationResult.Builder
- build() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceReconcileResult.Builder
- build() - Method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec.Builder
- build() - Method in class org.apache.flink.runtime.rest.handler.router.MultipartRoutes.Builder
- build() - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackendBuilder
- build() - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackendBuilder
- build() - Method in class org.apache.flink.runtime.state.metrics.LatencyTrackingStateConfig.Builder
- build() - Method in class org.apache.flink.runtime.state.SerializedCompositeKeyBuilder
-
Returns a serialized composite key, from whatever was set so far.
- build() - Method in interface org.apache.flink.runtime.state.StateBackendBuilder
- build() - Method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexThreadInfoTrackerBuilder
-
Constructs a new
VertexThreadInfoTracker. - build() - Method in class org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes.SinkOperatorUidHashesBuilder
-
Constructs the
CustomSinkOperatorUidHasheswith the given uid hashes. - build() - Method in class org.apache.flink.streaming.api.lineage.DefaultLineageGraph.LineageGraphBuilder
- build() - Method in class org.apache.flink.streaming.api.operators.InputSelection.Builder
- build() - Method in class org.apache.flink.streaming.api.operators.OperatorAttributesBuilder
- build() - Method in class org.apache.flink.streaming.runtime.streamrecord.RecordAttributesBuilder
-
If any operator attribute is null, we will log it at DEBUG level and determine a non-null default value as described below.
- build(int) - Method in class org.apache.flink.streaming.api.operators.InputSelection.Builder
-
Build normalized mask, if all inputs were manually selected, inputMask will be normalized to -1.
- build(long) - Method in class org.apache.flink.runtime.checkpoint.SubTaskInitializationMetricsBuilder
- build(ResultPartitionWriter) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriterBuilder
- build(MutableObjectIterator<T>) - Method in class org.apache.flink.runtime.operators.sort.ExternalSorterBuilder
-
Creates a pull-based
Sorter. - buildBloomFilterForBucketsInPartition(int, HashPartition<BT, PT>) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
- buildCompositeKeyNamespace(N, TypeSerializer<N>) - Method in class org.apache.flink.runtime.state.SerializedCompositeKeyBuilder
-
Returns a serialized composite key, from the key and key-group provided in a previous call to
SerializedCompositeKeyBuilder.setKeyAndKeyGroup(Object, int)and the given namespace. - buildCompositeKeyNamesSpaceUserKey(N, TypeSerializer<N>, UK, TypeSerializer<UK>) - Method in class org.apache.flink.runtime.state.SerializedCompositeKeyBuilder
-
Returns a serialized composite key, from the key and key-group provided in a previous call to
SerializedCompositeKeyBuilder.setKeyAndKeyGroup(Object, int)and the given namespace, followed by the given user-key. - buildCompositeKeyUserKey(UK, TypeSerializer<UK>) - Method in class org.apache.flink.runtime.state.SerializedCompositeKeyBuilder
-
Returns a serialized composite key, from the key and key-group provided in a previous call to
SerializedCompositeKeyBuilder.setKeyAndKeyGroup(Object, int)and the namespace provided inSerializedCompositeKeyBuilder.setNamespace(Object, TypeSerializer), followed by the given user-key. - buildContext(Object, K) - Method in class org.apache.flink.runtime.asyncprocessing.AsyncExecutionController
-
Build a new context based on record and key.
- builder() - Static method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
- builder() - Static method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
- builder() - Static method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceAllocationResult
- builder() - Static method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceReconcileResult
- builder() - Static method in class org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes
-
Creates a builder to construct
CustomSinkOperatorUidHashes. - builder() - Static method in class org.apache.flink.streaming.api.lineage.DefaultLineageGraph
- Builder() - Constructor for class org.apache.flink.runtime.jobgraph.JobResourceRequirements.Builder
- Builder() - Constructor for class org.apache.flink.runtime.jobmaster.JobResult.Builder
- Builder() - Constructor for class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
- Builder() - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceAllocationResult.Builder
- Builder() - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceReconcileResult.Builder
- Builder() - Constructor for class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec.Builder
- Builder() - Constructor for class org.apache.flink.runtime.rest.handler.router.MultipartRoutes.Builder
- Builder() - Constructor for class org.apache.flink.runtime.state.metrics.LatencyTrackingStateConfig.Builder
- Builder() - Constructor for class org.apache.flink.streaming.api.operators.InputSelection.Builder
- Builder(OperatorSubtaskState, List<OperatorSubtaskState>) - Constructor for class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState.Builder
- Builder(OperatorSubtaskState, List<OperatorSubtaskState>, Long) - Constructor for class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState.Builder
- BuildFirstCachedJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
- BuildFirstCachedJoinDriver() - Constructor for class org.apache.flink.runtime.operators.BuildFirstCachedJoinDriver
- buildGraph(JobGraph, Configuration, ScheduledExecutorService, Executor, ClassLoader, CompletedCheckpointStore, CheckpointsCleaner, CheckpointIDCounter, Duration, BlobWriter, Logger, ShuffleMaster<?>, JobMasterPartitionTracker, TaskDeploymentDescriptorFactory.PartitionLocationConstraint, ExecutionDeploymentListener, ExecutionStateUpdateListener, long, VertexAttemptNumberStore, VertexParallelismStore, CheckpointStatsTracker, boolean, ExecutionJobVertex.Factory, MarkPartitionFinishedStrategy, boolean, JobManagerJobMetricGroup) - Static method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraphBuilder
- buildIncomplete() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetricsBuilder
- buildInitialTable(MutableObjectIterator<BT>) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Creates the initial hash table.
- BuildSecondCachedJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
- BuildSecondCachedJoinDriver() - Constructor for class org.apache.flink.runtime.operators.BuildSecondCachedJoinDriver
- buildSideComparator - Variable in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
The utilities to hash and compare the build side data types.
- buildSideComparator - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The utilities to hash and compare the build side data types.
- buildSideSerializer - Variable in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
The utilities to serialize the build side data types.
- buildSideSerializer - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The utilities to serialize the build side data types.
- buildTableFromSpilledPartition(HashPartition<BT, PT>) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
- buildTableWithUniqueKey(MutableObjectIterator<T>) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
- BulkBlockChannelReader - Interface in org.apache.flink.runtime.io.disk.iomanager
- byCode(int) - Static method in enum org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.BackendStateType
- ByteBufUtils - Class in org.apache.flink.runtime.io.network.netty
-
Utility routines to process
ByteBuf. - ByteBufUtils() - Constructor for class org.apache.flink.runtime.io.network.netty.ByteBufUtils
- bytes - Variable in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageBytesBasedDataIdentifier
-
The bytes data of this identifier.
- bytes() - Method in class org.apache.flink.runtime.checkpoint.MasterState
- ByteStreamStateHandle - Class in org.apache.flink.runtime.state.memory
-
A state handle that contains stream state in a byte array.
- ByteStreamStateHandle(String, byte[]) - Constructor for class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
-
Creates a new ByteStreamStateHandle containing the given data.
C
- cache() - Method in class org.apache.flink.streaming.api.datastream.SideOutputDataStream
-
Caches the intermediate result of the transformation.
- cache() - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Cache the intermediate result of the transformation.
- CACHE_CONSUMER_OPERATOR_NAME - Static variable in class org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator
- CACHE_PRODUCER_OPERATOR_NAME - Static variable in class org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator
- CachedDataStream<T> - Class in org.apache.flink.streaming.api.datastream
-
CachedDataStreamrepresents aDataStreamwhose intermediate result will be cached at the first time when it is computed. - CachedDataStream(StreamExecutionEnvironment, Transformation<T>) - Constructor for class org.apache.flink.streaming.api.datastream.CachedDataStream
-
Create a new
CachedDataStreamin the given execution environment that wrap the given physical transformation to indicates that the transformation should be cached. - CachedShuffleDescriptors - Class in org.apache.flink.runtime.deployment
-
ShuffleDescriptors cache for aConsumedPartitionGroup. - CachedShuffleDescriptors(ConsumedPartitionGroup, TaskDeploymentDescriptorFactory.ShuffleDescriptorAndIndex[]) - Constructor for class org.apache.flink.runtime.deployment.CachedShuffleDescriptors
- cacheFile - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Now we could not migrate this field to configuration.
- cacheShuffleDescriptors(ConsumedPartitionGroup, TaskDeploymentDescriptorFactory.ShuffleDescriptorAndIndex[]) - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
- CacheTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
When in batch mode, the
CacheTransformationrepresents the intermediate result of the upper stream should be cached when it is computed at the first time. - CacheTransformation(Transformation<T>, String) - Constructor for class org.apache.flink.streaming.api.transformations.CacheTransformation
-
Creates a new
Transformationwith the given name, output type and parallelism. - CacheTransformationTranslator<OUT,T extends CacheTransformation<OUT>> - Class in org.apache.flink.streaming.runtime.translators
-
Translator for
CacheTransformationTranslator. - CacheTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator
- CacheTransformationTranslator.IdentityStreamOperator<T> - Class in org.apache.flink.streaming.runtime.translators
-
The
CacheTransformationTranslator.IdentityStreamOperatoracts as a dummy source to consume cached intermediate dataset. - CacheTransformationTranslator.NoOpStreamOperator<T> - Class in org.apache.flink.streaming.runtime.translators
-
The
CacheTransformationTranslator.NoOpStreamOperatoracts as a dummy sink so that the upstream can produce the intermediate dataset to be cached. - calculateBufferSize(long, int) - Method in class org.apache.flink.runtime.throughput.BufferSizeEMA
-
Calculating the buffer size over total possible buffers size and number of buffers in use.
- calculateCandidateScore(int, int, Supplier<Double>) - Method in class org.apache.flink.runtime.jobmaster.slotpool.LocationPreferenceSlotSelectionStrategy
- calculateCheckpointPlan() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointPlanCalculator
-
Calculates the plan of the next checkpoint.
- calculateCheckpointPlan() - Method in class org.apache.flink.runtime.checkpoint.DefaultCheckpointPlanCalculator
- calculateDefaultNumSlots(ResourceProfile, ResourceProfile) - Static method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerUtils
- calculateMessageDigest(File) - Static method in class org.apache.flink.runtime.blob.BlobUtils
- calculateRequiredSlots(Iterable<JobInformation.VertexInformation>) - Method in interface org.apache.flink.runtime.scheduler.adaptive.allocator.SlotAllocator
-
Calculates the total resources required for scheduling the given vertices.
- calculateRequiredSlots(Iterable<JobInformation.VertexInformation>) - Method in class org.apache.flink.runtime.scheduler.adaptive.allocator.SlotSharingSlotAllocator
- calculateScore(SlotSharingSlotAllocator.ExecutionSlotSharingGroup, Map<JobVertexID, Integer>, JobInformation, JobAllocationsInformation) - Method in class org.apache.flink.runtime.scheduler.adaptive.allocator.StateLocalitySlotAssigner
- calculateThroughput() - Method in class org.apache.flink.runtime.throughput.ThroughputCalculator
- calculateThroughput(long, long) - Method in class org.apache.flink.runtime.throughput.ThroughputCalculator
- calculateTotalBuffers(SingleInputGate) - Method in class org.apache.flink.runtime.io.network.metrics.AbstractBuffersUsageGauge
- calculateTotalBuffers(SingleInputGate) - Method in class org.apache.flink.runtime.io.network.metrics.CreditBasedInputBuffersUsageGauge
- calculateTotalBuffers(SingleInputGate) - Method in class org.apache.flink.runtime.io.network.metrics.ExclusiveBuffersUsageGauge
- calculateTotalBuffers(SingleInputGate) - Method in class org.apache.flink.runtime.io.network.metrics.FloatingBuffersUsageGauge
- calculateTotalFlinkMemoryFromComponents(Configuration) - Static method in class org.apache.flink.runtime.taskexecutor.TaskExecutorResourceUtils
- calculateTotalProcessMemoryFromComponents(Configuration) - Static method in class org.apache.flink.runtime.taskexecutor.TaskExecutorResourceUtils
- calculateUsedBuffers(SingleInputGate) - Method in class org.apache.flink.runtime.io.network.metrics.AbstractBuffersUsageGauge
- calculateUsedBuffers(SingleInputGate) - Method in class org.apache.flink.runtime.io.network.metrics.CreditBasedInputBuffersUsageGauge
- calculateUsedBuffers(SingleInputGate) - Method in class org.apache.flink.runtime.io.network.metrics.ExclusiveBuffersUsageGauge
- calculateUsedBuffers(SingleInputGate) - Method in class org.apache.flink.runtime.io.network.metrics.FloatingBuffersUsageGauge
- call() - Method in class org.apache.flink.runtime.state.AsyncSnapshotCallable
- call(Callable<R>) - Method in interface org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
- call(Callable<R>) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor
-
Deprecated.
- callAsync(Callable<T>, BiConsumer<T, Throwable>) - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinatorContext
- callAsync(Callable<T>, BiConsumer<T, Throwable>, long, long) - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinatorContext
- callbackFinished() - Method in class org.apache.flink.runtime.asyncprocessing.ContextStateFutureImpl
- callbackRegistered() - Method in class org.apache.flink.runtime.asyncprocessing.ContextStateFutureImpl
- callInternal() - Method in class org.apache.flink.runtime.state.AsyncSnapshotCallable
-
This method implements the (async) snapshot logic.
- callWithNextKey(FlatJoinFunction<T1, T2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeInnerJoinIterator
-
Calls the
JoinFunction#join()method for all two key-value pairs that share the same key and come from different inputs. - callWithNextKey(FlatJoinFunction<T1, T2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
Calls the
JoinFunction#join()method for all two key-value pairs that share the same key and come from different inputs. - callWithNextKey(FlatJoinFunction<T1, T2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeOuterJoinIterator
-
Calls the
JoinFunction#join()method for all two key-value pairs that share the same key and come from different inputs. - callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
- callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
- callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
- callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
- callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - Method in interface org.apache.flink.runtime.operators.util.JoinTaskIterator
-
Moves the internal pointer to the next key that both inputs share.
- CAN_BE_UNKNOWN - org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory.PartitionLocationConstraint
- canBeCompressed(Buffer) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Whether the buffer can be compressed or not.
- canBeCompressed(Buffer, BufferCompressor) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageUtils
-
Whether the buffer can be compressed or not.
- canBePipelinedConsumed() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
return if this partition's upstream and downstream support scheduling in the same time.
- canBeReleased() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
- canBeReleased() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- canBeReleased() - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Checks whether the task executor can be released.
- canBeReleased() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- canBeSubsumed() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
Checks whether this checkpoint can be subsumed or whether it should always continue, regardless of newer checkpoints in progress.
- cancel() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- cancel() - Method in class org.apache.flink.runtime.executiongraph.Execution
- cancel() - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- cancel() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
Cancels all currently running vertex executions.
- cancel() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
Cancels this ExecutionVertex.
- cancel() - Method in class org.apache.flink.runtime.executiongraph.SpeculativeExecutionVertex
- cancel() - Method in class org.apache.flink.runtime.heartbeat.DefaultHeartbeatMonitor
- cancel() - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatMonitor
-
Cancel this monitor.
- cancel() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
- cancel() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
- cancel() - Method in interface org.apache.flink.runtime.jobgraph.tasks.TaskInvokable
-
This method is called when a task is canceled either as a result of a user abort or an execution failure.
- cancel() - Method in class org.apache.flink.runtime.minicluster.MiniClusterJobClient
- cancel() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
- cancel() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
- cancel() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
- cancel() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
- cancel() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
- cancel() - Method in class org.apache.flink.runtime.operators.BatchTask
- cancel() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
- cancel() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
- cancel() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
- cancel() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
- cancel() - Method in class org.apache.flink.runtime.operators.CrossDriver
- cancel() - Method in class org.apache.flink.runtime.operators.DataSinkTask
- cancel() - Method in class org.apache.flink.runtime.operators.DataSourceTask
- cancel() - Method in interface org.apache.flink.runtime.operators.Driver
-
This method is invoked when the driver must aborted in mid processing.
- cancel() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
- cancel() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
- cancel() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
- cancel() - Method in class org.apache.flink.runtime.operators.JoinDriver
- cancel() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
- cancel() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
- cancel() - Method in class org.apache.flink.runtime.operators.MapDriver
- cancel() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
- cancel() - Method in class org.apache.flink.runtime.operators.NoOpDriver
- cancel() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
- cancel() - Method in class org.apache.flink.runtime.operators.ReduceDriver
- cancel() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
- cancel() - Method in class org.apache.flink.runtime.registration.RetryingRegistration
-
Cancels the registration procedure.
- cancel() - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- cancel() - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- cancel() - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
- cancel() - Method in class org.apache.flink.runtime.state.AsyncSnapshotCallable
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.legacy.ContinuousFileMonitoringFunction
-
Deprecated.
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.legacy.FileMonitoringFunction
-
Deprecated.
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.legacy.FromElementsFunction
-
Deprecated.
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.legacy.FromIteratorFunction
-
Deprecated.
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.legacy.FromSplittableIteratorFunction
-
Deprecated.
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.legacy.InputFormatSourceFunction
-
Deprecated.
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.legacy.SocketTextStreamFunction
-
Deprecated.
- cancel() - Method in interface org.apache.flink.streaming.api.functions.source.legacy.SourceFunction
-
Deprecated.Cancels the source.
- cancel() - Method in class org.apache.flink.streaming.api.functions.source.legacy.StatefulSequenceSource
-
Deprecated.
- cancel() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
- cancel() - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
Deprecated.
- cancel() - Method in interface org.apache.flink.streaming.runtime.io.checkpointing.BarrierAlignmentUtil.Cancellable
- cancel() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- cancel() - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
-
Cancel all resources.
- cancel(boolean) - Method in class org.apache.flink.runtime.state.AsyncSnapshotCallable.AsyncSnapshotTask
- cancel(boolean) - Method in class org.apache.flink.runtime.state.DoneFuture
- cancel(Throwable) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlotRequestBulk
-
Cancels all requests of this bulk.
- cancel(Duration) - Method in class org.apache.flink.runtime.dispatcher.cleanup.CheckpointResourcesCleanupRunner
- cancel(Duration) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerRunner
-
Cancels the currently executed job.
- cancel(Duration) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- cancel(Duration) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Cancels the currently executed job.
- cancel(Duration) - Method in class org.apache.flink.runtime.jobmaster.JobMasterServiceLeadershipRunner
- cancel(Execution) - Method in class org.apache.flink.runtime.scheduler.DefaultExecutionOperations
- cancel(Execution) - Method in interface org.apache.flink.runtime.scheduler.ExecutionOperations
-
Cancel the execution.
- cancel(ExecutionAttemptID) - Method in interface org.apache.flink.runtime.scheduler.ExecutionSlotAllocator
-
Cancel the ongoing slot request of the given
Execution. - cancel(ExecutionAttemptID) - Method in class org.apache.flink.runtime.scheduler.SimpleExecutionSlotAllocator
- CANCEL - org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter.TerminationMode
- CANCEL_WITH_SAVEPOINT - org.apache.flink.runtime.dispatcher.TriggerSavepointMode
- cancelAllPendingSlotRequestsForVertex(ExecutionVertexID) - Method in class org.apache.flink.runtime.scheduler.DefaultScheduler
- cancelAllPendingSlotRequestsInternal() - Method in class org.apache.flink.runtime.scheduler.DefaultScheduler
- cancelAllPendingSlotRequestsInternal() - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- cancelChainedTasks(List<ChainedDriver<?, ?>>) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Cancels all tasks via their
ChainedDriver.cancelTask()method. - CancelCheckpointMarker - Class in org.apache.flink.runtime.io.network.api
-
The CancelCheckpointMarker travels through the data streams, similar to the
CheckpointBarrier, but signals that a certain checkpoint should be canceled. - CancelCheckpointMarker(long) - Constructor for class org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
- cancelCleanupTask() - Method in class org.apache.flink.runtime.blob.AbstractBlobCache
-
Cancels any cleanup task that subclasses may be executing.
- cancelCleanupTask() - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
- cancelCleanupTask() - Method in class org.apache.flink.runtime.blob.TransientBlobCache
- cancelConsumption() - Method in interface org.apache.flink.runtime.io.network.partition.PartitionProducerStateProvider.ResponseHandle
-
Cancel the partition consumptions as a result of state check.
- CANCELED - org.apache.flink.runtime.clusterframework.ApplicationStatus
-
Application was canceled or killed on request.
- CANCELED - org.apache.flink.runtime.execution.ExecutionState
- cancelExecution() - Method in class org.apache.flink.runtime.taskmanager.Task
-
Cancels the task execution.
- cancelExecution(Execution) - Method in class org.apache.flink.runtime.scheduler.DefaultScheduler
- CANCELING - org.apache.flink.runtime.execution.ExecutionState
- cancelJob(JobID) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- cancelJob(JobID, Duration) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- cancelJob(JobID, Duration) - Method in class org.apache.flink.runtime.dispatcher.MiniDispatcher
- cancelJob(JobID, Duration) - Method in class org.apache.flink.runtime.webmonitor.NonLeaderRetrievalRestfulGateway
- cancelJob(JobID, Duration) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Cancel the given job.
- cancellationContext - Variable in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
-
Context that allows us to stop firing timers if the containing task has been cancelled.
- cancelRequestFor(InputChannelID) - Method in interface org.apache.flink.runtime.io.network.NetworkClientHandler
- cancelSlotRequest(SlotRequestId, Throwable) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlotProvider
-
Cancels the slot request with the given
SlotRequestId. - cancelSlotRequest(SlotRequestId, Throwable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlotProviderImpl
- cancelStreamRegistry - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
Registry for all opened streams, so they can be closed if the task using this backend is closed.
- cancelStreamRegistry - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
- cancelStreamRegistry - Variable in class org.apache.flink.runtime.state.DefaultOperatorStateBackendBuilder
- cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
- cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
- cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
- cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
- cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
- cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
- cancelTask() - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
- cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
Deprecated.
- cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- cancelTask(ExecutionAttemptID, Duration) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Cancel the given task.
- cancelTask(ExecutionAttemptID, Duration) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
- cancelTask(ExecutionAttemptID, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- cancelTask(ExecutionAttemptID, Duration) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Cancel the given task.
- cancelTask(ExecutionAttemptID, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- CancelTaskException - Exception in org.apache.flink.runtime.execution
-
Thrown to trigger a canceling of the executing task.
- CancelTaskException() - Constructor for exception org.apache.flink.runtime.execution.CancelTaskException
- CancelTaskException(String) - Constructor for exception org.apache.flink.runtime.execution.CancelTaskException
- CancelTaskException(Throwable) - Constructor for exception org.apache.flink.runtime.execution.CancelTaskException
- cancelWithFuture() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
Cancels all currently running vertex executions.
- canEmitBatchOfRecords - Variable in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
- canEqual(Object) - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
- canEqual(Object) - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
- canFastDuplicate(StreamStateHandle) - Method in interface org.apache.flink.runtime.state.CheckpointStateToolset
-
Tells if we can duplicate the given
StreamStateHandle. - canFastDuplicate(StreamStateHandle) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStateToolset
- canFastDuplicate(StreamStateHandle) - Method in class org.apache.flink.runtime.state.NotDuplicatingCheckpointStateToolset
- canFastDuplicate(StreamStateHandle, CheckpointedStateScope) - Method in interface org.apache.flink.runtime.state.CheckpointStreamFactory
-
Tells if we can duplicate the given
StreamStateHandleinto the path corresponding to the givenCheckpointedStateScope. - canFastDuplicate(StreamStateHandle, CheckpointedStateScope) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
- canFastDuplicate(StreamStateHandle, CheckpointedStateScope) - Method in class org.apache.flink.runtime.state.filesystem.FsMergingCheckpointStorageLocation
- canFastDuplicate(StreamStateHandle, CheckpointedStateScope) - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
- canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
Returns true if this trigger supports merging of trigger state and can therefore be used with a
MergingWindowAssigner. - canRescaleMaxParallelism(int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- canRescaleMaxParallelism(int) - Method in class org.apache.flink.runtime.scheduler.DefaultVertexParallelismInfo
- canRescaleMaxParallelism(int) - Method in interface org.apache.flink.runtime.scheduler.VertexParallelismInformation
-
Returns whether the vertex's max parallelism can be changed to a given value.
- canRestart() - Method in class org.apache.flink.runtime.executiongraph.failover.ExponentialDelayRestartBackoffTimeStrategy
- canRestart() - Method in class org.apache.flink.runtime.executiongraph.failover.FailureHandlingResult
-
Returns whether the restarting can be conducted.
- canRestart() - Method in class org.apache.flink.runtime.executiongraph.failover.FailureRateRestartBackoffTimeStrategy
- canRestart() - Method in class org.apache.flink.runtime.executiongraph.failover.FixedDelayRestartBackoffTimeStrategy
- canRestart() - Method in enum org.apache.flink.runtime.executiongraph.failover.NoRestartBackoffTimeStrategy
- canRestart() - Method in interface org.apache.flink.runtime.executiongraph.failover.RestartBackoffTimeStrategy
-
Returns whether a restart should be conducted.
- capacity() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- capacity(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- CaseInsensitiveOrderComparator() - Constructor for class org.apache.flink.runtime.rest.RestServerEndpoint.RestHandlerUrlComparator.CaseInsensitiveOrderComparator
- castInto(Class<T>) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolBridge
- castInto(Class<T>) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolService
- castInto(Class<T>) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolService
-
Tries to cast this slot pool service into the given clazz.
- ChainedAllReduceDriver<IT> - Class in org.apache.flink.runtime.operators.chaining
- ChainedAllReduceDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
- ChainedDriver<IT,OT> - Class in org.apache.flink.runtime.operators.chaining
-
The interface to be implemented by drivers that do not run in an own task context, but are chained to other tasks.
- ChainedDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedDriver
- ChainedFlatMapDriver<IT,OT> - Class in org.apache.flink.runtime.operators.chaining
- ChainedFlatMapDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
- ChainedMapDriver<IT,OT> - Class in org.apache.flink.runtime.operators.chaining
- ChainedMapDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
- ChainedReduceCombineDriver<T> - Class in org.apache.flink.runtime.operators.chaining
-
Chained version of ReduceCombineDriver.
- ChainedReduceCombineDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
- ChainedSource(WatermarkGaugeExposingOutput<StreamRecord<?>>, StreamTaskSourceInput<?>) - Constructor for class org.apache.flink.streaming.runtime.tasks.OperatorChain.ChainedSource
- chainedSources - Variable in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- ChainedStateHandle<T extends StateObject> - Class in org.apache.flink.runtime.state
-
Handle to state handles for the operators in an operator chain.
- ChainedStateHandle(List<? extends T>) - Constructor for class org.apache.flink.runtime.state.ChainedStateHandle
-
Wraps a list to the state handles for the operators in a chain.
- chainedTasks - Variable in class org.apache.flink.runtime.operators.BatchTask
-
A list of chained drivers, if there are any.
- chainingStrategy - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
- ChainingStrategy - Enum in org.apache.flink.streaming.api.operators
-
Defines the chaining scheme for the operator.
- CHANGELOG_BUSY_TIME - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- ChangelogStateBackendHandle - Interface in org.apache.flink.runtime.state.changelog
-
A handle to ChangelogStateBackend state.
- ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl - Class in org.apache.flink.runtime.state.changelog
- ChangelogStateBackendHandleImpl(List<KeyedStateHandle>, List<ChangelogStateHandle>, KeyGroupRange, long, long, long) - Constructor for class org.apache.flink.runtime.state.changelog.ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl
- ChangelogStateBackendLocalHandle - Class in org.apache.flink.runtime.state.changelog
-
State handle for local copies of
ChangelogStateHandleStreamImpl. - ChangelogStateBackendLocalHandle(List<KeyedStateHandle>, List<ChangelogStateHandle>, ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl) - Constructor for class org.apache.flink.runtime.state.changelog.ChangelogStateBackendLocalHandle
- ChangelogStateHandle - Interface in org.apache.flink.runtime.state.changelog
-
A handle to saved
state changes. - ChangelogStateHandleStreamImpl - Class in org.apache.flink.runtime.state.changelog
-
ChangelogStateHandleimplementation based onStreamStateHandle. - ChangelogStateHandleStreamImpl(List<Tuple2<StreamStateHandle, Long>>, KeyGroupRange, long, long, String) - Constructor for class org.apache.flink.runtime.state.changelog.ChangelogStateHandleStreamImpl
- ChangelogTaskLocalStateStore - Class in org.apache.flink.runtime.state
-
Changelog's implementation of a
TaskLocalStateStore. - ChangelogTaskLocalStateStore(JobID, AllocationID, JobVertexID, int, LocalRecoveryConfig, Executor) - Constructor for class org.apache.flink.runtime.state.ChangelogTaskLocalStateStore
- CHANNEL_STATE_SHARED_STREAM_EXCEPTION - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- channelActive(ChannelHandlerContext) - Method in class org.apache.flink.runtime.io.network.netty.NettyMessageClientDecoderDelegate
- channelInactive(ChannelHandlerContext) - Method in class org.apache.flink.runtime.io.network.netty.NettyMessageClientDecoderDelegate
-
Releases resources when the channel is closed.
- channelInfo - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
The info of the input channel to identify it globally within a task.
- channelRead(ChannelHandlerContext, Object) - Method in class org.apache.flink.runtime.io.network.netty.NettyMessageClientDecoderDelegate
- channelRead0(ChannelHandlerContext, RoutedRequest) - Method in class org.apache.flink.runtime.rest.handler.LeaderRetrievalHandler
- channelRead0(ChannelHandlerContext, RoutedRequest<Object>) - Method in class org.apache.flink.runtime.rest.handler.job.GeneratedLogUrlHandler
- channelRead0(ChannelHandlerContext, HttpObject) - Method in class org.apache.flink.runtime.rest.FileUploadHandler
- channelRead0(ChannelHandlerContext, HttpRequest) - Method in class org.apache.flink.runtime.rest.handler.PipelineErrorHandler
- channelRead0(ChannelHandlerContext, HttpRequest) - Method in class org.apache.flink.runtime.rest.handler.router.RouterHandler
- ChannelReaderInputView - Class in org.apache.flink.runtime.io.disk.iomanager
-
A
DataInputViewthat is backed by aBlockChannelReader, making it effectively a data input stream. - ChannelReaderInputView(BlockChannelReader<MemorySegment>, List<MemorySegment>, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
Creates a new channel reader that reads from the given channel until the last block (as marked by a
ChannelWriterOutputView) is found. - ChannelReaderInputView(BlockChannelReader<MemorySegment>, List<MemorySegment>, int, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
Creates a new channel reader that reads from the given channel, expecting a specified number of blocks in the channel.
- ChannelReaderInputViewIterator<E> - Class in org.apache.flink.runtime.io.disk
-
A simple iterator over the input read though an I/O channel.
- ChannelReaderInputViewIterator(AbstractChannelReaderInputView, List<MemorySegment>, TypeSerializer<E>) - Constructor for class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
- ChannelReaderInputViewIterator(BlockChannelReader<MemorySegment>, LinkedBlockingQueue<MemorySegment>, List<MemorySegment>, List<MemorySegment>, TypeSerializer<E>, int) - Constructor for class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
- ChannelReaderInputViewIterator(IOManager, FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>, List<MemorySegment>, List<MemorySegment>, TypeSerializer<E>, int) - Constructor for class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
- ChannelReaderInputViewIterator(IOManager, FileIOChannel.ID, List<MemorySegment>, List<MemorySegment>, TypeSerializer<E>, int) - Constructor for class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
- ChannelSelector<T extends org.apache.flink.core.io.IOReadableWritable> - Interface in org.apache.flink.runtime.io.network.api.writer
-
The
ChannelSelectordetermines to which logical channels a record should be written to. - ChannelSelectorRecordWriter<T extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.writer
-
A regular record-oriented runtime result writer.
- ChannelStateHolder - Interface in org.apache.flink.runtime.io.network.partition
-
Implemented by entities that hold any kind of channel state and need a reference to the
ChannelStateWriter. - ChannelStatePendingResult - Class in org.apache.flink.runtime.checkpoint.channel
-
The pending result of channel state for a specific checkpoint-subtask.
- ChannelStatePendingResult(int, long, ChannelStateWriter.ChannelStateWriteResult, ChannelStateSerializer) - Constructor for class org.apache.flink.runtime.checkpoint.channel.ChannelStatePendingResult
- ChannelStatePersister - Class in org.apache.flink.runtime.io.network.partition.consumer
-
Helper class for persisting channel state via
ChannelStateWriter. - channelStateWriter - Variable in class org.apache.flink.runtime.io.network.partition.consumer.RecoveredInputChannel
- ChannelStateWriter - Interface in org.apache.flink.runtime.checkpoint.channel
-
Writes channel state during checkpoint/savepoint.
- ChannelStateWriter.ChannelStateWriteResult - Class in org.apache.flink.runtime.checkpoint.channel
-
Channel state write result.
- ChannelStateWriter.NoOpChannelStateWriter - Class in org.apache.flink.runtime.checkpoint.channel
-
No-op implementation of
ChannelStateWriter. - ChannelStateWriteRequestExecutorFactory - Class in org.apache.flink.runtime.checkpoint.channel
-
The factory of
ChannelStateWriteRequestExecutor. - ChannelStateWriteRequestExecutorFactory(JobID) - Constructor for class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriteRequestExecutorFactory
- ChannelStateWriterImpl - Class in org.apache.flink.runtime.checkpoint.channel
-
ChannelStateWriterimplemented usingCheckpointStateOutputStreams. - ChannelStateWriterImpl(JobVertexID, String, int, SupplierWithException<CheckpointStorageWorkerView, ? extends IOException>, ChannelStateWriteRequestExecutorFactory, int) - Constructor for class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriterImpl
- ChannelStatistics() - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGateFactory.ChannelStatistics
- ChannelWriterOutputView - Class in org.apache.flink.runtime.io.disk.iomanager
-
A
DataOutputViewthat is backed by aBlockChannelWriter, making it effectively a data output stream. - ChannelWriterOutputView(BlockChannelWriter<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
Creates an new ChannelWriterOutputView that writes to the given channel.
- ChannelWriterOutputView(BlockChannelWriter<MemorySegment>, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
Creates an new ChannelWriterOutputView that writes to the given channel and buffers data in the given memory segments.
- check() - Method in interface org.apache.flink.streaming.runtime.tasks.StreamTask.CanEmitBatchOfRecordsChecker
- checkAgainstThreshold() - Method in class org.apache.flink.runtime.metrics.ThresholdMeter
- checkAndGetNextWatermark(T, long) - Method in interface org.apache.flink.streaming.runtime.operators.util.WatermarkStrategyWithPunctuatedWatermarks
-
Asks this implementation if it wants to emit a watermark.
- checkCollection(Collection<OUT>, Class<OUT>) - Static method in class org.apache.flink.streaming.api.functions.source.legacy.FromElementsFunction
-
Deprecated.Verifies that all elements in the collection are non-null, and are of the given class, or a subclass thereof.
- checkConfigParameter(boolean, Object, String, String) - Static method in class org.apache.flink.runtime.util.ConfigurationParserUtils
-
Validates a condition for a config parameter and displays a standard exception, if the condition does not hold.
- checkDiscarded() - Method in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator.PendingStatsRequest
- checkErroneous() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
Checks the exception state of this channel.
- checkErroneous() - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
- checkError() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Checks for an error and rethrows it if one was reported.
- checkFailureCounter(CheckpointException, long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointFailureManager
- checkFileValidity(File, File, Logger) - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
-
Checks various conditions for file access.
- checkForBarrier(Buffer) - Method in class org.apache.flink.runtime.io.network.partition.consumer.ChannelStatePersister
- checkInProduceState() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- checkLimit(long) - Method in class org.apache.flink.runtime.blob.BlobCacheSizeTracker
-
Check the size limit and return the BLOBs to delete.
- checkNotClosed() - Method in class org.apache.flink.runtime.jobmaster.slotpool.AbstractServiceConnectionManager
- checkNotShutdown() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
- checkParallelismPreconditions(int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
- checkParallelismPreconditions(TaskStateAssignment) - Method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
- Checkpoint - Interface in org.apache.flink.runtime.checkpoint
-
A checkpoint, pending or completed.
- CHECKPOINT - Static variable in class org.apache.flink.runtime.checkpoint.CheckpointType
-
A checkpoint, full or incremental.
- CHECKPOINT_ALIGNMENT_TIME - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- CHECKPOINT_ASYNC_EXCEPTION - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- CHECKPOINT_COORDINATOR_SHUTDOWN - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- CHECKPOINT_COORDINATOR_SUSPEND - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- CHECKPOINT_DECLINED - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- CHECKPOINT_DECLINED_INPUT_END_OF_STREAM - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- CHECKPOINT_DECLINED_ON_CANCELLATION_BARRIER - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- CHECKPOINT_DECLINED_SUBSUMED - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- CHECKPOINT_DECLINED_TASK_CLOSING - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- CHECKPOINT_DECLINED_TASK_NOT_READY - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- CHECKPOINT_DIR_PREFIX - Static variable in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorageAccess
-
The prefix of the directory containing the data exclusive to a checkpoint.
- CHECKPOINT_EXPIRED - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- CHECKPOINT_SHARED_STATE_DIR - Static variable in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorageAccess
-
The name of the directory for shared checkpoint state.
- CHECKPOINT_START_DELAY_TIME - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- CHECKPOINT_SUBSUMED - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- CHECKPOINT_TASK_OWNED_STATE_DIR - Static variable in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorageAccess
-
The name of the directory for state not owned/released by the master, but by the TaskManagers.
- Checkpoint.DiscardObject - Interface in org.apache.flink.runtime.checkpoint
-
Extra interface for discarding the checkpoint.
- CheckpointableInput - Interface in org.apache.flink.runtime.io.network.partition.consumer
-
Input, with just basic methods for blocking and resuming consumption.
- CheckpointableKeyedStateBackend<K> - Interface in org.apache.flink.runtime.state
-
Interface that combines both, the
KeyedStateBackendinterface, which encapsulates methods responsible for keyed state management and theSnapshotablewhich tells the system how to snapshot the underlying state. - CheckpointableTask - Interface in org.apache.flink.runtime.jobgraph.tasks
-
A task that participates in checkpointing.
- CheckpointAlignment(long, long, long, long) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
- CheckpointAlignment(StatsSummaryDto, StatsSummaryDto, StatsSummaryDto, StatsSummaryDto) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
- CheckpointBarrier - Class in org.apache.flink.runtime.io.network.api
-
Checkpoint barriers are used to align checkpoints throughout the streaming topology.
- CheckpointBarrier(long, long, CheckpointOptions) - Constructor for class org.apache.flink.runtime.io.network.api.CheckpointBarrier
- CheckpointBarrierHandler - Class in org.apache.flink.streaming.runtime.io.checkpointing
-
The
CheckpointBarrierHandlerreacts to checkpoint barrier arriving from the input channels. - CheckpointBarrierHandler(CheckpointableTask, Clock, boolean) - Constructor for class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
- CheckpointBarrierTracker - Class in org.apache.flink.streaming.runtime.io.checkpointing
-
The
CheckpointBarrierTrackerkeeps track of what checkpoint barriers have been received from which input channels. - CheckpointBarrierTracker(int, CheckpointableTask, Clock, boolean) - Constructor for class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierTracker
- CheckpointBoundKeyedStateHandle - Interface in org.apache.flink.runtime.state
-
KeyedStateHandlethat is bound to a specific checkpoint. - checkpointCfg - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Settings that control the checkpointing behavior.
- CheckpointCommittableManager<CommT> - Interface in org.apache.flink.streaming.runtime.operators.sink.committables
-
A
CheckpointCommittableManagercollects committables for one checkpoint across potentially multiple upstream subtasks. - checkpointCompleted(long) - Method in interface org.apache.flink.runtime.state.SharedStateRegistry
- checkpointCompleted(long) - Method in class org.apache.flink.runtime.state.SharedStateRegistryImpl
- CheckpointConfig - Class in org.apache.flink.streaming.api.environment
-
Configuration that captures all checkpointing related settings.
- CheckpointConfig() - Constructor for class org.apache.flink.streaming.api.environment.CheckpointConfig
- CheckpointConfig(Configuration) - Constructor for class org.apache.flink.streaming.api.environment.CheckpointConfig
- CheckpointConfig(CheckpointConfig) - Constructor for class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Creates a deep copy of the provided
CheckpointConfig. - CheckpointConfigHandler - Class in org.apache.flink.runtime.rest.handler.job.checkpoints
-
Handler which serves the checkpoint configuration.
- CheckpointConfigHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, CheckpointConfigInfo, JobMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointConfigHandler
- CheckpointConfigHeaders - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Message headers for the
CheckpointConfigHandler. - CheckpointConfigInfo - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Response class of the
CheckpointConfigHandler. - CheckpointConfigInfo(CheckpointConfigInfo.ProcessingMode, long, long, long, int, CheckpointConfigInfo.ExternalizedCheckpointInfo, String, String, boolean, int, long, boolean, boolean, long, String) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
- CheckpointConfigInfo.ExternalizedCheckpointInfo - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Contains information about the externalized checkpoint configuration.
- CheckpointConfigInfo.ProcessingMode - Enum in org.apache.flink.runtime.rest.messages.checkpoints
-
Processing mode.
- CheckpointConfigInfo.ProcessingModeDeserializer - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Processing mode deserializer.
- CheckpointConfigInfo.ProcessingModeSerializer - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
JSON deserializer for
CheckpointConfigInfo.ProcessingMode. - checkpointCoordinator(long, CompletableFuture<byte[]>) - Method in interface org.apache.flink.runtime.checkpoint.OperatorCoordinatorCheckpointContext
- checkpointCoordinator(long, CompletableFuture<byte[]>) - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator
-
Takes a checkpoint of the coordinator.
- checkpointCoordinator(long, CompletableFuture<byte[]>) - Method in class org.apache.flink.runtime.operators.coordination.OperatorCoordinatorHolder
- checkpointCoordinator(long, CompletableFuture<byte[]>) - Method in class org.apache.flink.runtime.operators.coordination.RecreateOnResetOperatorCoordinator
- checkpointCoordinator(long, CompletableFuture<byte[]>) - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinator
- checkpointCoordinator(long, CompletableFuture<byte[]>) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
- CheckpointCoordinator - Class in org.apache.flink.runtime.checkpoint
-
The checkpoint coordinator coordinates the distributed snapshots of operators and state.
- CheckpointCoordinator(JobID, CheckpointCoordinatorConfiguration, Collection<OperatorCoordinatorCheckpointContext>, CheckpointIDCounter, CompletedCheckpointStore, CheckpointStorage, Executor, CheckpointsCleaner, ScheduledExecutor, CheckpointFailureManager, CheckpointPlanCalculator, CheckpointStatsTracker) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
- CheckpointCoordinator(JobID, CheckpointCoordinatorConfiguration, Collection<OperatorCoordinatorCheckpointContext>, CheckpointIDCounter, CompletedCheckpointStore, CheckpointStorage, Executor, CheckpointsCleaner, ScheduledExecutor, CheckpointFailureManager, CheckpointPlanCalculator, Clock, CheckpointStatsTracker, BiFunction<Set<ExecutionJobVertex>, Map<OperatorID, OperatorState>, VertexFinishedStateChecker>) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
- CheckpointCoordinatorConfiguration - Class in org.apache.flink.runtime.jobgraph.tasks
-
Configuration settings for the
CheckpointCoordinator. - CheckpointCoordinatorConfiguration(long, long, long, int, CheckpointRetentionPolicy, boolean, boolean, int, long) - Constructor for class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
-
Deprecated.
- CheckpointCoordinatorConfiguration.CheckpointCoordinatorConfigurationBuilder - Class in org.apache.flink.runtime.jobgraph.tasks
-
CheckpointCoordinatorConfigurationbuilder. - CheckpointCoordinatorConfigurationBuilder() - Constructor for class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration.CheckpointCoordinatorConfigurationBuilder
- CheckpointCoordinatorDeActivator - Class in org.apache.flink.runtime.checkpoint
-
This actor listens to changes in the JobStatus and activates or deactivates the periodic checkpoint scheduler.
- CheckpointCoordinatorDeActivator(CheckpointCoordinator, boolean) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointCoordinatorDeActivator
- CheckpointCoordinatorGateway - Interface in org.apache.flink.runtime.checkpoint
-
RPC Gateway interface for messages to the CheckpointCoordinator.
- checkpointDir - Variable in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
- CheckpointDuration(long, long) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
- CheckpointDuration(StatsSummaryDto, StatsSummaryDto) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
- CheckpointedCollectResultBuffer<T> - Class in org.apache.flink.streaming.api.operators.collect
-
A buffer which encapsulates the logic of dealing with the response from the
CollectSinkFunction. - CheckpointedCollectResultBuffer(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.api.operators.collect.CheckpointedCollectResultBuffer
- CheckpointedFunction - Interface in org.apache.flink.streaming.api.checkpoint
-
This is the core interface for stateful transformation functions, meaning functions that maintain state across individual stream records.
- checkpointedInputGate - Variable in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
- CheckpointedInputGate - Class in org.apache.flink.streaming.runtime.io.checkpointing
-
The
CheckpointedInputGateusesCheckpointBarrierHandlerto handle incomingCheckpointBarrierfrom theInputGate. - CheckpointedInputGate(InputGate, CheckpointBarrierHandler, MailboxExecutor) - Constructor for class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
-
Creates a new checkpoint stream aligner.
- CheckpointedInputGate(InputGate, CheckpointBarrierHandler, MailboxExecutor, UpstreamRecoveryTracker) - Constructor for class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
- CheckpointedResultPartition - Interface in org.apache.flink.runtime.io.network.partition
-
Interface for partitions that are checkpointed, meaning they store data as part of unaligned checkpoints.
- CheckpointedStateScope - Enum in org.apache.flink.runtime.state
-
The scope for a chunk of checkpointed state.
- CheckpointException - Exception in org.apache.flink.runtime.checkpoint
-
Base class for checkpoint related exceptions.
- CheckpointException(String, CheckpointFailureReason) - Constructor for exception org.apache.flink.runtime.checkpoint.CheckpointException
- CheckpointException(String, CheckpointFailureReason, Throwable) - Constructor for exception org.apache.flink.runtime.checkpoint.CheckpointException
- CheckpointException(CheckpointFailureReason) - Constructor for exception org.apache.flink.runtime.checkpoint.CheckpointException
- CheckpointException(CheckpointFailureReason, Throwable) - Constructor for exception org.apache.flink.runtime.checkpoint.CheckpointException
- CheckpointFailureManager - Class in org.apache.flink.runtime.checkpoint
-
The checkpoint failure manager which centralized manage checkpoint failure processing logic.
- CheckpointFailureManager(int, CheckpointFailureManager.FailJobCallback) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointFailureManager
- CheckpointFailureManager.FailJobCallback - Interface in org.apache.flink.runtime.checkpoint
-
A callback interface about how to fail a job.
- CheckpointFailureReason - Enum in org.apache.flink.runtime.checkpoint
-
Various reasons why a checkpoint was failure.
- CheckpointHandlers - Class in org.apache.flink.runtime.rest.handler.job.checkpoints
-
HTTP handlers for asynchronous triggering of checkpoints.
- CheckpointHandlers() - Constructor for class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointHandlers
- CheckpointHandlers.CheckpointStatusHandler - Class in org.apache.flink.runtime.rest.handler.job.checkpoints
-
HTTP handler to query for the status of the checkpoint.
- CheckpointHandlers.CheckpointTriggerHandler - Class in org.apache.flink.runtime.rest.handler.job.checkpoints
-
Handler for the checkpoint trigger operation.
- checkpointId - Variable in class org.apache.flink.runtime.state.AbstractIncrementalStateHandle
-
The checkpoint Id.
- CheckpointIDCounter - Interface in org.apache.flink.runtime.checkpoint
-
A checkpoint ID counter.
- checkpointIdPathParameter - Variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointMessageParameters
- CheckpointIdPathParameter - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Path parameter for the checkpoint id of type
Long. - CheckpointIdPathParameter() - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointIdPathParameter
- checkpointIDToName(long) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointStoreUtil
-
Get the name in external storage from checkpoint id.
- checkpointIDToName(long) - Method in enum org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointStoreUtil
-
Convert a checkpoint id into a ZooKeeper path.
- CheckpointInfo - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Represents information about a triggered checkpoint.
- CheckpointInfo(Long, SerializedThrowable) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointInfo
- CheckpointingMode - Enum in org.apache.flink.streaming.api
-
Deprecated.This class has been moved to
CheckpointingMode. - CheckpointingStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Response of the
CheckpointingStatisticsHandler. - CheckpointingStatistics(CheckpointingStatistics.Counts, CheckpointingStatistics.Summary, CheckpointingStatistics.LatestCheckpoints, List<CheckpointStatistics>) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
- CheckpointingStatistics.Counts - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Checkpoint counts.
- CheckpointingStatistics.LatestCheckpoints - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Statistics about the latest checkpoints.
- CheckpointingStatistics.RestoredCheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Statistics for a restored checkpoint.
- CheckpointingStatistics.Summary - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Checkpoint summary.
- CheckpointingStatisticsHandler - Class in org.apache.flink.runtime.rest.handler.job.checkpoints
-
Handler which serves the checkpoint statistics.
- CheckpointingStatisticsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, CheckpointingStatistics, JobMessageParameters>, Cache<JobID, CompletableFuture<CheckpointStatsSnapshot>>, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointingStatisticsHandler
- CheckpointingStatisticsHeaders - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Message headers for the
CheckpointingStatisticsHandler. - CheckpointingStatisticsHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
- CheckpointMessageParameters - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Message parameters for checkpoint related messages.
- CheckpointMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointMessageParameters
- CheckpointMetadata - Class in org.apache.flink.runtime.checkpoint.metadata
-
The metadata of a snapshot (checkpoint or savepoint).
- CheckpointMetadata(long, Collection<OperatorState>, Collection<MasterState>) - Constructor for class org.apache.flink.runtime.checkpoint.metadata.CheckpointMetadata
- CheckpointMetadata(long, Collection<OperatorState>, Collection<MasterState>, CheckpointProperties) - Constructor for class org.apache.flink.runtime.checkpoint.metadata.CheckpointMetadata
- CheckpointMetaData - Class in org.apache.flink.runtime.checkpoint
-
Encapsulates all the meta data for a checkpoint.
- CheckpointMetaData(long, long) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointMetaData
- CheckpointMetaData(long, long, long) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointMetaData
- CheckpointMetadataOutputStream - Class in org.apache.flink.runtime.state
-
An output stream for checkpoint metadata.
- CheckpointMetadataOutputStream() - Constructor for class org.apache.flink.runtime.state.CheckpointMetadataOutputStream
- CheckpointMetrics - Class in org.apache.flink.runtime.checkpoint
-
A collection of simple metrics, around the triggering of a checkpoint.
- CheckpointMetrics() - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointMetrics
- CheckpointMetrics(long, long, long, long, long, long, boolean, long, long) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointMetrics
- CheckpointMetricsBuilder - Class in org.apache.flink.runtime.checkpoint
-
A builder for
CheckpointMetrics. - CheckpointMetricsBuilder() - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointMetricsBuilder
- CheckpointOptions - Class in org.apache.flink.runtime.checkpoint
-
Options for performing the checkpoint.
- CheckpointOptions(SnapshotType, CheckpointStorageLocationReference) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointOptions
- CheckpointOptions(SnapshotType, CheckpointStorageLocationReference, CheckpointOptions.AlignmentType, long) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointOptions
- CheckpointOptions.AlignmentType - Enum in org.apache.flink.runtime.checkpoint
-
How a checkpoint should be aligned.
- CheckpointPlan - Interface in org.apache.flink.runtime.checkpoint
-
The plan of one checkpoint, indicating which tasks to trigger, waiting for acknowledge or commit for one specific checkpoint.
- CheckpointPlanCalculator - Interface in org.apache.flink.runtime.checkpoint
-
Calculates the plan of the next checkpoint, including the tasks to trigger, wait or commit for each checkpoint.
- CheckpointPlanCalculatorContext - Interface in org.apache.flink.runtime.checkpoint
-
Provides the context for
DefaultCheckpointPlanCalculatorto compute the plan of checkpoints. - CheckpointProperties - Class in org.apache.flink.runtime.checkpoint
-
The configuration of a checkpoint.
- CheckpointProperties(boolean, SnapshotType, boolean, boolean, boolean, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointProperties
- CheckpointRecoveryFactory - Interface in org.apache.flink.runtime.checkpoint
-
A factory for per Job checkpoint recovery components.
- CheckpointResourcesCleanupRunner - Class in org.apache.flink.runtime.dispatcher.cleanup
-
CheckpointResourcesCleanupRunnerimplementsJobManagerRunnerin a way, that only the checkpoint-related resources are instantiated. - CheckpointResourcesCleanupRunner(JobResult, CheckpointRecoveryFactory, SharedStateRegistryFactory, Configuration, Executor, long) - Constructor for class org.apache.flink.runtime.dispatcher.cleanup.CheckpointResourcesCleanupRunner
- CheckpointResourcesCleanupRunnerFactory - Enum in org.apache.flink.runtime.dispatcher.cleanup
-
CheckpointResourcesCleanupRunnerFactoryimplementsCleanupRunnerFactoryproviding a factory method for creatingCheckpointResourcesCleanupRunnerinstances. - CheckpointResponder - Interface in org.apache.flink.runtime.taskmanager
-
Responder for checkpoint acknowledge and decline messages in the
Task. - CheckpointRetentionPolicy - Enum in org.apache.flink.runtime.checkpoint
-
Policy for whether checkpoints are retained after a job terminates.
- Checkpoints - Class in org.apache.flink.runtime.checkpoint
-
A utility class with the methods to write/load/dispose the checkpoint and savepoint metadata.
- CheckpointScheduling - Interface in org.apache.flink.runtime.checkpoint
-
CheckpointSchedulingprovides methods for starting and stopping the periodic scheduling of checkpoints. - CheckpointsCleaner - Class in org.apache.flink.runtime.checkpoint
-
Delegate class responsible for checkpoints cleaning and counting the number of checkpoints yet to clean.
- CheckpointsCleaner() - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointsCleaner
- CheckpointsCleaner(boolean) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointsCleaner
- checkpointsDirectory - Variable in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageAccess
- checkpointsMatch(Collection<CompletedCheckpoint>, Collection<CompletedCheckpoint>) - Static method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
- checkpointStarted(CheckpointBarrier) - Method in interface org.apache.flink.runtime.io.network.partition.consumer.CheckpointableInput
- checkpointStarted(CheckpointBarrier) - Method in class org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate
- checkpointStarted(CheckpointBarrier) - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Called by task thread when checkpointing is started (e.g., any input channel received barrier).
- checkpointStarted(CheckpointBarrier) - Method in class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
- checkpointStarted(CheckpointBarrier) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RecoveredInputChannel
- checkpointStarted(CheckpointBarrier) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
Spills all queued buffers on checkpoint start.
- checkpointStarted(CheckpointBarrier) - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
-
This method is used with unaligned checkpoints to mark the arrival of a first
CheckpointBarrier. - checkpointState(CheckpointMetaData, CheckpointOptions, CheckpointMetricsBuilder, OperatorChain<?, ?>, boolean, Supplier<Boolean>) - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
-
Must be called after
SubtaskCheckpointCoordinator.initInputsCheckpoint(long, CheckpointOptions). - CheckpointStateOutputStream - Class in org.apache.flink.runtime.state
-
A dedicated output stream that produces a
StreamStateHandlewhen closed. - CheckpointStateOutputStream() - Constructor for class org.apache.flink.runtime.state.CheckpointStateOutputStream
- CheckpointStateToolset - Interface in org.apache.flink.runtime.state
-
A toolset of operations that can be performed on a location embedded within the class.
- CheckpointStatisticDetailsHandler - Class in org.apache.flink.runtime.rest.handler.job.checkpoints
-
REST handler which returns the details for a checkpoint.
- CheckpointStatisticDetailsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, CheckpointStatistics, CheckpointMessageParameters>, Executor, Cache<JobID, CompletableFuture<CheckpointStatsSnapshot>>, CheckpointStatsCache) - Constructor for class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointStatisticDetailsHandler
- CheckpointStatisticDetailsHeaders - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Headers for the
CheckpointStatisticDetailsHandler. - CheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Statistics for a checkpoint.
- CheckpointStatistics.CompletedCheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Statistics for a completed checkpoint.
- CheckpointStatistics.FailedCheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Statistics for a failed checkpoint.
- CheckpointStatistics.PendingCheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Statistics for a pending checkpoint.
- CheckpointStatsCache - Class in org.apache.flink.runtime.rest.handler.job.checkpoints
-
A size-based cache of accessed checkpoints for completed and failed checkpoints.
- CheckpointStatsCache(int) - Constructor for class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointStatsCache
- CheckpointStatsCounts - Class in org.apache.flink.runtime.checkpoint
-
Counts of checkpoints.
- CheckpointStatsHistory - Class in org.apache.flink.runtime.checkpoint
-
An array based history of checkpoint stats.
- CheckpointStatsListener - Interface in org.apache.flink.runtime.checkpoint
-
An interface that allows listening on the checkpoint lifecycle.
- CheckpointStatsSnapshot - Class in org.apache.flink.runtime.checkpoint
-
A snapshot of the checkpoint stats.
- CheckpointStatsStatus - Enum in org.apache.flink.runtime.checkpoint
-
Status of the tracked checkpoint.
- CheckpointStatsTracker - Interface in org.apache.flink.runtime.checkpoint
-
Tracker for checkpoint statistics.
- CheckpointStatusHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointHandlers.CheckpointStatusHandler
- CheckpointStatusHeaders - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
These headers define the protocol for querying the status of a checkpoint operation.
- CheckpointStatusMessageParameters - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
The parameters for triggering a checkpoint.
- CheckpointStatusMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatusMessageParameters
- checkpointStopped(long) - Method in interface org.apache.flink.runtime.io.network.partition.consumer.CheckpointableInput
- checkpointStopped(long) - Method in class org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate
- checkpointStopped(long) - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Called by task thread on cancel/complete to clean-up temporary data.
- checkpointStopped(long) - Method in class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
- checkpointStopped(long) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RecoveredInputChannel
- checkpointStopped(long) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- checkpointStopped(long) - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
- checkpointStorage - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Our checkpoint storage.
- CheckpointStorage - Interface in org.apache.flink.runtime.state
-
CheckpointStorage defines how
StateBackend's store their state for fault tolerance in streaming applications. - CheckpointStorageAccess - Interface in org.apache.flink.runtime.state
-
Implementations of this interface should implement methods acting as an administration role for checkpoint storage, which defined in
CheckpointStorageCoordinatorView. - CheckpointStorageCoordinatorView - Interface in org.apache.flink.runtime.state
-
This interface creates a
CheckpointStorageLocationto which an individual checkpoint or savepoint is stored. - CheckpointStorageFactory<T extends CheckpointStorage> - Interface in org.apache.flink.runtime.state
-
A factory to create a specific
CheckpointStorage. - CheckpointStorageLoader - Class in org.apache.flink.runtime.state
-
This class contains utility methods to load checkpoint storage from configurations.
- CheckpointStorageLoader() - Constructor for class org.apache.flink.runtime.state.CheckpointStorageLoader
- CheckpointStorageLocation - Interface in org.apache.flink.runtime.state
-
A storage location for one particular checkpoint, offering data persistent, metadata persistence, and lifecycle/cleanup methods.
- CheckpointStorageLocationReference - Class in org.apache.flink.runtime.state
-
A reference to a storage location.
- CheckpointStorageLocationReference(byte[]) - Constructor for class org.apache.flink.runtime.state.CheckpointStorageLocationReference
-
Creates a new location reference.
- CheckpointStorageWorkerView - Interface in org.apache.flink.runtime.state
-
This interface implements the durable storage of checkpoint data and metadata streams.
- CheckpointStoreUtil - Interface in org.apache.flink.runtime.checkpoint
-
CompletedCheckpointStoreutility interfaces. - CheckpointStreamFactory - Interface in org.apache.flink.runtime.state
-
A factory for checkpoint output streams, which are used to persist data for checkpoints.
- CheckpointStreamWithResultProvider - Interface in org.apache.flink.runtime.state
-
Interface that provides access to a CheckpointStateOutputStream and a method to provide the
SnapshotResult. - CheckpointStreamWithResultProvider.KeyedStateHandleFactory - Interface in org.apache.flink.runtime.state
-
Factory method for a
KeyedStateHandleto be used inCheckpointStreamWithResultProvider.toKeyedStateHandleSnapshotResult(SnapshotResult, KeyGroupRangeOffsets, KeyedStateHandleFactory). - CheckpointStreamWithResultProvider.PrimaryAndSecondaryStream - Class in org.apache.flink.runtime.state
-
Implementation of
CheckpointStreamWithResultProviderthat creates both, the primary/remote/jm-owned state and the secondary/local/tm-owned state. - CheckpointStreamWithResultProvider.PrimaryStreamOnly - Class in org.apache.flink.runtime.state
-
Implementation of
CheckpointStreamWithResultProviderthat only creates the primary/remote/jm-owned state. - CheckpointTriggerHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointHandlers.CheckpointTriggerHandler
- CheckpointTriggerHeaders - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
These headers define the protocol for triggering a checkpoint.
- CheckpointTriggerMessageParameters - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
The parameters for triggering a checkpoint.
- CheckpointTriggerMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointTriggerMessageParameters
- CheckpointTriggerRequestBody - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
RequestBodyto trigger checkpoints. - CheckpointTriggerRequestBody(CheckpointType, TriggerId) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointTriggerRequestBody
- CheckpointType - Class in org.apache.flink.runtime.checkpoint
-
The type of checkpoint to perform.
- checkSavepointActionPreconditions(CheckpointCoordinator, String, JobID, Logger) - Static method in class org.apache.flink.runtime.scheduler.stopwithsavepoint.StopWithSavepointTerminationManager
- checkStateMetaInfo(StateDescriptor<?, ?>) - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
- checkStateMetaInfo(StateDescriptor<?>) - Method in class org.apache.flink.runtime.state.v2.RegisteredKeyValueStateBackendMetaInfo
- checkSupportedInputCount(int) - Static method in class org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
- clean(F) - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
- clean(F) - Method in class org.apache.flink.streaming.api.datastream.BroadcastStream
- clean(F) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Invokes the
ClosureCleaneron the given function if closure cleaning is enabled in theExecutionConfig. - clean(F) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns a "closure-cleaned" version of the given function.
- cleanCheckpoint(Checkpoint, boolean, Runnable, Executor) - Method in class org.apache.flink.runtime.checkpoint.CheckpointsCleaner
- cleanCheckpointOnFailedStoring(CompletedCheckpoint, Executor) - Method in class org.apache.flink.runtime.checkpoint.CheckpointsCleaner
- cleaningUpDisconnectedResource(ResourceID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.NonSupportedResourceAllocatorImpl
- cleaningUpDisconnectedResource(ResourceID) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ResourceAllocator
-
Clean up the disconnected resource with the given resource id.
- cleanSubsumedCheckpoints(long, Set<Long>, Runnable, Executor) - Method in class org.apache.flink.runtime.checkpoint.CheckpointsCleaner
-
Clean checkpoint that is not in the given {@param stillInUse}.
- cleanup() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
- cleanup() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
- cleanup() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
- cleanup() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
- cleanup() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
- cleanup() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
- cleanup() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
- cleanup() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
- cleanup() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
- cleanup() - Method in class org.apache.flink.runtime.operators.CrossDriver
- cleanup() - Method in interface org.apache.flink.runtime.operators.Driver
-
This method is invoked in any case (clean termination and exception) at the end of the tasks operation.
- cleanup() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
- cleanup() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
- cleanup() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
- cleanup() - Method in class org.apache.flink.runtime.operators.JoinDriver
- cleanup() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
- cleanup() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
- cleanup() - Method in class org.apache.flink.runtime.operators.MapDriver
- cleanup() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
- cleanup() - Method in class org.apache.flink.runtime.operators.NoOpDriver
- cleanup() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
- cleanup() - Method in class org.apache.flink.runtime.operators.ReduceDriver
- cleanup() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
- cleanup() - Method in class org.apache.flink.runtime.rest.handler.legacy.DefaultExecutionGraphCache
- cleanup() - Method in interface org.apache.flink.runtime.rest.handler.legacy.ExecutionGraphCache
-
Perform the cleanup of out dated cache entries.
- cleanup() - Method in class org.apache.flink.runtime.state.filesystem.FSDataOutputStreamWrapper
- cleanup() - Method in class org.apache.flink.runtime.state.filesystem.RecoverableStreamWrapper
- cleanup() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
-
Calling this method will attempt delete the underlying snapshot directory recursively, if the state is "ongoing".
- cleanUp(Throwable) - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
- cleanUp(Throwable) - Method in interface org.apache.flink.runtime.jobgraph.tasks.TaskInvokable
-
Cleanup any resources used in
TaskInvokable.invoke()ORTaskInvokable.restore(). - cleanUp(Throwable) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- cleanupAllData() - Method in interface org.apache.flink.runtime.blob.BlobStoreService
-
Cleans up the store.
- cleanupAllData() - Method in class org.apache.flink.runtime.blob.FileSystemBlobStore
- cleanupAllData() - Method in class org.apache.flink.runtime.blob.VoidBlobStore
- cleanupAllData() - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
- cleanupAllData() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Deletes all data stored by high availability services in external stores.
- cleanupAllData() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
- cleanupAsync(JobID) - Method in class org.apache.flink.runtime.dispatcher.cleanup.DefaultResourceCleaner
- cleanupAsync(JobID) - Method in interface org.apache.flink.runtime.dispatcher.cleanup.ResourceCleaner
-
Cleans job-related data from resources asynchronously.
- cleanupDirectories(ClusterEntrypoint.ShutdownBehaviour) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
Clean up of temporary directories created by the
ClusterEntrypoint. - cleanUpInternal() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
Deprecated.
- cleanUpInternal() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
- cleanUpInternal() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- cleanupPartialRecord() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumerWithPartialRecordLength
- cleanupProvidedResources() - Method in class org.apache.flink.runtime.state.AsyncSnapshotCallable
-
This method implements the cleanup of resources that have been passed in (from the sync part).
- CleanupRetryStrategyFactory - Enum in org.apache.flink.runtime.dispatcher.cleanup
-
CleanupRetryStrategyFactoryis used to create theRetryStrategyfor theDispatcherResourceCleanerFactory. - CleanupRunnerFactory - Interface in org.apache.flink.runtime.dispatcher.cleanup
-
CleanupRunnerFactoryprovides a factory method for creatingCheckpointResourcesCleanupRunnerinstances. - clear() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- clear() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
- clear() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
- clear() - Method in class org.apache.flink.runtime.io.network.partition.PrioritizedDeque
-
Removes all priority and non-priority elements.
- clear() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Clears the internal state of the view.
- clear() - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
Clears the internal state.
- clear() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
-
Removes all entries from the PriorityQueue.
- clear() - Method in class org.apache.flink.runtime.operators.util.BitSet
-
Clear the bit set.
- clear() - Method in class org.apache.flink.runtime.query.KvStateEntry
- clear() - Method in class org.apache.flink.runtime.resourcemanager.DefaultJobLeaderIdService
- clear() - Method in interface org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
Stop and clear the currently registered job leader id listeners.
- clear() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.DefaultResourceTracker
- clear() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- clear() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ResourceTracker
-
Removes all state from the tracker.
- clear() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
-
Clears the queue.
- clear() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
- clear() - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueSet
- clear() - Method in class org.apache.flink.runtime.state.HeapBroadcastState
- clear() - Method in class org.apache.flink.runtime.state.PartitionableListState
- clear() - Method in class org.apache.flink.runtime.state.v2.AbstractKeyedState
- clear() - Method in class org.apache.flink.runtime.state.v2.adaptor.StateAdaptor
- clear() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
Removes all tasks from this task slot.
- clear() - Method in class org.apache.flink.runtime.util.BooleanArrayList
- clear() - Method in class org.apache.flink.runtime.util.DefaultGroupCache
- clear() - Method in class org.apache.flink.runtime.util.DualKeyLinkedMap
- clear() - Method in interface org.apache.flink.runtime.util.GroupCache
-
clear all cache.
- clear() - Method in class org.apache.flink.runtime.util.IntArrayList
- clear() - Method in class org.apache.flink.runtime.util.LongArrayList
- clear() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Remove all registered nodes etc.
- clear() - Method in class org.apache.flink.streaming.api.operators.util.SimpleVersionedListState
- clear() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
- clear() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
- clear() - Method in class org.apache.flink.streaming.runtime.watermarkstatus.HeapPriorityQueue
-
Clears the queue.
- clear(LeaderInformationRegister, String) - Static method in class org.apache.flink.runtime.leaderelection.LeaderInformationRegister
-
Creates a new
LeaderInformationRegisterthat matches the passedLeaderInformationRegisterexcept for the entry ofcomponentIdwhich is removed if it existed. - clear(ProcessAllWindowFunction.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction
-
Deletes any state in the
Contextwhen the Window expires (the watermark passes itsmaxTimestamp+allowedLateness). - clear(ProcessAllWindowFunction.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
- clear(ProcessWindowFunction.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction
-
Deletes any state in the
Contextwhen the Window expires (the watermark passes itsmaxTimestamp+allowedLateness). - clear(ProcessWindowFunction.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
- clear(GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.EndOfStreamTrigger
- clear(GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
- clear(TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
- clear(TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
- clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
Clears any state that the trigger might still hold for the given window.
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
- clear(W, InternalWindowFunction.InternalWindowContext) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction
-
Deletes any state in the
Contextwhen the Window expires (the watermark passes itsmaxTimestamp+allowedLateness). - CLEAR - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Clear the current partition of the state,
State.asyncClear(). - clearAll() - Method in class org.apache.flink.runtime.io.network.TaskEventDispatcher
-
Removes all registered event handlers.
- clearAllBroadcastVariables() - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
- clearAllMemory(List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
- clearAllMemory(List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
releases all of the partition's segments (pages and overflow buckets)
- clearAllMemory(List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.ReOpenableHashPartition
- clearAllPendingAllocations() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingTaskManager
- clearBroadcastVariable(String) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
- clearBuffers() - Method in interface org.apache.flink.runtime.io.network.api.reader.MutableReader
- clearBuffers() - Method in class org.apache.flink.runtime.io.network.api.reader.MutableRecordReader
- clearBuffers() - Method in interface org.apache.flink.runtime.io.network.api.reader.Reader
- clearBuffers() - Method in class org.apache.flink.runtime.io.network.api.reader.RecordReader
- clearCachedInformationForPartitionGroup(ConsumedPartitionGroup) - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
- clearCacheForGroup(G) - Method in class org.apache.flink.runtime.util.DefaultGroupCache
- clearCacheForGroup(G) - Method in interface org.apache.flink.runtime.util.GroupCache
-
Clear all caches of the corresponding group.
- clearEntries() - Method in interface org.apache.flink.runtime.persistence.StateHandleStore
-
Only clears all the state handle pointers on Kubernetes or ZooKeeper.
- clearEntries() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Recursively deletes all children.
- clearInitialConfigs() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
In general, we don't clear any configuration.
- clearJobListeners() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Clear all registered
JobListeners. - clearMetaDataFollowsFlag(byte[]) - Static method in class org.apache.flink.runtime.state.FullSnapshotUtil
- clearPartitions() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
This method clears all partitions currently residing (partially) in memory.
- clearPendingAllocationsOfJob(JobID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- clearPendingAllocationsOfJob(JobID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingTaskManager
- clearReaders(MutableReader<?>[]) - Static method in class org.apache.flink.runtime.operators.BatchTask
- clearResourceFor(TieredStorageDataIdentifier) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageResourceRegistry
-
Remove all resources for the given owner.
- clearResourceRequirements(JobID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedSlotManager
- clearResourceRequirements(JobID) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Notifies the slot manager that the resource requirements for the given job should be cleared.
- clearWriters(List<RecordWriter<?>>) - Static method in class org.apache.flink.runtime.operators.BatchTask
- client - Variable in class org.apache.flink.streaming.api.operators.collect.ClientAndIterator
- CLIENT_ALIVENESS_CHECK_DURATION - Static variable in class org.apache.flink.runtime.dispatcher.Dispatcher
- ClientAndIterator<E> - Class in org.apache.flink.streaming.api.operators.collect
-
A pair of an
Iteratorto receive results from a streaming application and aJobClientto interact with the program. - ClientAndIterator(JobClient, CloseableIterator<E>) - Constructor for class org.apache.flink.streaming.api.operators.collect.ClientAndIterator
- ClientCoordinationHandler - Class in org.apache.flink.runtime.rest.handler.job.coordination
-
Handler that receives the coordination requests from the client and returns the response from the coordinator.
- ClientCoordinationHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<ClientCoordinationRequestBody, ClientCoordinationResponseBody, ClientCoordinationMessageParameters>) - Constructor for class org.apache.flink.runtime.rest.handler.job.coordination.ClientCoordinationHandler
- ClientCoordinationHeaders - Class in org.apache.flink.runtime.rest.messages.job.coordination
-
Message headers for the
ClientCoordinationHandler. - ClientCoordinationMessageParameters - Class in org.apache.flink.runtime.rest.messages.job.coordination
- ClientCoordinationMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.coordination.ClientCoordinationMessageParameters
- ClientCoordinationRequestBody - Class in org.apache.flink.runtime.rest.messages.job.coordination
-
Request that carries a serialized
CoordinationRequestto a specified coordinator. - ClientCoordinationRequestBody(SerializedValue<CoordinationRequest>) - Constructor for class org.apache.flink.runtime.rest.messages.job.coordination.ClientCoordinationRequestBody
- ClientCoordinationResponseBody - Class in org.apache.flink.runtime.rest.messages.job.coordination
-
Response that carries a serialized
CoordinationResponseto the client. - ClientCoordinationResponseBody(SerializedValue<CoordinationResponse>) - Constructor for class org.apache.flink.runtime.rest.messages.job.coordination.ClientCoordinationResponseBody
- ClientHighAvailabilityServices - Interface in org.apache.flink.runtime.highavailability
-
ClientHighAvailabilityServicesprovides services those are required on client-side. - ClientHighAvailabilityServicesFactory - Interface in org.apache.flink.runtime.highavailability
-
Factory interface for
ClientHighAvailabilityServices. - ClientUtils - Enum in org.apache.flink.runtime.client
-
Contains utility methods for clients.
- clock - Variable in class org.apache.flink.runtime.jobmaster.slotpool.AbstractSlotPoolServiceFactory
- cloneConfiguration(Configuration) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Clones the given configuration and resets instance specific config options.
- close() - Method in class org.apache.flink.runtime.asyncprocessing.AsyncExecutionController
- close() - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperator
- close() - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperatorV2
- close() - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateUdfStreamOperator
- close() - Method in class org.apache.flink.runtime.asyncprocessing.StateRequestBuffer
- close() - Method in class org.apache.flink.runtime.blob.AbstractBlobCache
- close() - Method in class org.apache.flink.runtime.blob.BlobCacheService
- close() - Method in class org.apache.flink.runtime.blob.BlobClient
- close() - Method in class org.apache.flink.runtime.blob.BlobServer
-
Shuts down the BLOB server.
- close() - Method in class org.apache.flink.runtime.blob.FileSystemBlobStore
- close() - Method in class org.apache.flink.runtime.blob.VoidBlobStore
- close() - Method in class org.apache.flink.runtime.blocklist.DefaultBlocklistHandler
- close() - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter.NoOpChannelStateWriter
- close() - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriterImpl
- close() - Method in interface org.apache.flink.runtime.checkpoint.channel.SequentialChannelStateReader
- close() - Method in class org.apache.flink.runtime.checkpoint.channel.SequentialChannelStateReaderImpl
- close() - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
- close() - Method in class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFile
- close() - Method in class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFilePool
- close() - Method in class org.apache.flink.runtime.checkpoint.filemerging.WithinCheckpointFileMergingSnapshotManager
- close() - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
-
Tear-down method for the hook.
- close() - Method in class org.apache.flink.runtime.dispatcher.FileExecutionGraphInfoStore
- close() - Method in class org.apache.flink.runtime.dispatcher.MemoryExecutionGraphInfoStore
- close() - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
- close() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Closes the high availability services, releasing all resources.
- close() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
- close() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
- close() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneClientHAServices
- close() - Method in class org.apache.flink.runtime.highavailability.zookeeper.CuratorFrameworkWithUnhandledErrorListener
- close() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperClientHAServices
- close() - Method in class org.apache.flink.runtime.io.disk.FileBasedBufferIterator
- close() - Method in class org.apache.flink.runtime.io.disk.FileChannelInputView
- close() - Method in class org.apache.flink.runtime.io.disk.FileChannelManagerImpl
-
Remove all the temp directories.
- close() - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
-
Closes this output, writing pending data and releasing the memory.
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractChannelReaderInputView
-
Closes this InputView, closing the underlying reader and returning all memory segments.
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
-
Closes this OutputView, closing the underlying writer
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
Closes the channel and waits until all pending asynchronous requests are processed.
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
Closes this InputView, closing the underlying reader and returning all memory segments.
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
Closes this OutputView, closing the underlying writer and returning all memory segments.
- close() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
-
Closes the channel.
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Removes all temporary files.
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
Close method.
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.RequestQueue
-
Closes this request queue.
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.SynchronousFileIOChannel
- close() - Method in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
- close() - Method in class org.apache.flink.runtime.io.disk.SpillingBuffer
- close() - Method in class org.apache.flink.runtime.io.network.api.writer.MultipleRecordWriters
- close() - Method in class org.apache.flink.runtime.io.network.api.writer.NonRecordWriter
- close() - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
Closes the writer.
- close() - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
Closes the partition writer which releases the allocated resource, for example the buffer pool.
- close() - Method in class org.apache.flink.runtime.io.network.api.writer.SingleRecordWriter
- close() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
- close() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
- close() - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
Tries to shut down all network I/O components.
- close() - Method in class org.apache.flink.runtime.io.network.partition.BufferWritingResultPartition
- close() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- close() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
- close() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.index.FileDataIndexCache
-
Close
FileDataIndexCache, this will delete the index file. - close() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.index.FileDataIndexSpilledRegionManager
-
Close this spilled region manager.
- close() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.index.FileDataIndexSpilledRegionManagerImpl
- close() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredInternalShuffleMaster
- close() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartition
- close() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.BufferAccumulator
-
Close the accumulator.
- close() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.HashBufferAccumulator
- close() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.HashSubpartitionBufferAccumulator
- close() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.SortBufferAccumulator
- close() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageConsumerClient
- close() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMasterClient
- close() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageProducerClient
- close() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskTierConsumerAgent
- close() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskTierProducerAgent
- close() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory.MemoryTierConsumerAgent
- close() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory.MemoryTierProducerAgent
- close() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.NoOpMasterAgent
- close() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteStorageScanner
-
Close the executor.
- close() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierConsumerAgent
- close() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierMasterAgent
- close() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierProducerAgent
- close() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierConsumerAgent
-
Close the consumer agent.
- close() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierMasterAgent
-
Close this tier master agent.
- close() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierProducerAgent
-
Close the agent.
- close() - Method in class org.apache.flink.runtime.io.network.partition.PartitionedFileWriter
- close() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedResultPartition
- close() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- close() - Method in class org.apache.flink.runtime.io.network.partition.SortMergeResultPartition
- close() - Method in class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
- close() - Method in class org.apache.flink.runtime.iterative.io.SolutionSetFastUpdateOutputCollector
- close() - Method in class org.apache.flink.runtime.iterative.io.SolutionSetObjectsUpdateOutputCollector
- close() - Method in class org.apache.flink.runtime.iterative.io.SolutionSetUpdateOutputCollector
- close() - Method in class org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
- close() - Method in interface org.apache.flink.runtime.jobmaster.ServiceConnectionManager
-
Close the service connection manager.
- close() - Method in class org.apache.flink.runtime.jobmaster.slotpool.AbstractServiceConnectionManager
- close() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolService
- close() - Method in enum org.apache.flink.runtime.jobmaster.slotpool.NoOpDeclareResourceRequirementServiceConnectionManager
- close() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
- close() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolService
-
Close the slot pool service.
- close() - Method in class org.apache.flink.runtime.leaderelection.DefaultLeaderElectionService
- close() - Method in interface org.apache.flink.runtime.leaderelection.LeaderElection
-
Closes the
LeaderElectionby deregistering theLeaderContenderfrom the underlying leader election. - close() - Method in class org.apache.flink.runtime.leaderelection.StandaloneLeaderElection
- close() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionDriver
- close() - Method in class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalDriver
- close() - Method in class org.apache.flink.runtime.memory.OpaqueMemoryResource
-
Releases this resource.
- close() - Method in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricDumpSerializer
- close() - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
- close() - Method in class org.apache.flink.runtime.metrics.groups.ComponentMetricGroup
-
Closes the component group by removing and closing all metrics and subgroups (inherited from
AbstractMetricGroup), plus closing and removing all dedicated component subgroups. - close() - Method in class org.apache.flink.runtime.metrics.groups.JobManagerOperatorMetricGroup
- close() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
- close() - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
- close() - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
- close() - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
- close() - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
- close() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
- close() - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator
-
This method is called when the coordinator is disposed.
- close() - Method in class org.apache.flink.runtime.operators.coordination.OperatorCoordinatorHolder
- close() - Method in class org.apache.flink.runtime.operators.coordination.RecreateOnResetOperatorCoordinator
- close() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
Closes the hash table.
- close() - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
-
Closes the hash table.
- close() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
- close() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Closes the hash table.
- close() - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
- close() - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
- close() - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
- close() - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
- close() - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
- close() - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
- close() - Method in class org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
- close() - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
- close() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
- close() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
- close() - Method in class org.apache.flink.runtime.operators.shipping.OutputCollector
- close() - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
- close() - Method in class org.apache.flink.runtime.operators.sort.ExternalSorter
-
Shuts down all the threads initiated by this sort/merger.
- close() - Method in class org.apache.flink.runtime.operators.sort.LargeRecordHandler
-
Closes all structures and deletes all temporary files.
- close() - Method in class org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
- close() - Method in class org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
- close() - Method in class org.apache.flink.runtime.operators.TempBarrier
- close() - Method in interface org.apache.flink.runtime.operators.util.CoGroupTaskIterator
-
General-purpose close method.
- close() - Method in interface org.apache.flink.runtime.operators.util.JoinTaskIterator
-
General-purpose close method.
- close() - Method in class org.apache.flink.runtime.operators.util.metrics.CountingCollector
- close() - Method in class org.apache.flink.runtime.operators.util.SimpleCloseableInputProvider
- close() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
Close connection.
- close() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.DefaultSlotStatusSyncer
- close() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedSlotManager
-
Closes the slot manager.
- close() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotStatusSyncer
-
Close this syncer, clear all the state.
- close() - Method in class org.apache.flink.runtime.rest.handler.FileUploads
- close() - Method in class org.apache.flink.runtime.rest.handler.job.JobVertexFlameGraphHandler
- close() - Method in class org.apache.flink.runtime.rest.handler.legacy.DefaultExecutionGraphCache
- close() - Method in interface org.apache.flink.runtime.rest.handler.legacy.ExecutionGraphCache
-
Closes the execution graph cache.
- close() - Method in class org.apache.flink.runtime.scheduler.adaptive.DefaultStateTransitionManager
- close() - Method in interface org.apache.flink.runtime.scheduler.adaptive.StateTransitionManager
-
Is called when the state transition manager should be closed.
- close() - Method in class org.apache.flink.runtime.shuffle.NettyShuffleMaster
- close() - Method in interface org.apache.flink.runtime.shuffle.ShuffleMaster
-
Closes this shuffle master service which should release all resources.
- close() - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinator
- close() - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinatorContext
- close() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- close() - Method in class org.apache.flink.runtime.state.BoundedInputStream
- close() - Method in class org.apache.flink.runtime.state.changelog.LocalChangelogRegistryImpl
- close() - Method in interface org.apache.flink.runtime.state.changelog.StateChangelogStorageView
- close() - Method in interface org.apache.flink.runtime.state.changelog.StateChangelogWriter
-
Close this log.
- close() - Method in class org.apache.flink.runtime.state.CheckpointMetadataOutputStream
-
This method should close the stream, if has not been closed before.
- close() - Method in class org.apache.flink.runtime.state.CheckpointStateOutputStream
-
This method should close the stream, if has not been closed before.
- close() - Method in interface org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
- close() - Method in class org.apache.flink.runtime.state.CompressibleFSDataInputStream
- close() - Method in class org.apache.flink.runtime.state.CompressibleFSDataOutputStream
- close() - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
- close() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
- close() - Method in class org.apache.flink.runtime.state.FileMergingSnapshotManagerClosableWrapper
- close() - Method in class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
- close() - Method in class org.apache.flink.runtime.state.filesystem.FileMergingCheckpointStateOutputStream
-
This method throws no exception if the close fails, but only logs the error.
- close() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
- close() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
-
If the stream is only closed, we remove the produced file (cleanup through the auto close feature, for example).
- close() - Method in class org.apache.flink.runtime.state.filesystem.FsMergingCheckpointStorageAccess
-
This will be registered to resource closer of
StreamTask. - close() - Method in class org.apache.flink.runtime.state.heap.HeapKeyValueStateIterator
- close() - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
- close() - Method in interface org.apache.flink.runtime.state.KeyValueStateIterator
- close() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
- close() - Method in class org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
- close() - Method in class org.apache.flink.runtime.state.RetrievableStreamStateHandle
- close() - Method in class org.apache.flink.runtime.state.SharedStateRegistryImpl
- close() - Method in class org.apache.flink.runtime.state.TaskStateManagerImpl
- close() - Method in class org.apache.flink.runtime.state.v2.adaptor.AsyncKeyedStateBackendAdaptor
- close() - Method in class org.apache.flink.runtime.taskexecutor.DefaultJobTable
- close() - Method in interface org.apache.flink.runtime.taskexecutor.JobTable.Job
-
Closes this job and removes it from the owning
JobTable. - close() - Method in interface org.apache.flink.runtime.taskexecutor.JobTable.JobServices
-
Closes the job services.
- close() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
- close() - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
- close() - Method in class org.apache.flink.runtime.util.ForwardingInputStream
- close() - Method in class org.apache.flink.runtime.util.ForwardingOutputStream
- close() - Method in class org.apache.flink.runtime.util.NonClosingInputStreamDecorator
- close() - Method in class org.apache.flink.runtime.util.NonClosingOutputStreamDecorator
- close() - Method in class org.apache.flink.runtime.util.profiler.ProfilingService
- close() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
- close() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
- close() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Close and clean up the execution environment.
- close() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.OutputFormatSinkFunction
-
Deprecated.
- close() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.SocketClientSink
-
Deprecated.Closes the connection with the Socket server.
- close() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
- close() - Method in class org.apache.flink.streaming.api.functions.source.legacy.ContinuousFileMonitoringFunction
-
Deprecated.
- close() - Method in class org.apache.flink.streaming.api.functions.source.legacy.InputFormatSourceFunction
-
Deprecated.
- close() - Method in interface org.apache.flink.streaming.api.functions.source.legacy.SourceFunction.SourceContext
-
Deprecated.This method is called by the system to shut down the context.
- close() - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
- close() - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
- close() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- close() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- close() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
- close() - Method in class org.apache.flink.streaming.api.operators.collect.ClientAndIterator
- close() - Method in class org.apache.flink.streaming.api.operators.collect.CollectResultFetcher
- close() - Method in class org.apache.flink.streaming.api.operators.collect.CollectResultIterator
- close() - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
- close() - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperator
- close() - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
- close() - Method in class org.apache.flink.streaming.api.operators.CountingOutput
- close() - Method in class org.apache.flink.streaming.api.operators.MapPartitionIterator
- close() - Method in class org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput
- close() - Method in class org.apache.flink.streaming.api.operators.sort.SortingDataInput
- close() - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
- close() - Method in class org.apache.flink.streaming.api.operators.SourceOperator
- close() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
This method is called at the very end of the operator's life, both in the case of a successful completion of the operation, and in the case of a failure and canceling.
- close() - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
Deprecated.
- close() - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
- close() - Method in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
- close() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
- close() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
-
Cleans up all internally held resources.
- close() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
- close() - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
- close() - Method in class org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessor
- close() - Method in class org.apache.flink.streaming.runtime.io.StreamOneInputProcessor
- close() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput
- close() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
- close() - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
- close() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
- close() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
- close() - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
- close() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
Lifecycle method to close the mailbox for action submission/retrieval.
- close() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
Close the mailbox.
- close() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
- close() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
This method releases all resources of the record writer output.
- close() - Method in class org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
- close() - Method in class org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper
-
Close the operator.
- close(Throwable) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyConnectionWriter
-
If error is null, remove and recycle all buffers in the writer.
- close(Throwable) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyConnectionWriterImpl
- close(Collection<MasterTriggerRestoreHook<?>>, Logger) - Static method in class org.apache.flink.runtime.checkpoint.hooks.MasterHooks
-
Closes the master hooks.
- close(FileMergingSnapshotManager.SubtaskKey) - Method in class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFilePool
-
Close files in shared file pool by subtaskKey and close all files in exclusive file pool.
- close(RemoteInputChannel) - Method in class org.apache.flink.runtime.io.network.netty.NettyPartitionRequestClient
- close(RemoteInputChannel) - Method in interface org.apache.flink.runtime.io.network.PartitionRequestClient
-
Cancels the partition request for the given remote input channel and removes this client from factory if it is not referenced by any other input channels.
- CloseableInputProvider<E> - Interface in org.apache.flink.runtime.operators.util
-
Utility interface for a provider of an input that can be closed.
- closeAction() - Method in class org.apache.flink.runtime.state.filesystem.FSDataOutputStreamWrapper
- closeAction() - Method in class org.apache.flink.runtime.state.filesystem.RecoverableStreamWrapper
- closeAllOperators() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
Execute
StreamOperator.close()of each operator in the chain of thisStreamTask. - closeAllOperators() - Method in class org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
- closeAndDelete() - Method in class org.apache.flink.runtime.io.disk.FileChannelInputView
- closeAndDelete() - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
-
Closes this output, writing pending data and releasing the memory.
- closeAndDelete() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
- closeAndDelete() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
This method waits for all pending asynchronous requests to return.
- closeAndDelete() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
-
Closes the channel and deletes the underlying file.
- closeAndDelete() - Method in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
- closeAndFinalizeCheckpoint() - Method in class org.apache.flink.runtime.state.CheckpointMetadataOutputStream
-
Closes the stream after all metadata was written and finalizes the checkpoint location.
- closeAndFinalizeCheckpoint() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
- closeAndFinalizeCheckpointStreamResult() - Method in interface org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
-
Closes the stream ans returns a snapshot result with the stream handle(s).
- closeAndFinalizeCheckpointStreamResult() - Method in class org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryAndSecondaryStream
- closeAndFinalizeCheckpointStreamResult() - Method in class org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryStreamOnly
- closeAndGetBytes() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
-
Closes the stream and returns the byte array containing the stream's data.
- closeAndGetHandle() - Method in class org.apache.flink.runtime.state.CheckpointStateOutputStream
-
Closes the stream and gets a state handle that can create an input stream producing the data written to this stream.
- closeAndGetHandle() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
- closeAndGetHandle() - Method in class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
- closeAndGetHandle() - Method in class org.apache.flink.runtime.state.filesystem.FileMergingCheckpointStateOutputStream
- closeAndGetHandle() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
- closeAndGetHandle() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
- closeAndGetPrimaryHandle() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
-
Returns the state handle from the
DuplicatingCheckpointOutputStream.primaryOutputStream. - closeAndGetSecondaryHandle() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
-
Returns the state handle from the
DuplicatingCheckpointOutputStream.secondaryOutputStream. - closeAsync() - Method in class org.apache.flink.runtime.checkpoint.CheckpointsCleaner
- closeAsync() - Method in class org.apache.flink.runtime.dispatcher.cleanup.CheckpointResourcesCleanupRunner
- closeAsync() - Method in class org.apache.flink.runtime.dispatcher.DispatcherOperationCaches
- closeAsync() - Method in class org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess
- closeAsync() - Method in class org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherGatewayService
- closeAsync() - Method in class org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherRunner
- closeAsync() - Method in enum org.apache.flink.runtime.dispatcher.runner.StoppedDispatcherLeaderProcess
- closeAsync() - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
- closeAsync() - Method in class org.apache.flink.runtime.entrypoint.component.DispatcherResourceManagerComponent
- closeAsync() - Method in class org.apache.flink.runtime.jobmaster.DefaultJobMasterServiceProcess
- closeAsync() - Method in class org.apache.flink.runtime.jobmaster.JobMasterServiceLeadershipRunner
- closeAsync() - Method in enum org.apache.flink.runtime.jobmaster.JobMasterServiceProcess.WaitingForLeadership
- closeAsync() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
Shuts down this registry and the associated
MetricReporter. - closeAsync() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
Shuts down the mini cluster, failing all currently executing jobs.
- closeAsync() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerServiceImpl
- closeAsync() - Method in class org.apache.flink.runtime.rest.handler.AbstractHandler
- closeAsync() - Method in class org.apache.flink.runtime.rest.handler.async.CompletedOperationCache
- closeAsync() - Method in class org.apache.flink.runtime.rest.RestClient
- closeAsync() - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
- closeAsync() - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- closeAsync() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.AdaptiveBatchScheduler
- closeAsync() - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- closeAsync() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
- closeAsync() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- closeAsync() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorToServiceAdapter
- closeAsync() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
- closeAsync() - Method in enum org.apache.flink.runtime.webmonitor.WebMonitorExtension.EmptyWebMonitorExtension
- closeAsyncWithoutCleaningHighAvailabilityData() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- closeAsyncWithTimeout(String, Runnable, Duration) - Static method in class org.apache.flink.runtime.operators.coordination.ComponentClosingUtils
-
Close a component with a timeout.
- closeAsyncWithTimeout(String, ThrowingRunnable<Exception>, Duration) - Static method in class org.apache.flink.runtime.operators.coordination.ComponentClosingUtils
-
Close a component with a timeout.
- closeChainedTasks(List<ChainedDriver<?, ?>>, AbstractInvokable) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Closes all chained tasks, in the order as they are stored in the array.
- closeConnection() - Method in class org.apache.flink.runtime.io.network.netty.NettyPartitionRequestClient
- closed - Variable in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
Flag marking this channel as closed
- closed - Variable in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
Flag to mark the table as open / closed.
- closed - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Flag indicating that the closing logic has been invoked.
- closed() - Method in class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFile
- CLOSED - org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox.State
- closeExceptionally() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
- closeForCommitAction() - Method in class org.apache.flink.runtime.state.filesystem.FSDataOutputStreamWrapper
- closeForCommitAction() - Method in class org.apache.flink.runtime.state.filesystem.RecoverableStreamWrapper
- closeHandlerAsync() - Method in class org.apache.flink.runtime.rest.handler.AbstractHandler
- closeHandlerAsync() - Method in class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.StatusHandler
- closeJobManagerConnection(JobID, ResourceManager.ResourceRequirementHandling, Exception) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
This method should be called by the framework once it detects that a currently registered job manager has failed.
- closeLocalStrategiesAndCaches() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
- closeLocalStrategiesAndCaches() - Method in class org.apache.flink.runtime.operators.BatchTask
- closeLock - Variable in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
The lock that is used during closing to synchronize the thread that waits for all requests to be handled with the asynchronous I/O thread.
- closeOpenChannelConnections(ConnectionID) - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
-
Closes opened ChannelConnections in case of a resource release.
- closeOpenChannelConnections(ConnectionID) - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
- closeOpenChannelConnections(ConnectionID) - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
- closer - Variable in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- closeStreamAndCreateStateHandle(Path, long, long) - Method in interface org.apache.flink.runtime.state.filesystem.FileMergingCheckpointStateOutputStream.FileMergingSnapshotManagerProxy
-
Close the stream and create a
SegmentFileStateHandlefor a file segment. - closeStreamExceptionally() - Method in interface org.apache.flink.runtime.state.filesystem.FileMergingCheckpointStateOutputStream.FileMergingSnapshotManagerProxy
-
Notify the
FileMergingSnapshotManagerthat the stream is closed exceptionally. - closeTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
- closeTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
- closeTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
- closeTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
- closeTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
- closeTask() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
- closeTask() - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
- closeTaskManagerConnection(ResourceID, Exception) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
This method should be called by the framework once it detects that a currently registered task executor has failed.
- closeUserCode(Function) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Closes the given stub using its
RichFunction.close()method. - closeWithOptionalClean(boolean) - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Calls
HighAvailabilityServices.cleanupAllData()(iftrueis passed as a parameter) before callingHighAvailabilityServices.close()on this instance. - CLUSTER_CONFIG_REST_PATH - Static variable in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
- ClusterConfigHandler - Class in org.apache.flink.runtime.rest.handler.cluster
-
Handler which serves the cluster's configuration.
- ClusterConfigHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, ConfigurationInfo, EmptyMessageParameters>, Configuration) - Constructor for class org.apache.flink.runtime.rest.handler.cluster.ClusterConfigHandler
- clusterConfiguration - Variable in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
- ClusterConfiguration - Class in org.apache.flink.runtime.entrypoint
-
Configuration class which contains the parsed command line arguments for the
ClusterEntrypoint. - ClusterConfiguration(String, Properties, String[]) - Constructor for class org.apache.flink.runtime.entrypoint.ClusterConfiguration
- ClusterConfigurationInfoHeaders - Class in org.apache.flink.runtime.rest.messages
-
Message headers for the
ClusterConfigHandler. - ClusterConfigurationParserFactory - Class in org.apache.flink.runtime.entrypoint
-
Parser factory which generates a
ClusterConfigurationfrom the given list of command line arguments. - ClusterConfigurationParserFactory() - Constructor for class org.apache.flink.runtime.entrypoint.ClusterConfigurationParserFactory
- ClusterDatasetCorruptedException - Exception in org.apache.flink.runtime.scheduler
-
Indicates some task fail to consume cluster dataset.
- ClusterDatasetCorruptedException(Throwable, List<IntermediateDataSetID>) - Constructor for exception org.apache.flink.runtime.scheduler.ClusterDatasetCorruptedException
- ClusterDataSetDeleteHandlers - Class in org.apache.flink.runtime.rest.handler.dataset
-
Handler for
ClusterDataSetDeleteTriggerHeaders. - ClusterDataSetDeleteHandlers(Duration) - Constructor for class org.apache.flink.runtime.rest.handler.dataset.ClusterDataSetDeleteHandlers
- ClusterDataSetDeleteHandlers.ClusterDataSetDeleteStatusHandler - Class in org.apache.flink.runtime.rest.handler.dataset
-
AbstractAsynchronousOperationHandlers.StatusHandlerimplementation for the cluster data set delete operation. - ClusterDataSetDeleteHandlers.ClusterDataSetDeleteTriggerHandler - Class in org.apache.flink.runtime.rest.handler.dataset
-
AbstractAsynchronousOperationHandlers.TriggerHandlerimplementation for the cluster data set delete operation. - ClusterDataSetDeleteHandlers.SerializableVoid - Class in org.apache.flink.runtime.rest.handler.dataset
-
A
Voidalternative that implementsSerializable. - ClusterDataSetDeleteStatusHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.dataset.ClusterDataSetDeleteHandlers.ClusterDataSetDeleteStatusHandler
- ClusterDataSetDeleteStatusHeaders - Class in org.apache.flink.runtime.rest.messages.dataset
-
Specification for retrieving the status for the delete operation of a cluster data set.
- ClusterDataSetDeleteStatusMessageParameters - Class in org.apache.flink.runtime.rest.messages.dataset
- ClusterDataSetDeleteStatusMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteStatusMessageParameters
- ClusterDataSetDeleteTriggerHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, GatewayRetriever<ResourceManagerGateway>) - Constructor for class org.apache.flink.runtime.rest.handler.dataset.ClusterDataSetDeleteHandlers.ClusterDataSetDeleteTriggerHandler
- ClusterDataSetDeleteTriggerHeaders - Class in org.apache.flink.runtime.rest.messages.dataset
-
Specification for triggering the deletion of a cluster data set.
- ClusterDataSetDeleteTriggerMessageParameters - Class in org.apache.flink.runtime.rest.messages.dataset
- ClusterDataSetDeleteTriggerMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteTriggerMessageParameters
- ClusterDataSetEntry - Class in org.apache.flink.runtime.rest.messages.dataset
-
The entry for a single cluster data set.
- clusterDataSetIdPathParameter - Variable in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteTriggerMessageParameters
- ClusterDataSetIdPathParameter - Class in org.apache.flink.runtime.rest.messages.dataset
-
Path parameter identifying cluster data sets.
- ClusterDataSetIdPathParameter() - Constructor for class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetIdPathParameter
- ClusterDataSetListHandler - Class in org.apache.flink.runtime.rest.handler.dataset
-
Handler for
ClusterDataSetListHeaders. - ClusterDataSetListHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, GatewayRetriever<ResourceManagerGateway>) - Constructor for class org.apache.flink.runtime.rest.handler.dataset.ClusterDataSetListHandler
- ClusterDataSetListHeaders - Class in org.apache.flink.runtime.rest.messages.dataset
-
Specification for retrieving an overview over all available cluster partitions.
- ClusterDataSetListResponseBody - Class in org.apache.flink.runtime.rest.messages.dataset
- ClusterEntrypoint - Class in org.apache.flink.runtime.entrypoint
-
Base class for the Flink cluster entry points.
- ClusterEntrypoint(Configuration) - Constructor for class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
- ClusterEntrypoint.ExecutionMode - Enum in org.apache.flink.runtime.entrypoint
-
Execution mode of the
MiniDispatcher. - ClusterEntrypoint.ShutdownBehaviour - Enum in org.apache.flink.runtime.entrypoint
-
Shutdown behaviour of a
ClusterEntrypoint. - ClusterEntrypointException - Exception in org.apache.flink.runtime.entrypoint
-
Exceptions thrown by the
ClusterEntrypoint. - ClusterEntrypointException(String) - Constructor for exception org.apache.flink.runtime.entrypoint.ClusterEntrypointException
- ClusterEntrypointException(String, Throwable) - Constructor for exception org.apache.flink.runtime.entrypoint.ClusterEntrypointException
- ClusterEntrypointException(Throwable) - Constructor for exception org.apache.flink.runtime.entrypoint.ClusterEntrypointException
- ClusterEntryPointExceptionUtils - Class in org.apache.flink.runtime.entrypoint
-
Exception utils to handle and enrich exceptions occurring in the ClusterEntrypoint.
- ClusterEntrypointUtils - Class in org.apache.flink.runtime.entrypoint
-
Utility class for
ClusterEntrypoint. - ClusterInformation - Class in org.apache.flink.runtime.entrypoint
-
Information about the cluster which is shared with the cluster components.
- ClusterInformation(String, int) - Constructor for class org.apache.flink.runtime.entrypoint.ClusterInformation
- ClusterOverview - Class in org.apache.flink.runtime.messages.webmonitor
-
Response to the
RequestStatusOverviewmessage, carrying a description of the Flink cluster status. - ClusterOverview(int, int, int, Integer, Integer, int, int, int, int) - Constructor for class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
- ClusterOverview(ResourceOverview, JobsOverview) - Constructor for class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
- ClusterOverviewHandler - Class in org.apache.flink.runtime.rest.handler.cluster
-
Handler which returns the cluster overview information with version.
- ClusterOverviewHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, ClusterOverviewWithVersion, EmptyMessageParameters>) - Constructor for class org.apache.flink.runtime.rest.handler.cluster.ClusterOverviewHandler
- ClusterOverviewHeaders - Class in org.apache.flink.runtime.rest.messages
-
Message headers for the
ClusterOverviewHandler. - ClusterOverviewWithVersion - Class in org.apache.flink.runtime.rest.handler.legacy.messages
-
Cluster overview message including the current Flink version and commit id.
- ClusterOverviewWithVersion(int, int, int, Integer, Integer, int, int, int, int, String, String) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
- ClusterPartitionManager - Interface in org.apache.flink.runtime.io.network.partition
-
Interface for components that manage cluster partitions.
- ClusterPartitionReport - Class in org.apache.flink.runtime.taskexecutor.partition
-
A report about the current status of all cluster partitions of the TaskExecutor, describing which partitions are available.
- ClusterPartitionReport(Collection<ClusterPartitionReport.ClusterPartitionReportEntry>) - Constructor for class org.apache.flink.runtime.taskexecutor.partition.ClusterPartitionReport
- ClusterPartitionReport.ClusterPartitionReportEntry - Class in org.apache.flink.runtime.taskexecutor.partition
-
An entry describing all partitions belonging to one dataset.
- ClusterPartitionReportEntry(IntermediateDataSetID, int, Map<ResultPartitionID, ShuffleDescriptor>) - Constructor for class org.apache.flink.runtime.taskexecutor.partition.ClusterPartitionReport.ClusterPartitionReportEntry
- ClusterResourceStatisticsProvider - Interface in org.apache.flink.runtime.resourcemanager.slotmanager
-
Provides statistics of cluster resources.
- ClusterUncaughtExceptionHandler - Class in org.apache.flink.runtime.util
-
Utility for handling any uncaught exceptions
- ClusterUncaughtExceptionHandler(ClusterOptions.UncaughtExceptionHandleMode) - Constructor for class org.apache.flink.runtime.util.ClusterUncaughtExceptionHandler
- CO_GROUP - org.apache.flink.runtime.operators.DriverStrategy
- CO_GROUP_RAW - org.apache.flink.runtime.operators.DriverStrategy
- CoBroadcastWithKeyedOperator<KS,IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
A
TwoInputStreamOperatorfor executingKeyedBroadcastProcessFunctions. - CoBroadcastWithKeyedOperator(KeyedBroadcastProcessFunction<KS, IN1, IN2, OUT>, List<MapStateDescriptor<?, ?>>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
- CoBroadcastWithNonKeyedOperator<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
A
TwoInputStreamOperatorfor executingBroadcastProcessFunctions. - CoBroadcastWithNonKeyedOperator(BroadcastProcessFunction<IN1, IN2, OUT>, List<MapStateDescriptor<?, ?>>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
- CoFeedbackTransformation<F> - Class in org.apache.flink.streaming.api.transformations
-
This represents a feedback point in a topology.
- CoFeedbackTransformation(int, TypeInformation<F>, Long) - Constructor for class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
Creates a new
CoFeedbackTransformationfrom the given input. - CoFlatMapFunction<IN1,IN2,OUT> - Interface in org.apache.flink.streaming.api.functions.co
-
A CoFlatMapFunction implements a flat-map transformation over two connected streams.
- coGroup(DataStream<T2>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Creates a join operation.
- CoGroupDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
-
CoGroup task which is executed by a Task Manager.
- CoGroupDriver() - Constructor for class org.apache.flink.runtime.operators.CoGroupDriver
- CoGroupedStreams<T1,T2> - Class in org.apache.flink.streaming.api.datastream
-
CoGroupedStreamsrepresents twoDataStreamsthat have been co-grouped. - CoGroupedStreams(DataStream<T1>, DataStream<T2>) - Constructor for class org.apache.flink.streaming.api.datastream.CoGroupedStreams
-
Creates new CoGrouped data streams, which are the first step towards building a streaming co-group.
- CoGroupedStreams.TaggedUnion<T1,T2> - Class in org.apache.flink.streaming.api.datastream
-
Internal class for implementing tagged union co-group.
- CoGroupedStreams.UnionSerializer<T1,T2> - Class in org.apache.flink.streaming.api.datastream
-
TypeSerializerforCoGroupedStreams.TaggedUnion. - CoGroupedStreams.UnionSerializerSnapshot<T1,T2> - Class in org.apache.flink.streaming.api.datastream
-
The
TypeSerializerSnapshotfor theCoGroupedStreams.UnionSerializer. - CoGroupedStreams.Where<KEY> - Class in org.apache.flink.streaming.api.datastream
-
CoGrouped streams that have the key for one side defined.
- CoGroupedStreams.Where.EqualTo - Class in org.apache.flink.streaming.api.datastream
-
A co-group operation that has
KeySelectorsdefined for both inputs. - CoGroupedStreams.WithWindow<T1,T2,KEY,W extends Window> - Class in org.apache.flink.streaming.api.datastream
-
A co-group operation that has
KeySelectorsdefined for both inputs as well as aWindowAssigner. - CoGroupRawDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
- CoGroupRawDriver() - Constructor for class org.apache.flink.runtime.operators.CoGroupRawDriver
- CoGroupRawDriver.SimpleIterable<IN> - Class in org.apache.flink.runtime.operators
- CoGroupRawDriver.SimpleIterable.SimpleIterator<IN> - Class in org.apache.flink.runtime.operators
- CoGroupTaskIterator<T1,T2> - Interface in org.apache.flink.runtime.operators.util
-
Interface describing the methods that have to be implemented by local strategies for the CoGroup Pact.
- CoGroupWithSolutionSetFirstDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
- CoGroupWithSolutionSetFirstDriver() - Constructor for class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
- CoGroupWithSolutionSetSecondDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
- CoGroupWithSolutionSetSecondDriver() - Constructor for class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
- collect(IN) - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
- collect(IT) - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
- collect(IT) - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
- collect(IT) - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
- collect(IT) - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
- collect(IT) - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
- collect(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.api.operators.CountingOutput
- collect(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
- collect(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.streaming.api.operators.CountingOutput
- collect(OutputTag<X>, StreamRecord<X>) - Method in interface org.apache.flink.streaming.api.operators.Output
-
Emits a record to the side output identified by the given
OutputTag. - collect(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
- collect(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
- collect(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
- collect(OUT) - Method in class org.apache.flink.runtime.operators.util.metrics.CountingCollector
- collect(OUT) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
- collect(T) - Method in class org.apache.flink.runtime.iterative.io.SolutionSetFastUpdateOutputCollector
- collect(T) - Method in class org.apache.flink.runtime.iterative.io.SolutionSetObjectsUpdateOutputCollector
- collect(T) - Method in class org.apache.flink.runtime.iterative.io.SolutionSetUpdateOutputCollector
- collect(T) - Method in class org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
- collect(T) - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
- collect(T) - Method in class org.apache.flink.runtime.operators.shipping.OutputCollector
-
Collects a record and emits it to all writers.
- collect(T) - Method in interface org.apache.flink.streaming.api.functions.source.legacy.SourceFunction.SourceContext
-
Deprecated.Emits one element from the source, without attaching a timestamp.
- collect(T) - Method in class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
- collect(T) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
- collect(T, long) - Method in class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
- collectAndCheckIfChained(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
- collectAndCheckIfChained(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
- collectAndCheckIfChained(OutputTag<X>, StreamRecord<X>) - Method in interface org.apache.flink.streaming.runtime.tasks.OutputWithChainingCheck
- collectAndCheckIfChained(OUT) - Method in interface org.apache.flink.streaming.runtime.tasks.OutputWithChainingCheck
- collectAsync() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets up the collection of the elements in this
DataStream, and returns an iterator over the collected elements that can be used to retrieve elements once the job execution has started. - collectAsync(DataStream.Collector<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets up the collection of the elements in this
DataStream, which can be retrieved later via the givenDataStream.Collector. - CollectCoordinationRequest - Class in org.apache.flink.streaming.api.operators.collect
-
A
CoordinationRequestfrom the client indicating that it wants a new batch of query results. - CollectCoordinationRequest(String, long) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectCoordinationRequest
- CollectCoordinationRequest(DataInputView) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectCoordinationRequest
- CollectCoordinationResponse - Class in org.apache.flink.streaming.api.operators.collect
-
A
CoordinationResponsefrom the coordinator containing the required batch or new results and other necessary information in serialized form. - CollectCoordinationResponse(String, long, List<byte[]>) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
- CollectCoordinationResponse(DataInputView) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
- Collector() - Constructor for class org.apache.flink.streaming.api.datastream.DataStream.Collector
- CollectResultFetcher<T> - Class in org.apache.flink.streaming.api.operators.collect
-
A fetcher which fetches query results from sink and provides exactly-once semantics.
- CollectResultFetcher(AbstractCollectResultBuffer<T>, String, String, long) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectResultFetcher
- CollectResultIterator<T> - Class in org.apache.flink.streaming.api.operators.collect
-
An iterator which iterates through the results of a query job.
- CollectResultIterator(String, TypeSerializer<T>, String, CheckpointConfig, long) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectResultIterator
- CollectResultIterator(AbstractCollectResultBuffer<T>, String, String, int) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectResultIterator
- CollectSinkAddressEvent - Class in org.apache.flink.streaming.api.operators.collect
-
An
OperatorEventthat passes the socket server address in the sink to the coordinator. - CollectSinkAddressEvent(InetSocketAddress) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectSinkAddressEvent
- CollectSinkFunction<IN> - Class in org.apache.flink.streaming.api.operators.collect
-
A sink function that collects query results and sends them back to the client.
- CollectSinkFunction(TypeSerializer<IN>, long, String) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
- CollectSinkOperator<IN> - Class in org.apache.flink.streaming.api.operators.collect
-
A
StreamSinkthat collects query results and sends them back to the client. - CollectSinkOperator(TypeSerializer<IN>, long, String) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectSinkOperator
- CollectSinkOperatorCoordinator - Class in org.apache.flink.streaming.api.operators.collect
- CollectSinkOperatorCoordinator(int) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
- CollectSinkOperatorCoordinator.Provider - Class in org.apache.flink.streaming.api.operators.collect
-
Provider for
CollectSinkOperatorCoordinator. - CollectSinkOperatorFactory<IN> - Class in org.apache.flink.streaming.api.operators.collect
-
The Factory class for
CollectSinkOperator. - CollectSinkOperatorFactory(TypeSerializer<IN>, String) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorFactory
- CollectSinkOperatorFactory(TypeSerializer<IN>, String, MemorySize, Duration) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorFactory
- collectSizeStats(StateObject.StateObjectSizeStatsCollector) - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- collectSizeStats(StateObject.StateObjectSizeStatsCollector) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- collectSizeStats(StateObject.StateObjectSizeStatsCollector) - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- collectSizeStats(StateObject.StateObjectSizeStatsCollector) - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
- collectSizeStats(StateObject.StateObjectSizeStatsCollector) - Method in class org.apache.flink.runtime.state.ChainedStateHandle
- collectSizeStats(StateObject.StateObjectSizeStatsCollector) - Method in class org.apache.flink.runtime.state.changelog.inmemory.InMemoryChangelogStateHandle
- collectSizeStats(StateObject.StateObjectSizeStatsCollector) - Method in class org.apache.flink.runtime.state.DirectoryStateHandle
- collectSizeStats(StateObject.StateObjectSizeStatsCollector) - Method in class org.apache.flink.runtime.state.filemerging.SegmentFileStateHandle
- collectSizeStats(StateObject.StateObjectSizeStatsCollector) - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
- collectSizeStats(StateObject.StateObjectSizeStatsCollector) - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
- collectSizeStats(StateObject.StateObjectSizeStatsCollector) - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
- collectSizeStats(StateObject.StateObjectSizeStatsCollector) - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
- collectSizeStats(StateObject.StateObjectSizeStatsCollector) - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
- collectSizeStats(StateObject.StateObjectSizeStatsCollector) - Method in class org.apache.flink.runtime.state.OperatorStreamStateHandle
- collectSizeStats(StateObject.StateObjectSizeStatsCollector) - Method in class org.apache.flink.runtime.state.RetrievableStreamStateHandle
- collectSizeStats(StateObject.StateObjectSizeStatsCollector) - Method in interface org.apache.flink.runtime.state.StateObject
-
Collects statistics about state size and location from the state object.
- CollectStreamSink<T> - Class in org.apache.flink.streaming.api.operators.collect
-
A
DataStreamSinkwhich is used to collect results of a data stream. - CollectStreamSink(DataStream<T>, CollectSinkOperatorFactory<T>) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectStreamSink
- collectTaskStats(ImmutableSet<ExecutionAttemptID>, T) - Method in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator.PendingStatsRequest
-
Collects result from one of the tasks.
- collectUniqueDelegates(Stream<StateObjectCollection<? extends AbstractChannelStateHandle<?>>>) - Static method in class org.apache.flink.runtime.state.AbstractChannelStateHandle
- collectWithTimestamp(T, long) - Method in interface org.apache.flink.streaming.api.functions.source.legacy.SourceFunction.SourceContext
-
Deprecated.Emits one element from the source, and attaches the given timestamp.
- CoLocationConstraint - Class in org.apache.flink.runtime.jobmanager.scheduler
-
A
CoLocationConstraintstores the ID ofCoLocationGroupand an ID referring to the actual subtask (i.e. - CoLocationGroup - Interface in org.apache.flink.runtime.jobmanager.scheduler
-
CoLocationGrouprefers to a list ofJobVertexinstances, where the i-th subtask of one vertex has to be executed on the sameTaskManageras the i-th subtask of all otherJobVertexinstances in the same group. - CoLocationGroupImpl - Class in org.apache.flink.runtime.jobmanager.scheduler
-
A
CoLocationGroupimplementation. - CoLocationGroupImpl(JobVertex...) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroupImpl
- CoMapFunction<IN1,IN2,OUT> - Interface in org.apache.flink.streaming.api.functions.co
-
A CoFlatMapFunction implements a map() transformation over two connected streams.
- combine(JobsOverview) - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
-
Combines the given jobs overview with this.
- combinedWatermark - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- COMBININGSORT - org.apache.flink.runtime.operators.util.LocalStrategy
- CommandLineOptions - Class in org.apache.flink.runtime.entrypoint.parser
-
Container class for command line options.
- CommandLineParser<T> - Class in org.apache.flink.runtime.entrypoint.parser
-
Command line parser which produces a result from the given command line arguments.
- CommandLineParser(ParserResultFactory<T>) - Constructor for class org.apache.flink.runtime.entrypoint.parser.CommandLineParser
- commit() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
Make the change visible to the readers.
- commit(Committer<CommT>) - Method in interface org.apache.flink.streaming.runtime.operators.sink.committables.CheckpointCommittableManager
-
Commits all due committables if all respective committables of the specific subtask and checkpoint have been received.
- commitDate - Variable in class org.apache.flink.runtime.util.EnvironmentInformation.RevisionInformation
-
The git commit date
- commitId - Variable in class org.apache.flink.runtime.util.EnvironmentInformation.RevisionInformation
-
The git commit id (hash)
- CommitRequestImpl<CommT> - Class in org.apache.flink.streaming.runtime.operators.sink.committables
-
Internal implementation to commit a specific committable and handle the response.
- CommitRequestImpl(CommT, int, CommitRequestState, SinkCommitterMetricGroup) - Constructor for class org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
- CommitRequestImpl(CommT, SinkCommitterMetricGroup) - Constructor for class org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
- CommitRequestState - Enum in org.apache.flink.streaming.runtime.operators.sink.committables
-
Internal state of a committable.
- CommittableCollector<CommT> - Class in org.apache.flink.streaming.runtime.operators.sink.committables
-
This class is responsible to book-keep the committing progress across checkpoints and upstream subtasks.
- CommittableCollector(SinkCommitterMetricGroup) - Constructor for class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
- CommittableCollectorSerializer<CommT> - Class in org.apache.flink.streaming.runtime.operators.sink.committables
-
The serializer for the
CommittableCollector. - CommittableCollectorSerializer(SimpleVersionedSerializer<CommT>, int, int, SinkCommitterMetricGroup) - Constructor for class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollectorSerializer
- CommittableMessage<CommT> - Interface in org.apache.flink.streaming.api.connector.sink2
-
The message send from
SinkWritertoCommitter. - CommittableMessageSerializer<CommT> - Class in org.apache.flink.streaming.api.connector.sink2
-
The serializer to serialize
CommittableMessages in custom operators. - CommittableMessageSerializer(SimpleVersionedSerializer<CommT>) - Constructor for class org.apache.flink.streaming.api.connector.sink2.CommittableMessageSerializer
- CommittableMessageTypeInfo<CommT> - Class in org.apache.flink.streaming.api.connector.sink2
-
The type information for the
CommittableMessageto make it consumable from aDataStream. - CommittableSummary<CommT> - Class in org.apache.flink.streaming.api.connector.sink2
-
This class tracks the information about committables belonging to one checkpoint coming from one subtask.
- CommittableSummary(int, int, long, int, int, int) - Constructor for class org.apache.flink.streaming.api.connector.sink2.CommittableSummary
- CommittableWithLineage<CommT> - Class in org.apache.flink.streaming.api.connector.sink2
-
Provides metadata.
- CommittableWithLineage(CommT, long, int) - Constructor for class org.apache.flink.streaming.api.connector.sink2.CommittableWithLineage
- COMMITTED - org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestState
- CommitterOperatorFactory<CommT> - Class in org.apache.flink.streaming.runtime.operators.sink
-
A
StreamOperatorFactoryforCommitterOperator. - CommitterOperatorFactory(SupportsCommitter<CommT>, boolean, boolean) - Constructor for class org.apache.flink.streaming.runtime.operators.sink.CommitterOperatorFactory
- CommonProcessMemorySpec<FM extends FlinkMemory> - Class in org.apache.flink.runtime.util.config.memory
-
Common memory components of Flink processes (e.g.
- CommonProcessMemorySpec(FM, JvmMetaspaceAndOverhead) - Constructor for class org.apache.flink.runtime.util.config.memory.CommonProcessMemorySpec
- compact() - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
-
Removes all metadata about checkpoints of which all committables are fully committed.
- CompactingHashTable<T> - Class in org.apache.flink.runtime.operators.hash
-
A hash table that uses Flink's managed memory and supports replacement of records or updates to records.
- CompactingHashTable(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.hash.CompactingHashTable
- CompactingHashTable(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.operators.hash.CompactingHashTable
- CompactingHashTable.EntryIterator - Class in org.apache.flink.runtime.operators.hash
-
Iterator that traverses the whole hash table once
- CompactingHashTable.HashTableProber<PT> - Class in org.apache.flink.runtime.operators.hash
- ComparableAggregator<T> - Class in org.apache.flink.streaming.api.functions.aggregation
-
An
AggregationFunctionthat computes values based on comparisons ofComparables. - ComparableAggregator(int, TypeInformation<T>, AggregationFunction.AggregationType, boolean, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
- ComparableAggregator(int, TypeInformation<T>, AggregationFunction.AggregationType, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
- ComparableAggregator(String, TypeInformation<T>, AggregationFunction.AggregationType, boolean, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
- Comparator - Class in org.apache.flink.streaming.api.functions.aggregation
-
Internal comparator implementation, for use with
ComparableAggregator. - Comparator() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.Comparator
- compare(int, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
- compare(int, int) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
-
Compare items at the given addresses consistent with the semantics of
Comparator.compare(Object, Object). - compare(int, int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
- compare(int, int, int, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
- compare(int, int, int, int) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
-
Compare records at the given addresses consistent with the semantics of
Comparator.compare(Object, Object). - compare(int, int, int, int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
- compare(String, String) - Method in class org.apache.flink.runtime.rest.RestServerEndpoint.RestHandlerUrlComparator.CaseInsensitiveOrderComparator
- compare(Tuple2<byte[], INPUT>, Tuple2<byte[], INPUT>) - Method in class org.apache.flink.streaming.api.operators.sortpartition.FixedLengthByteKeyAndValueComparator
- compare(Tuple2<byte[], INPUT>, Tuple2<byte[], INPUT>) - Method in class org.apache.flink.streaming.api.operators.sortpartition.VariableLengthByteKeyAndValueComparator
- compare(Tuple2<RestHandlerSpecification, ChannelInboundHandler>, Tuple2<RestHandlerSpecification, ChannelInboundHandler>) - Method in class org.apache.flink.runtime.rest.RestServerEndpoint.RestHandlerUrlComparator
- comparePriority(T, T) - Method in interface org.apache.flink.runtime.state.PriorityComparator
-
Compares two objects for priority.
- comparePriorityTo(SourceCoordinator.WatermarkElement) - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinator.WatermarkElement
- comparePriorityTo(InternalTimer<?, ?>) - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
- comparePriorityTo(T) - Method in interface org.apache.flink.runtime.state.PriorityComparable
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.streaming.api.operators.sortpartition.FixedLengthByteKeyAndValueComparator
- compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.streaming.api.operators.sortpartition.VariableLengthByteKeyAndValueComparator
- compareTo(BlobKey) - Method in class org.apache.flink.runtime.blob.BlobKey
- compareTo(IntegerResourceVersion) - Method in class org.apache.flink.runtime.persistence.IntegerResourceVersion
- compareTo(StringResourceVersion) - Method in class org.apache.flink.runtime.persistence.StringResourceVersion
- compareTo(SequenceNumber) - Method in class org.apache.flink.runtime.state.changelog.SequenceNumber.GenericSequenceNumber
- compareTo(TaskManagerLocation) - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
- compareTo(TimestampedInputSplit) - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
- compareTo(WindowOperator.Timer<K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
- compareToReference(TypeComparator<Tuple2<byte[], INPUT>>) - Method in class org.apache.flink.streaming.api.operators.sortpartition.FixedLengthByteKeyAndValueComparator
- compareToReference(TypeComparator<Tuple2<byte[], INPUT>>) - Method in class org.apache.flink.streaming.api.operators.sortpartition.VariableLengthByteKeyAndValueComparator
- complete() - Static method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationInfo
- complete() - Method in class org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
- COMPLETE - org.apache.flink.runtime.taskmanager.Task.NotifyCheckpointOperation
- completeAllocation() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerSlot
- completed() - Static method in class org.apache.flink.runtime.rest.messages.queue.QueueStatus
- completed(V) - Static method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationResult
- COMPLETED - org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
-
Checkpoint that has successfully completed.
- COMPLETED - org.apache.flink.runtime.checkpoint.InitializationStatus
- COMPLETED - org.apache.flink.runtime.rest.messages.queue.QueueStatus.Id
- CompletedCheckpoint - Class in org.apache.flink.runtime.checkpoint
-
A CompletedCheckpoint describes a checkpoint after all required tasks acknowledged it (with their state) and that is considered successful.
- CompletedCheckpoint(JobID, long, long, long, Map<OperatorID, OperatorState>, Collection<MasterState>, CheckpointProperties, CompletedCheckpointStorageLocation, CompletedCheckpointStats) - Constructor for class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
- CompletedCheckpoint(JobID, long, long, long, Map<OperatorID, OperatorState>, Collection<MasterState>, CheckpointProperties, CompletedCheckpointStorageLocation, CompletedCheckpointStats, CheckpointProperties) - Constructor for class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
- CompletedCheckpoint.CompletedCheckpointDiscardObject - Class in org.apache.flink.runtime.checkpoint
-
Implementation of
Checkpoint.DiscardObject. - CompletedCheckpointDiscardObject() - Constructor for class org.apache.flink.runtime.checkpoint.CompletedCheckpoint.CompletedCheckpointDiscardObject
- CompletedCheckpointStatistics(long, CheckpointStatsStatus, boolean, String, long, long, long, long, long, long, long, long, int, int, CheckpointStatistics.RestAPICheckpointType, Map<JobVertexID, TaskCheckpointStatistics>, String, boolean) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.CompletedCheckpointStatistics
- CompletedCheckpointStats - Class in org.apache.flink.runtime.checkpoint
-
Statistics for a successfully completed checkpoint.
- CompletedCheckpointStatsSummary - Class in org.apache.flink.runtime.checkpoint
-
Summary over all completed checkpoints.
- CompletedCheckpointStatsSummarySnapshot - Class in org.apache.flink.runtime.checkpoint
-
Immutable snapshot of
CompletedCheckpointStatsSummary. - CompletedCheckpointStatsSummarySnapshot(StatsSummarySnapshot, StatsSummarySnapshot, StatsSummarySnapshot, StatsSummarySnapshot, StatsSummarySnapshot) - Constructor for class org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummarySnapshot
- CompletedCheckpointStorageLocation - Interface in org.apache.flink.runtime.state
-
The CompletedCheckpointStorageLocation describes the storage aspect of a completed checkpoint.
- CompletedCheckpointStore - Interface in org.apache.flink.runtime.checkpoint
-
A bounded LIFO-queue of
CompletedCheckpointinstances. - completeDeploymentOf(ExecutionAttemptID) - Method in class org.apache.flink.runtime.jobmaster.DefaultExecutionDeploymentTracker
- completeDeploymentOf(ExecutionAttemptID) - Method in interface org.apache.flink.runtime.jobmaster.ExecutionDeploymentTracker
-
Marks the deployment of the given execution as complete.
- CompletedOperationCache<K extends OperationKey,R extends Serializable> - Class in org.apache.flink.runtime.rest.handler.async
-
Cache to manage ongoing operations.
- CompletedOperationCache(Duration) - Constructor for class org.apache.flink.runtime.rest.handler.async.CompletedOperationCache
- CompletedSubtaskCheckpointStatistics(int, long, long, long, long, SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration, SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment, long, boolean, boolean) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
- completeExceptional(SerializedThrowable) - Static method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationInfo
- completeOneRecord(EpochManager.Epoch) - Method in class org.apache.flink.runtime.asyncprocessing.EpochManager
-
Complete one record in the specific epoch.
- completePromiseAndDiscard() - Method in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator.PendingStatsRequest
- completeSnapshotAndGetHandle() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
-
Calling this method completes the snapshot for this snapshot directory, if possible, and creates a corresponding
DirectoryStateHandlethat points to the snapshot directory. - CompleteStateIterator<T> - Class in org.apache.flink.runtime.state.v2.adaptor
-
A
StateIteratorthat has all elements. - ComponentClosingUtils - Class in org.apache.flink.runtime.operators.coordination
-
A util class to help with a clean component shutdown.
- componentMainThreadExecutor - Variable in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolService
- ComponentMetricGroup<P extends AbstractMetricGroup<?>> - Class in org.apache.flink.runtime.metrics.groups
-
Abstract
MetricGroupfor system components (e.g., TaskManager, Job, Task, Operator). - ComponentMetricGroup(MetricRegistry, String[], P) - Constructor for class org.apache.flink.runtime.metrics.groups.ComponentMetricGroup
-
Creates a new ComponentMetricGroup.
- CompositeBuffer - Class in org.apache.flink.runtime.io.network.buffer
-
An implementation of
Bufferwhich contains multiple partial buffers for network data communication. - CompositeBuffer(Buffer.DataType, int, boolean) - Constructor for class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- CompositeBuffer(BufferHeader) - Constructor for class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- compositeHeapBuffer() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
- compositeHeapBuffer(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
- CompositeKeySerializationUtils - Class in org.apache.flink.runtime.state
-
Utils for RocksDB state serialization and deserialization.
- CompositeKeySerializationUtils() - Constructor for class org.apache.flink.runtime.state.CompositeKeySerializationUtils
- CompositeStateHandle - Interface in org.apache.flink.runtime.state
-
Base of all snapshots that are taken by
StateBackends and some other components in tasks. - compress(byte[], int, int, byte[], int) - Method in class org.apache.flink.runtime.io.compression.AirBlockCompressor
- compress(byte[], int, int, byte[], int) - Method in interface org.apache.flink.runtime.io.compression.BlockCompressor
-
Compress data read from src, and write the compressed data to dst.
- compress(byte[], int, int, byte[], int) - Method in class org.apache.flink.runtime.io.compression.Lz4BlockCompressor
- compress(ByteBuffer, int, int, ByteBuffer, int) - Method in class org.apache.flink.runtime.io.compression.AirBlockCompressor
- compress(ByteBuffer, int, int, ByteBuffer, int) - Method in interface org.apache.flink.runtime.io.compression.BlockCompressor
-
Compress source data read from (
Buffer.position()+srcOff), and write the compressed data to dst. - compress(ByteBuffer, int, int, ByteBuffer, int) - Method in class org.apache.flink.runtime.io.compression.Lz4BlockCompressor
- compressBufferIfPossible(Buffer, BufferCompressor) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageUtils
-
Try compress buffer if possible.
- CompressibleFSDataInputStream - Class in org.apache.flink.runtime.state
-
FSDataInputStreamthat delegates all reading operations to a wrappingStreamCompressionDecorator. - CompressibleFSDataInputStream(FSDataInputStream, StreamCompressionDecorator) - Constructor for class org.apache.flink.runtime.state.CompressibleFSDataInputStream
- CompressibleFSDataOutputStream - Class in org.apache.flink.runtime.state
-
FSDataOutputStreamthat delegates all writing operations to a wrappingStreamCompressionDecorator. - CompressibleFSDataOutputStream(FSDataOutputStream, StreamCompressionDecorator) - Constructor for class org.apache.flink.runtime.state.CompressibleFSDataOutputStream
- CompressorUtils - Class in org.apache.flink.runtime.io.compression
-
Utils for
BlockCompressor. - CompressorUtils() - Constructor for class org.apache.flink.runtime.io.compression.CompressorUtils
- compressToIntermediateBuffer(Buffer) - Method in class org.apache.flink.runtime.io.network.buffer.BufferCompressor
-
Compresses the given
BufferusingBlockCompressor. - compressToOriginalBuffer(Buffer) - Method in class org.apache.flink.runtime.io.network.buffer.BufferCompressor
-
The difference between this method and
BufferCompressor.compressToIntermediateBuffer(Buffer)is that this method will copy the compressed data back to the inputBufferstarting from offset 0. - compute(Object, BiFunction<Object, Object, Object>) - Method in interface org.apache.flink.runtime.operators.coordination.CoordinatorStore
- compute(Object, BiFunction<Object, Object, Object>) - Method in class org.apache.flink.runtime.operators.coordination.CoordinatorStoreImpl
- computeDefaultMaxParallelism(int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
-
Computes a default maximum parallelism from the operator parallelism.
- computeDynamicSourceParallelism() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.AdaptiveBatchScheduler
- computeForwardGroups(Iterable<JobVertex>, Function<JobVertex, Set<JobVertex>>) - Static method in class org.apache.flink.runtime.jobgraph.forwardgroup.ForwardGroupComputeUtil
- computeForwardGroupsAndCheckParallelism(Iterable<JobVertex>) - Static method in class org.apache.flink.runtime.jobgraph.forwardgroup.ForwardGroupComputeUtil
- computeIfPresent(Object, BiFunction<Object, Object, Object>) - Method in interface org.apache.flink.runtime.operators.coordination.CoordinatorStore
- computeIfPresent(Object, BiFunction<Object, Object, Object>) - Method in class org.apache.flink.runtime.operators.coordination.CoordinatorStoreImpl
- computeKeyGroupForKeyHash(int, int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
-
Assigns the given key to a key-group index.
- computeKeyGroupRangeForOperatorIndex(int, int, int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
-
Computes the range of key-groups that are assigned to a given operator under the given parallelism and maximum parallelism.
- computeMaxEdgesToTargetExecutionVertex(int, int, DistributionPattern) - Static method in class org.apache.flink.runtime.executiongraph.EdgeManagerBuildUtil
-
Given parallelisms of two job vertices, compute the max number of edges connected to a target execution vertex from the source execution vertices.
- computeMemorySize(double) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Computes the memory size corresponding to the fraction of all memory governed by this MemoryManager.
- computeNetworkBuffersForAnnouncing(int, int, Optional<Integer>, int, int, Map<IntermediateDataSetID, Integer>, Map<IntermediateDataSetID, Integer>, Map<IntermediateDataSetID, Integer>, Map<IntermediateDataSetID, ResultPartitionType>, Map<IntermediateDataSetID, ResultPartitionType>) - Static method in class org.apache.flink.runtime.shuffle.NettyShuffleUtils
- computeNumberOfPages(double) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Computes to how many pages the given number of bytes corresponds.
- computeOperatorIndexForKeyGroup(int, int, int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
-
Computes the index of the operator to which a key-group belongs under the given parallelism and maximum parallelism.
- computePipelinedRegions(Iterable<? extends LogicalVertex>) - Static method in class org.apache.flink.runtime.executiongraph.failover.LogicalPipelinedRegionComputeUtil
- computePipelinedRegions(Iterable<? extends SchedulingExecutionVertex>, Function<ExecutionVertexID, ? extends SchedulingExecutionVertex>, Function<IntermediateResultPartitionID, ? extends SchedulingResultPartition>) - Static method in class org.apache.flink.runtime.executiongraph.failover.SchedulingPipelinedRegionComputeUtil
- computeRequiredBytesInKeyGroupPrefix(int) - Static method in class org.apache.flink.runtime.state.CompositeKeySerializationUtils
- computeShuffleMemorySizeForTask(TaskInputsOutputsDescriptor) - Method in class org.apache.flink.runtime.shuffle.NettyShuffleMaster
-
JM announces network memory requirement from the calculating result of this method.
- computeShuffleMemorySizeForTask(TaskInputsOutputsDescriptor) - Method in interface org.apache.flink.runtime.shuffle.ShuffleMaster
-
Compute shuffle memory size for a task with the given
TaskInputsOutputsDescriptor. - computeSourceParallelismUpperBound(JobVertexID, int) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DefaultVertexParallelismAndInputInfosDecider
- computeSourceParallelismUpperBound(JobVertexID, int) - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.VertexParallelismAndInputInfosDecider
-
Compute source parallelism upper bound for the source vertex.
- computeVertexInputInfos(int, List<? extends IntermediateResultInfo>, boolean) - Static method in class org.apache.flink.runtime.executiongraph.VertexInputInfoComputationUtils
- computeVertexInputInfos(ExecutionJobVertex, Function<IntermediateDataSetID, IntermediateResult>) - Static method in class org.apache.flink.runtime.executiongraph.VertexInputInfoComputationUtils
- computeVertexParallelismStore(Iterable<JobVertex>) - Static method in class org.apache.flink.runtime.scheduler.SchedulerBase
-
Compute the
VertexParallelismStorefor all given vertices, which will set defaults and ensure that the returned store contains valid parallelisms. - computeVertexParallelismStore(Iterable<JobVertex>, Function<JobVertex, Integer>) - Static method in class org.apache.flink.runtime.scheduler.SchedulerBase
- computeVertexParallelismStore(Iterable<JobVertex>, Function<JobVertex, Integer>, Function<Integer, Integer>) - Static method in class org.apache.flink.runtime.scheduler.SchedulerBase
-
Compute the
VertexParallelismStorefor all given vertices, which will set defaults and ensure that the returned store contains valid parallelisms, with a custom function for default max parallelism calculation and a custom function for normalizing vertex parallelism. - computeVertexParallelismStore(JobGraph) - Static method in class org.apache.flink.runtime.scheduler.SchedulerBase
-
Compute the
VertexParallelismStorefor all vertices of a given job graph, which will set defaults and ensure that the returned store contains valid parallelisms. - computeVertexParallelismStoreForDynamicGraph(Iterable<JobVertex>, int) - Static method in class org.apache.flink.runtime.scheduler.adaptivebatch.AdaptiveBatchScheduler
-
Compute the
VertexParallelismStorefor all given vertices in a dynamic graph, which will set defaults and ensure that the returned store contains valid parallelisms, with the configured default max parallelism. - concat(CharacterFilter, Character, String...) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
Concatenates the given component names separated by the delimiter character.
- concatScopes(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
- config - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The task configuration with the setup parameters.
- config - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
- config - Variable in class org.apache.flink.runtime.operators.util.TaskConfig
- config - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
The execution configuration for this environment.
- config - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- config - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- CONFIG_DIR_OPTION - Static variable in class org.apache.flink.runtime.entrypoint.parser.CommandLineOptions
- ConfigurableCheckpointStorage - Interface in org.apache.flink.runtime.state
-
An interface for checkpoint storage types that pick up additional parameters from a configuration.
- ConfigurableStateBackend - Interface in org.apache.flink.runtime.state
-
An interface for state backends that pick up additional parameters from a configuration.
- ConfigurableStreamPartitioner - Interface in org.apache.flink.streaming.runtime.partitioner
-
Interface for
StreamPartitionerwhich have to be configured with the maximum parallelism of the stream transformation. - configuration - Variable in class org.apache.flink.runtime.highavailability.AbstractHaServices
-
The runtime configuration.
- configuration - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Currently, configuration is split across multiple member variables and classes such as
ExecutionConfigorCheckpointConfig. - configuration - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
The configuration of this streaming task.
- ConfigurationCommandLineOptions - Class in org.apache.flink.runtime.entrypoint.parser
-
Represents the set of command-line options related to update and get configuration.
- ConfigurationCommandLineOptions() - Constructor for class org.apache.flink.runtime.entrypoint.parser.ConfigurationCommandLineOptions
- ConfigurationInfo - Class in org.apache.flink.runtime.rest.messages
-
Response of the
ClusterConfigHandler, represented as a list of key-value pairs of the clusterConfiguration. - ConfigurationInfo() - Constructor for class org.apache.flink.runtime.rest.messages.ConfigurationInfo
- ConfigurationInfo(int) - Constructor for class org.apache.flink.runtime.rest.messages.ConfigurationInfo
- ConfigurationInfoEntry - Class in org.apache.flink.runtime.rest.messages
-
A single key-value pair entry in the
ConfigurationInforesponse. - ConfigurationInfoEntry(String, String) - Constructor for class org.apache.flink.runtime.rest.messages.ConfigurationInfoEntry
- ConfigurationNotAllowedMessage - Class in org.apache.flink.runtime.dispatcher
-
If
DeploymentOptions.PROGRAM_CONFIG_ENABLEDis disabled, this error denotes the not allowed configuration. - ConfigurationParserUtils - Class in org.apache.flink.runtime.util
-
Utility class to extract related parameters from
Configurationand to sanity check them. - ConfigurationParserUtils() - Constructor for class org.apache.flink.runtime.util.ConfigurationParserUtils
- configure(int) - Method in interface org.apache.flink.streaming.runtime.partitioner.ConfigurableStreamPartitioner
-
Configure the
StreamPartitionerwith the maximum parallelism of the down stream operator. - configure(int) - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
- configure(ReadableConfig) - Method in class org.apache.flink.runtime.state.metrics.LatencyTrackingStateConfig.Builder
- configure(ReadableConfig) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets all relevant options contained in the
ReadableConfigsuch as e.g. - configure(ReadableConfig) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets all relevant options contained in the
ReadableConfig. - configure(ReadableConfig, ClassLoader) - Method in interface org.apache.flink.runtime.state.ConfigurableCheckpointStorage
-
Creates a variant of the checkpoint storage that applies additional configuration parameters.
- configure(ReadableConfig, ClassLoader) - Method in interface org.apache.flink.runtime.state.ConfigurableStateBackend
-
Creates a variant of the state backend that applies additional configuration parameters.
- configure(ReadableConfig, ClassLoader) - Method in class org.apache.flink.runtime.state.hashmap.HashMapStateBackend
- configure(ReadableConfig, ClassLoader) - Method in class org.apache.flink.runtime.state.storage.FileSystemCheckpointStorage
- configure(ReadableConfig, ClassLoader) - Method in class org.apache.flink.runtime.state.storage.JobManagerCheckpointStorage
-
Creates a copy of this checkpoint storage that uses the values defined in the configuration for fields where that were not specified in this checkpoint storage.
- configure(ReadableConfig, ClassLoader) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets all relevant options contained in the
ReadableConfig. - configureBufferTimeout(StreamGraph, int, Transformation<T>, long) - Static method in class org.apache.flink.streaming.util.graph.StreamGraphUtils
-
Configure a stream node's buffer timeout according to the given transformation.
- CONFIGURED - org.apache.flink.runtime.minicluster.MiniCluster.HaServices
-
Uses the configured HA Services in
HighAvailabilityOptions.HA_MODEoption. - configuredNetworkBuffersPerChannel - Variable in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGateFactory
- configureUncaughtExceptionHandler(Configuration) - Static method in class org.apache.flink.runtime.entrypoint.ClusterEntrypointUtils
-
Sets the uncaught exception handler for current thread based on configuration.
- confirm(SequenceNumber, SequenceNumber, long) - Method in interface org.apache.flink.runtime.state.changelog.StateChangelogWriter
-
Mark the given state changes as confirmed by the JM.
- confirmCheckpoint(long) - Method in class org.apache.flink.runtime.state.NoOpTaskLocalStateStoreImpl
- confirmCheckpoint(long) - Method in interface org.apache.flink.runtime.state.TaskLocalStateStore
-
Notifies that the checkpoint with the given id was confirmed as complete.
- confirmCheckpoint(long) - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
- confirmCheckpoint(ExecutionAttemptID, long, long, long) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- confirmCheckpoint(ExecutionAttemptID, long, long, long) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Confirm a checkpoint for the given task.
- confirmCheckpoint(ExecutionAttemptID, long, long, long) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- confirmLeadership(String, UUID, String) - Method in class org.apache.flink.runtime.leaderelection.DefaultLeaderElectionService
- confirmLeadership(UUID, String) - Method in interface org.apache.flink.runtime.leaderelection.LeaderElection
-
Confirms that the
LeaderContenderhas accepted the leadership identified by the given leader session id. - confirmLeadership(UUID, String) - Method in class org.apache.flink.runtime.leaderelection.StandaloneLeaderElection
- connect(ResourceID, JobMasterGateway, TaskManagerActions, CheckpointResponder, GlobalAggregateManager, PartitionProducerStateChecker) - Method in interface org.apache.flink.runtime.taskexecutor.JobTable.Job
-
Connects the job to a JobManager and associates the provided services with this connection.
- connect(DeclareResourceRequirementServiceConnectionManager.DeclareResourceRequirementsService) - Method in enum org.apache.flink.runtime.jobmaster.slotpool.NoOpDeclareResourceRequirementServiceConnectionManager
- connect(BroadcastStream<R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Creates a new
BroadcastConnectedStreamby connecting the currentDataStreamorKeyedStreamwith aBroadcastStream. - connect(DataStream<R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Creates a new
ConnectedStreamsby connectingDataStreamoutputs of (possible) different types with each other. - connect(S) - Method in interface org.apache.flink.runtime.jobmaster.ServiceConnectionManager
-
Connect to the given service.
- connect(S) - Method in class org.apache.flink.runtime.jobmaster.slotpool.AbstractServiceConnectionManager
- ConnectedStreams<IN1,IN2> - Class in org.apache.flink.streaming.api.datastream
-
ConnectedStreams represent two connected streams of (possibly) different data types.
- ConnectedStreams(StreamExecutionEnvironment, DataStream<IN1>, DataStream<IN2>) - Constructor for class org.apache.flink.streaming.api.datastream.ConnectedStreams
- connectionBroken(NettyConnectionId) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyServiceProducer
-
NettyConnectionWriterrelated to a connection id will be notified when the netty connection is broken. - connectionBroken(NettyConnectionId) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskIOScheduler
- connectionBroken(NettyConnectionId) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskTierProducerAgent
- connectionBroken(NettyConnectionId) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory.MemoryTierProducerAgent
- ConnectionClosedException - Exception in org.apache.flink.runtime.rest
-
Exception which is thrown if the
RestClientdetects that a connection was closed. - ConnectionClosedException(String) - Constructor for exception org.apache.flink.runtime.rest.ConnectionClosedException
- ConnectionClosedException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rest.ConnectionClosedException
- ConnectionClosedException(Throwable) - Constructor for exception org.apache.flink.runtime.rest.ConnectionClosedException
- ConnectionErrorMessage - Class in org.apache.flink.runtime.io.network.netty
-
Message for indicating connection error.
- ConnectionErrorMessage(Throwable) - Constructor for class org.apache.flink.runtime.io.network.netty.ConnectionErrorMessage
- connectionEstablished(TieredStorageSubpartitionId, NettyConnectionWriter) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyServiceProducer
-
NettyConnectionWriterwill be created when a netty connection is established for a subpartition. - connectionEstablished(TieredStorageSubpartitionId, NettyConnectionWriter) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskIOScheduler
- connectionEstablished(TieredStorageSubpartitionId, NettyConnectionWriter) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskTierProducerAgent
- connectionEstablished(TieredStorageSubpartitionId, NettyConnectionWriter) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory.MemoryTierProducerAgent
- ConnectionException - Exception in org.apache.flink.runtime.rest
-
Base class for all connection related exception thrown by the
RestClient. - ConnectionException(String) - Constructor for exception org.apache.flink.runtime.rest.ConnectionException
- ConnectionException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rest.ConnectionException
- ConnectionException(Throwable) - Constructor for exception org.apache.flink.runtime.rest.ConnectionException
- ConnectionID - Class in org.apache.flink.runtime.io.network
-
A
ConnectionIDidentifies a connection to a remote task manager by the socket address and a connection index. - ConnectionID(ResourceID, InetSocketAddress, int) - Constructor for class org.apache.flink.runtime.io.network.ConnectionID
- ConnectionID(TaskManagerLocation, int) - Constructor for class org.apache.flink.runtime.io.network.ConnectionID
- ConnectionIdleException - Exception in org.apache.flink.runtime.rest
-
Exception which is thrown by the
RestClientif a connection becomes idle. - ConnectionIdleException(String) - Constructor for exception org.apache.flink.runtime.rest.ConnectionIdleException
- ConnectionIdleException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rest.ConnectionIdleException
- ConnectionIdleException(Throwable) - Constructor for exception org.apache.flink.runtime.rest.ConnectionIdleException
- connectionManager - Variable in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGateFactory
- ConnectionManager - Interface in org.apache.flink.runtime.io.network
-
The connection manager manages physical connections for the (logical) remote input channels at runtime.
- ConnectionUtils - Class in org.apache.flink.runtime.net
-
Utilities to determine the network interface and address that should be used to bind the TaskManager communication to.
- ConnectionUtils() - Constructor for class org.apache.flink.runtime.net.ConnectionUtils
- ConnectionUtils.LeaderConnectingAddressListener - Class in org.apache.flink.runtime.net
-
A
LeaderRetrievalListenerthat allows retrieving anInetAddressfor the current leader. - connectNewDataSetAsInput(JobVertex, DistributionPattern, ResultPartitionType) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- connectNewDataSetAsInput(JobVertex, DistributionPattern, ResultPartitionType, boolean) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- connectNewDataSetAsInput(JobVertex, DistributionPattern, ResultPartitionType, IntermediateDataSetID, boolean) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- connectPartitionWithConsumerVertexGroup(IntermediateResultPartitionID, ConsumerVertexGroup) - Method in class org.apache.flink.runtime.executiongraph.EdgeManager
- connectToPredecessors(Map<IntermediateDataSetID, IntermediateResult>) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- connectToResourceManager(ResourceManagerGateway) - Method in interface org.apache.flink.runtime.io.network.partition.JobMasterPartitionTracker
- connectToResourceManager(ResourceManagerGateway) - Method in class org.apache.flink.runtime.io.network.partition.JobMasterPartitionTrackerImpl
- connectToResourceManager(ResourceManagerGateway) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolService
- connectToResourceManager(ResourceManagerGateway) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Connects the SlotPool to the given ResourceManager.
- connectToResourceManager(ResourceManagerGateway) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolService
-
Connects the SlotPool to the given ResourceManager.
- connectVertexWithConsumedPartitionGroup(ExecutionVertexID, ConsumedPartitionGroup) - Method in class org.apache.flink.runtime.executiongraph.EdgeManager
- CONSERVATIVE_PAGE_SIZE_MULTIPLE - Static variable in class org.apache.flink.runtime.io.network.partition.PageSizeUtil
-
A conservative fallback value (64 KiBytes) that should be a multiple of the page size even in some uncommon cases of servers installations with larger-than-usual page sizes.
- constructLogString(String, String, AbstractInvokable) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Utility function that composes a string for logging purposes.
- consume(T, int) - Method in interface org.apache.flink.runtime.state.KeyGroupPartitioner.KeyGroupElementsConsumer
- consumeAndCacheRemainingData() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
- ConsumedPartitionGroup - Class in org.apache.flink.runtime.scheduler.strategy
-
Group of consumed
IntermediateResultPartitionIDs. - consumedSubpartitionIndexSet - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
The indexes of the subpartitions consumed by this channel.
- ConsumerRegionGroupExecutionView - Class in org.apache.flink.runtime.executiongraph.failover.partitionrelease
-
This view maintains the finished progress of consumer
SchedulingPipelinedRegions for eachConsumedPartitionGroup. - ConsumerRegionGroupExecutionView() - Constructor for class org.apache.flink.runtime.executiongraph.failover.partitionrelease.ConsumerRegionGroupExecutionView
- ConsumerVertexGroup - Class in org.apache.flink.runtime.scheduler.strategy
-
Group of consumer
ExecutionVertexIDs. - containBuffer(int) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.index.FileDataIndexRegionHelper.Region
-
Whether the current region contain the buffer.
- containBuffer(int) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.ProducerMergedPartitionFileIndex.FixedSizeRegion
- ContaineredTaskManagerParameters - Class in org.apache.flink.runtime.clusterframework
-
This class describes the basic parameters for launching a TaskManager process.
- ContaineredTaskManagerParameters(TaskExecutorProcessSpec, HashMap<String, String>) - Constructor for class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
- ContainingTaskDetails - Interface in org.apache.flink.streaming.runtime.tasks
-
Details about the operator containing task (such as
StreamTask). - contains(int) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartitionIndexSet
- contains(int) - Method in class org.apache.flink.runtime.state.KeyGroupRange
-
Checks whether or not a single key-group is contained in the range.
- contains(int) - Method in interface org.apache.flink.runtime.state.KeyGroupsList
-
Returns true, if the given key group id is contained in the list, otherwise false.
- contains(Object) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- contains(K) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
- contains(JobVertexID) - Method in class org.apache.flink.runtime.jobgraph.topology.DefaultLogicalPipelinedRegion
- contains(ExecutionVertexID) - Method in class org.apache.flink.runtime.scheduler.adapter.DefaultSchedulingPipelinedRegion
- contains(SequenceNumber) - Method in interface org.apache.flink.runtime.state.changelog.SequenceNumberRange
- contains(SequenceNumber) - Method in class org.apache.flink.runtime.state.changelog.SequenceNumberRange.GenericSequenceNumberRange
- contains(T) - Method in class org.apache.flink.runtime.io.network.partition.PrioritizedDeque
-
Returns whether the given element is contained in this list.
- contains(UK) - Method in class org.apache.flink.runtime.state.v2.AbstractMapState
- contains(UK) - Method in class org.apache.flink.runtime.state.v2.adaptor.MapStateAdaptor
- contains(VID) - Method in interface org.apache.flink.runtime.topology.PipelinedRegion
-
Returns whether the vertex is in this pipelined region or not.
- containsAll(Collection<?>) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- containsFreeSlot(AllocationID) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotPool
-
Checks whether the slot pool contains a slot with the given
AllocationIDand if it is free. - containsFreeSlot(AllocationID) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPool
-
Checks whether the slot pool contains a slot with the given
AllocationIDand if it is free. - containsFreeSlot(AllocationID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultAllocatedSlotPool
- containsFreeSlot(AllocationID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultDeclarativeSlotPool
- containsJob(JobID) - Method in class org.apache.flink.runtime.resourcemanager.DefaultJobLeaderIdService
- containsJob(JobID) - Method in interface org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
Check whether the given job is being monitored or not.
- containsJob(JobID) - Method in class org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService
-
Check whether the service monitors the given job.
- containsJob(JobID) - Method in interface org.apache.flink.runtime.taskexecutor.JobLeaderService
-
Check whether the service monitors the given job.
- containsKey(Object) - Method in interface org.apache.flink.runtime.operators.coordination.CoordinatorStore
- containsKey(Object) - Method in class org.apache.flink.runtime.operators.coordination.CoordinatorStoreImpl
- containsKey(K, N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
- containsKey(K, N) - Method in class org.apache.flink.runtime.state.heap.StateMap
-
Returns whether this map contains the specified key/namespace composite key.
- containsKey(N) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Returns whether this table contains a mapping for the composite of active key and given namespace.
- containsKeyA(A) - Method in class org.apache.flink.runtime.util.DualKeyLinkedMap
- containsKeyB(B) - Method in class org.apache.flink.runtime.util.DualKeyLinkedMap
- containsOperation(K) - Method in class org.apache.flink.runtime.rest.handler.async.CompletedOperationCache
-
Returns whether this cache contains an operation under the given operation key.
- containsPriorityElement(T) - Method in class org.apache.flink.runtime.io.network.partition.PrioritizedDeque
-
Returns whether the given element is a known priority element.
- containsResource(ResourceProfile) - Method in class org.apache.flink.runtime.util.ResourceCounter
-
Checks whether resourceProfile is contained in this counter.
- containsSlot(AllocationID) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotPool
-
Checks whether the slot pool contains a slot with the given allocationId.
- containsSlot(AllocationID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultAllocatedSlotPool
- containsSlots(ResourceID) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotPool
-
Checks whether the slot pool contains at least one slot belonging to the specified owner.
- containsSlots(ResourceID) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPool
-
Returns whether the slot pool has a slot registered which is owned by the given TaskExecutor.
- containsSlots(ResourceID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultAllocatedSlotPool
- containsSlots(ResourceID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultDeclarativeSlotPool
- CONTENT_TYPE_BINARY - Static variable in enum org.apache.flink.runtime.rest.util.RestConstants
- CONTENT_TYPE_JAR - Static variable in enum org.apache.flink.runtime.rest.util.RestConstants
- CONTENTS - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
- Context() - Constructor for class org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction.Context
- Context() - Constructor for class org.apache.flink.streaming.api.functions.co.BroadcastProcessFunction.Context
- Context() - Constructor for class org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context
- Context() - Constructor for class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.Context
- Context() - Constructor for class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.Context
- Context() - Constructor for class org.apache.flink.streaming.api.functions.co.ProcessJoinFunction.Context
- Context() - Constructor for class org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
- Context() - Constructor for class org.apache.flink.streaming.api.functions.ProcessFunction.Context
- Context() - Constructor for class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
- Context() - Constructor for class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
- Context(K, W) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
- ContextStateFutureImpl<T> - Class in org.apache.flink.runtime.asyncprocessing
-
A state future that holds the
RecordContextand maintains the reference count of it. - CONTINUE - org.apache.flink.streaming.api.windowing.triggers.TriggerResult
-
No action is taken on the window.
- ContinuousFileMonitoringFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source.legacy
-
Deprecated.This class is based on the
SourceFunctionAPI, which is due to be removed. Use the newSourceAPI instead. - ContinuousFileMonitoringFunction(FileInputFormat<OUT>, FileProcessingMode, int, long) - Constructor for class org.apache.flink.streaming.api.functions.source.legacy.ContinuousFileMonitoringFunction
-
Deprecated.
- ContinuousFileReaderOperator<OUT,T extends TimestampedInputSplit> - Class in org.apache.flink.streaming.api.functions.source
-
The operator that reads the
splitsreceived from the precedingContinuousFileMonitoringFunction. - ContinuousFileReaderOperatorFactory<OUT,T extends TimestampedInputSplit> - Class in org.apache.flink.streaming.api.functions.source
-
ContinuousFileReaderOperatorfactory. - ContinuousFileReaderOperatorFactory(InputFormat<OUT, ? super T>) - Constructor for class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
- ContinuousFileReaderOperatorFactory(InputFormat<OUT, ? super T>, TypeInformation<OUT>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
- continuousReadSuggested() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.PartitionFileReader.ReadBufferResult
- ConversionException - Exception in org.apache.flink.runtime.rest.messages
-
Exception which is thrown if an input cannot be converted into the requested type.
- ConversionException(String) - Constructor for exception org.apache.flink.runtime.rest.messages.ConversionException
- ConversionException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rest.messages.ConversionException
- ConversionException(Throwable) - Constructor for exception org.apache.flink.runtime.rest.messages.ConversionException
- convertFromCheckpointingMode(CheckpointingMode) - Static method in enum org.apache.flink.streaming.api.CheckpointingMode
-
Deprecated.
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointIdPathParameter
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetIdPathParameter
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.job.FailureLabelFilterParameter
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskAttemptPathParameter
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.JobIDPathParameter
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.JobVertexIdPathParameter
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.LogFileNamePathParameter
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Converts the given string to a valid value of this parameter.
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.MessageQueryParameter
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.OperatorUidPathParameter
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.ProfilingFileNamePathParameter
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.SubtaskIndexPathParameter
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerIdPathParameter
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.TriggerIdPathParameter
- convertId(int) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageIdMappingUtils
- convertId(TieredStoragePartitionId) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageIdMappingUtils
- convertId(TieredStorageSubpartitionId) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageIdMappingUtils
- convertId(TieredStorageTopicId) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageIdMappingUtils
- convertId(ResultPartitionID) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageIdMappingUtils
- convertId(IntermediateDataSetID) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageIdMappingUtils
- convertRecoveredInputChannels() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.AccumulatorsIncludeSerializedValueQueryParameter
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.FlameGraphTypeQueryParameter
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.job.FailureLabelFilterParameter
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobsFilterQueryParameter
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricsFilterParameter
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtasksFilterQueryParameter
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagersFilterQueryParameter
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.job.UpperLimitExceptionParameter
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.MessageQueryParameter
-
Converts the given string to a valid value of this parameter.
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.RescalingParallelismQueryParameter
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.SubtaskIndexQueryParameter
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter
- convertToCheckpointingMode(CheckpointingMode) - Static method in enum org.apache.flink.streaming.api.CheckpointingMode
-
Deprecated.
- convertToFractionOfSlot(ManagedMemoryUseCase, double, Set<ManagedMemoryUseCase>, Configuration, Configuration, Optional<Boolean>, ClassLoader) - Static method in enum org.apache.flink.runtime.util.config.memory.ManagedMemoryUtils
- convertToLineageGraph(List<Transformation<?>>) - Static method in class org.apache.flink.streaming.api.lineage.LineageGraphUtils
-
Convert transforms to LineageGraph.
- convertToPriorityEvent(int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
- convertToPriorityEvent(int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- convertToPriorityEvent(int, int) - Method in interface org.apache.flink.runtime.io.network.partition.consumer.CheckpointableInput
- convertToPriorityEvent(int, int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate
- convertToPriorityEvent(int, int) - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
- convertToString(Integer) - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskAttemptPathParameter
- convertToString(Integer) - Method in class org.apache.flink.runtime.rest.messages.SubtaskIndexPathParameter
- convertToString(Long) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointIdPathParameter
- convertToString(String) - Method in class org.apache.flink.runtime.rest.messages.LogFileNamePathParameter
- convertToString(String) - Method in class org.apache.flink.runtime.rest.messages.OperatorUidPathParameter
- convertToString(String) - Method in class org.apache.flink.runtime.rest.messages.ProfilingFileNamePathParameter
- convertToString(List<X>) - Method in class org.apache.flink.runtime.rest.messages.MessageQueryParameter
- convertToString(UUID, String) - Static method in class org.apache.flink.runtime.leaderelection.LeaderElectionUtils
- convertToString(JobID) - Method in class org.apache.flink.runtime.rest.messages.JobIDPathParameter
- convertToString(ResourceID) - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerIdPathParameter
- convertToString(IntermediateDataSetID) - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetIdPathParameter
- convertToString(JobVertexID) - Method in class org.apache.flink.runtime.rest.messages.JobVertexIdPathParameter
- convertToString(LeaderInformation) - Static method in class org.apache.flink.runtime.leaderelection.LeaderElectionUtils
-
Converts the passed
LeaderInformationinto a human-readable representation that can be used in log messages. - convertToString(TriggerId) - Method in class org.apache.flink.runtime.rest.messages.TriggerIdPathParameter
- convertToString(X) - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Converts the given value to its string representation.
- convertValueToString(Boolean) - Method in class org.apache.flink.runtime.rest.messages.AccumulatorsIncludeSerializedValueQueryParameter
- convertValueToString(Integer) - Method in class org.apache.flink.runtime.rest.messages.job.UpperLimitExceptionParameter
- convertValueToString(Integer) - Method in class org.apache.flink.runtime.rest.messages.RescalingParallelismQueryParameter
- convertValueToString(Integer) - Method in class org.apache.flink.runtime.rest.messages.SubtaskIndexQueryParameter
- convertValueToString(String) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricsFilterParameter
- convertValueToString(String) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtasksFilterQueryParameter
- convertValueToString(JobID) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobsFilterQueryParameter
- convertValueToString(ResourceID) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagersFilterQueryParameter
- convertValueToString(FlameGraphTypeQueryParameter.Type) - Method in class org.apache.flink.runtime.rest.messages.FlameGraphTypeQueryParameter
- convertValueToString(FailureLabelFilterParameter.FailureLabel) - Method in class org.apache.flink.runtime.rest.messages.job.FailureLabelFilterParameter
- convertValueToString(MetricsAggregationParameter.AggregationMode) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter
- convertValueToString(TerminationModeQueryParameter.TerminationMode) - Method in class org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter
- convertValueToString(X) - Method in class org.apache.flink.runtime.rest.messages.MessageQueryParameter
-
Converts the given value to its string representation.
- CoordinatedOperatorFactory<OUT> - Interface in org.apache.flink.streaming.api.operators
-
A factory class for the
StreamOperators implementingOperatorEventHandler. - CoordinatedTask - Interface in org.apache.flink.runtime.jobgraph.tasks
-
An task that is coordinated, i.e. contains operators coordinated by
OperatorCoordinator. - CoordinationRequest - Interface in org.apache.flink.runtime.operators.coordination
-
Root interface for all requests from the client to a
OperatorCoordinatorwhich requests for aCoordinationResponse. - CoordinationRequestGateway - Interface in org.apache.flink.runtime.operators.coordination
-
Client interface which sends out a
CoordinationRequestand expects for aCoordinationResponsefrom aOperatorCoordinator. - CoordinationRequestHandler - Interface in org.apache.flink.runtime.operators.coordination
-
Coordinator interface which can handle
CoordinationRequests and response withCoordinationResponses to the client or operator. - CoordinationResponse - Interface in org.apache.flink.runtime.operators.coordination
-
Root interface for all responses from a
OperatorCoordinatorto the client which is the response for aCoordinationRequest. - coordinator() - Method in class org.apache.flink.runtime.operators.coordination.OperatorCoordinatorHolder
- CoordinatorStore - Interface in org.apache.flink.runtime.operators.coordination
-
CoordinatorStorecan be used for sharing some information amongOperatorCoordinatorinstances. - CoordinatorStoreImpl - Class in org.apache.flink.runtime.operators.coordination
-
Basic implementation of
CoordinatorStore. - CoordinatorStoreImpl() - Constructor for class org.apache.flink.runtime.operators.coordination.CoordinatorStoreImpl
- CoProcessFunction<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
-
A function that processes elements of two streams and produces a single output one.
- CoProcessFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.CoProcessFunction
- CoProcessFunction.Context - Class in org.apache.flink.streaming.api.functions.co
-
Information available in an invocation of
#processElement1(Object, Context, Collector)/#processElement2(Object, Context, Collector)or#onTimer(long, OnTimerContext, Collector). - CoProcessFunction.OnTimerContext - Class in org.apache.flink.streaming.api.functions.co
-
Information available in an invocation of
#onTimer(long, OnTimerContext, Collector). - CoProcessOperator<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
A
StreamOperatorfor executingCoProcessFunctions. - CoProcessOperator(CoProcessFunction<IN1, IN2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoProcessOperator
- copy() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
-
Returns a retained copy with separate indexes.
- copy() - Method in class org.apache.flink.streaming.api.operators.collect.CollectResultIterator
- copy() - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
-
Returns a new committable collector that deep copies all internals.
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardForConsecutiveHashPartitioner
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardForUnspecifiedPartitioner
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
- copy() - Method in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
- copy(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
-
Create a copy of this QueryScopeInfo and append the given scope.
- copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobManagerOperatorQueryScopeInfo
- copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobManagerQueryScopeInfo
- copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobQueryScopeInfo
- copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
- copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskManagerQueryScopeInfo
- copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
- copy(ArrayList<T>) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
- copy(ArrayList<T>, ArrayList<T>) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.runtime.state.JavaSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
- copy(VoidNamespace) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
- copy(VoidNamespace, VoidNamespace) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
- copy(CoGroupedStreams.TaggedUnion<T1, T2>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
- copy(CoGroupedStreams.TaggedUnion<T1, T2>, CoGroupedStreams.TaggedUnion<T1, T2>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
- copy(IntervalJoinOperator.BufferEntry<T>) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
- copy(IntervalJoinOperator.BufferEntry<T>, IntervalJoinOperator.BufferEntry<T>) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
- copy(TimerHeapInternalTimer<K, N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
- copy(TimerHeapInternalTimer<K, N>) - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
- copy(TimerHeapInternalTimer<K, N>, TimerHeapInternalTimer<K, N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
- copy(TimerHeapInternalTimer<K, N>, TimerHeapInternalTimer<K, N>) - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
- copy(GlobalWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
- copy(GlobalWindow, GlobalWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
- copy(TimeWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
- copy(TimeWindow, TimeWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
- copy(StreamElement) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
- copy(StreamElement, StreamElement) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
- copy(T) - Method in class org.apache.flink.runtime.state.JavaSerializer
- copy(T) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Creates a copy of this stream record.
- copy(T, T) - Method in class org.apache.flink.runtime.state.JavaSerializer
- copy1 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
- copy2 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
- copyAndDiscardInFlightData() - Method in class org.apache.flink.runtime.checkpoint.FullyFinishedOperatorState
- copyAndDiscardInFlightData() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- copyJobGraph() - Method in class org.apache.flink.runtime.scheduler.adaptive.JobGraphJobInformation
-
Returns a copy of a jobGraph that can be mutated.
- CopyOnWriteStateMap<K,N,S> - Class in org.apache.flink.runtime.state.heap
-
Implementation of Flink's in-memory state maps with copy-on-write support.
- CopyOnWriteStateMap.StateMapEntry<K,N,S> - Class in org.apache.flink.runtime.state.heap
-
One entry in the
CopyOnWriteStateMap. - CopyOnWriteStateMapSnapshot<K,N,S> - Class in org.apache.flink.runtime.state.heap
-
This class represents the snapshot of a
CopyOnWriteStateMap. - CopyOnWriteStateTable<K,N,S> - Class in org.apache.flink.runtime.state.heap
-
This implementation of
StateTableusesCopyOnWriteStateMap. - CopyOnWriteStateTableSnapshot<K,N,S> - Class in org.apache.flink.runtime.state.heap
-
This class represents the snapshot of a
CopyOnWriteStateTableand has a role in operator state checkpointing. - copyRecordOrEvent(MemorySegment, int, int, int, int) - Method in class org.apache.flink.runtime.io.network.partition.SortBuffer
- copyTemplate() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
- copyTo(T, StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Copies this record into the new stream record.
- copyWithNewIDs(String, OperatorID) - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- copyWithReaderPosition(int) - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
-
Returns a retained copy with separate indexes and sets the reader position to the given value.
- CorruptConfigurationException - Exception in org.apache.flink.runtime.operators.util
-
Exception indicating that the parsed configuration was corrupt.
- CorruptConfigurationException(String) - Constructor for exception org.apache.flink.runtime.operators.util.CorruptConfigurationException
-
Creates a new exception with the given error message.
- CorruptConfigurationException(String, Throwable) - Constructor for exception org.apache.flink.runtime.operators.util.CorruptConfigurationException
- CoStreamFlatMap<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
StreamOperatorfor processingCoFlatMapFunctions. - CoStreamFlatMap(CoFlatMapFunction<IN1, IN2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
- CoStreamMap<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
StreamOperatorfor processingCoMapFunctions. - CoStreamMap(CoMapFunction<IN1, IN2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoStreamMap
- couldReusePreviousStateHandle(StreamStateHandle) - Method in interface org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager
-
Check whether previous state handles could further be reused considering the space amplification.
- couldReusePreviousStateHandle(StreamStateHandle) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
- couldReuseStateHandle(StreamStateHandle) - Method in interface org.apache.flink.runtime.state.CheckpointStreamFactory
-
A pre-check hook before the checkpoint writer want to reuse a state handle, if this returns false, it is not recommended for the writer to rewrite the state file considering the space amplification.
- couldReuseStateHandle(StreamStateHandle) - Method in class org.apache.flink.runtime.state.filesystem.FsMergingCheckpointStorageLocation
- count - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.CounterDump
- countBuffers() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
- counter(String) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
- counter(String) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
- counter(String, C) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
- counter(String, C) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
- CounterDump(QueryScopeInfo, String, long) - Constructor for class org.apache.flink.runtime.metrics.dump.MetricDump.CounterDump
- CountEvictor<W extends Window> - Class in org.apache.flink.streaming.api.windowing.evictors
-
An
Evictorthat keeps up to a certain amount of elements. - CountingCollector<OUT> - Class in org.apache.flink.runtime.operators.util.metrics
- CountingCollector(Collector<OUT>, Counter) - Constructor for class org.apache.flink.runtime.operators.util.metrics.CountingCollector
- CountingIterable<IN> - Class in org.apache.flink.runtime.operators.util.metrics
- CountingIterable(Iterable<IN>, Counter) - Constructor for class org.apache.flink.runtime.operators.util.metrics.CountingIterable
- CountingIterator<IN> - Class in org.apache.flink.runtime.operators.util.metrics
- CountingIterator(Iterator<IN>, Counter) - Constructor for class org.apache.flink.runtime.operators.util.metrics.CountingIterator
- CountingMutableObjectIterator<IN> - Class in org.apache.flink.runtime.operators.util.metrics
- CountingMutableObjectIterator(MutableObjectIterator<IN>, Counter) - Constructor for class org.apache.flink.runtime.operators.util.metrics.CountingMutableObjectIterator
- CountingOutput<OUT> - Class in org.apache.flink.streaming.api.operators
-
Wrapping
Outputthat updates metrics on the number of emitted elements. - CountingOutput(WatermarkGaugeExposingOutput<StreamRecord<OUT>>, Counter) - Constructor for class org.apache.flink.streaming.api.operators.CountingOutput
- Counts(long, long, int, long, long) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
- CountTrigger<W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A
Triggerthat fires once the count of elements in a pane reaches the given count. - countWindow(long) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Windows this
KeyedStreaminto tumbling count windows. - countWindow(long, long) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Windows this
KeyedStreaminto sliding count windows. - countWindowAll(long) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Windows this
DataStreaminto tumbling count windows. - countWindowAll(long, long) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Windows this
DataStreaminto sliding count windows. - cover(TimeWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
Returns the minimal window covers both this window and the given window.
- CPU - org.apache.flink.runtime.rest.messages.ProfilingInfo.ProfilingMode
- create() - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook.Factory
-
Instantiates the
MasterTriggerRestoreHook. - create() - Method in interface org.apache.flink.runtime.dispatcher.JobManagerMetricGroupFactory
- create() - Method in class org.apache.flink.runtime.executiongraph.failover.ExponentialDelayRestartBackoffTimeStrategy.ExponentialDelayRestartBackoffTimeStrategyFactory
- create() - Method in class org.apache.flink.runtime.executiongraph.failover.FailureRateRestartBackoffTimeStrategy.FailureRateRestartBackoffTimeStrategyFactory
- create() - Method in class org.apache.flink.runtime.executiongraph.failover.FixedDelayRestartBackoffTimeStrategy.FixedDelayRestartBackoffTimeStrategyFactory
- create() - Method in enum org.apache.flink.runtime.executiongraph.failover.NoRestartBackoffTimeStrategy.NoRestartBackoffTimeStrategyFactory
- create() - Method in interface org.apache.flink.runtime.executiongraph.failover.RestartBackoffTimeStrategy.Factory
-
Instantiates the
RestartBackoffTimeStrategy. - create() - Static method in class org.apache.flink.runtime.jobmaster.slotpool.PreviousAllocationSlotSelectionStrategy
- create() - Static method in class org.apache.flink.runtime.rest.messages.EnvironmentInfo
- create() - Static method in class org.apache.flink.runtime.state.StateObject.StateObjectSizeStatsCollector
- create() - Static method in class org.apache.flink.runtime.taskexecutor.DefaultJobTable
- create() - Method in class org.apache.flink.runtime.util.DefaultGroupCache.Factory
- create() - Static method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
-
Creates a
WindowAssignerthat assigns all elements to the sameGlobalWindow. - create() - Static method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
-
Creates an event-time trigger that fires once the watermark passes the end of the window.
- create() - Static method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
-
Creates a new trigger that fires once system time passes the end of the window.
- create(int, int, KeyExtractorFunction<T>, PriorityComparator<T>) - Method in interface org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue.PartitionQueueSetFactory
-
Creates a new queue for a given key-group partition.
- create(int, Path, BiConsumer<Integer, T>) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.index.FileDataIndexSpilledRegionManager.Factory
- create(int, Path, BiConsumer<Integer, T>) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.index.FileDataIndexSpilledRegionManagerImpl.Factory
- create(int, ResultPartition, File, int, boolean) - Method in enum org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionType
-
Creates BoundedBlockingSubpartition of this type.
- create(long, int) - Static method in class org.apache.flink.runtime.memory.MemoryManager
-
Creates a memory manager with the given capacity and given page size.
- create(long, ProfilingInfo.ProfilingMode) - Static method in class org.apache.flink.runtime.rest.messages.ProfilingInfo
- create(File) - Static method in class org.apache.flink.runtime.entrypoint.WorkingDirectory
- create(String, int, ResultPartitionDeploymentDescriptor) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionFactory
- create(String, int, ResultPartitionID, ResultPartitionType, int, int, int, boolean, ShuffleDescriptor, SupplierWithException<BufferPool, IOException>, boolean) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionFactory
- create(String, String) - Static method in class org.apache.flink.runtime.rest.messages.ThreadDumpInfo.ThreadInfo
- create(String, TypeSerializer<T>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
- create(String, TypeSerializer<T>) - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueSetFactory
- create(String, TypeSerializer<T>) - Method in interface org.apache.flink.runtime.state.PriorityQueueSetFactory
-
Creates a
KeyGroupedInternalPriorityQueue. - create(String, TypeSerializer<T>) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
- create(String, TypeSerializer<T>, boolean) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
- create(String, TypeSerializer<T>, boolean) - Method in interface org.apache.flink.runtime.state.PriorityQueueSetFactory
-
Creates a
KeyGroupedInternalPriorityQueue. - create(String, UnresolvedTaskManagerLocation, UUID) - Static method in class org.apache.flink.runtime.jobmaster.TaskManagerRegistrationInformation
- create(Collection<JobStatus>) - Static method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
- create(Collection<ThreadDumpInfo.ThreadInfo>) - Static method in class org.apache.flink.runtime.rest.messages.ThreadDumpInfo
- create(Executor, Collection<CompletedCheckpoint>, RecoveryClaimMode) - Method in interface org.apache.flink.runtime.state.SharedStateRegistryFactory
-
Factory method for
SharedStateRegistry. - create(List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.sort.DefaultInMemorySorterFactory
- create(List<MemorySegment>) - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorterFactory
-
Create an
InMemorySorterinstance with the given memory segments. - create(List<IOMetricsInfo>, List<Map<ExecutionState, Long>>) - Static method in class org.apache.flink.runtime.rest.messages.AggregatedTaskDetailsInfo
- create(List<SubtaskExecutionAttemptDetailsInfo>) - Static method in class org.apache.flink.runtime.rest.messages.AggregatedTaskDetailsInfo
- create(Map<ExecutionVertexID, LogicalSlot>) - Static method in class org.apache.flink.runtime.scheduler.adaptive.allocator.ReservedSlots
- create(UUID) - Method in interface org.apache.flink.runtime.dispatcher.runner.DispatcherLeaderProcessFactory
- create(UUID) - Method in class org.apache.flink.runtime.dispatcher.runner.JobDispatcherLeaderProcessFactory
- create(UUID) - Method in class org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcessFactory
- create(UUID) - Method in class org.apache.flink.runtime.jobmaster.factories.DefaultJobMasterServiceProcessFactory
- create(UUID) - Method in interface org.apache.flink.runtime.jobmaster.factories.JobMasterServiceProcessFactory
-
Create a new
JobMasterServiceProcessfor the given leaderSessionId. - create(UUID, AbstractDispatcherLeaderProcess.DispatcherGatewayServiceFactory, JobGraphStore, JobResultStore, Executor, FatalErrorHandler) - Static method in class org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcess
- create(JobID, String, Collection<ResourceRequirement>) - Static method in class org.apache.flink.runtime.slots.ResourceRequirements
- create(JobID, Consumer<? super Collection<ResourceRequirement>>, Duration, Duration, Duration, ComponentMainThreadExecutor) - Method in class org.apache.flink.runtime.jobmaster.slotpool.BlocklistDeclarativeSlotPoolFactory
- create(JobID, Consumer<? super Collection<ResourceRequirement>>, Duration, Duration, Duration, ComponentMainThreadExecutor) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolFactory
- create(JobID, Consumer<? super Collection<ResourceRequirement>>, Duration, Duration, Duration, ComponentMainThreadExecutor) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultDeclarativeSlotPoolFactory
- create(Configuration) - Static method in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
-
Factory method for initializing a TaskExecutorMemoryConfiguration based on the passed Configuration.
- create(Configuration, PluginManager, ScheduledExecutor, ExecutorService) - Static method in class org.apache.flink.runtime.security.token.DefaultDelegationTokenManagerFactory
- create(Configuration, TaskExecutorProcessSpec) - Static method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
-
Computes the parameters to be used to start a TaskManager Java process.
- create(Configuration, ResourceID, Executor, RpcService, HighAvailabilityServices, BlobServer, HeartbeatServices, DelegationTokenManager, MetricRegistry, ExecutionGraphInfoStore, MetricQueryServiceRetriever, Collection<FailureEnricher>, FatalErrorHandler) - Method in class org.apache.flink.runtime.entrypoint.component.DefaultDispatcherResourceManagerComponentFactory
- create(Configuration, ResourceID, Executor, RpcService, HighAvailabilityServices, BlobServer, HeartbeatServices, DelegationTokenManager, MetricRegistry, ExecutionGraphInfoStore, MetricQueryServiceRetriever, Collection<FailureEnricher>, FatalErrorHandler) - Method in interface org.apache.flink.runtime.entrypoint.component.DispatcherResourceManagerComponentFactory
- create(Configuration, FatalErrorHandler) - Method in interface org.apache.flink.runtime.highavailability.ClientHighAvailabilityServicesFactory
-
Creates a
ClientHighAvailabilityServicesinstance. - create(Configuration, FatalErrorHandler) - Method in class org.apache.flink.runtime.highavailability.DefaultClientHighAvailabilityServicesFactory
- create(RecordContext<K>) - Method in class org.apache.flink.runtime.asyncprocessing.StateFutureFactory
- create(BlocklistContext, Function<ResourceID, String>, ComponentMainThreadExecutor, Logger) - Method in interface org.apache.flink.runtime.blocklist.BlocklistHandler.Factory
-
Instantiates a
BlocklistHandler. - create(BlocklistContext, Function<ResourceID, String>, ComponentMainThreadExecutor, Logger) - Method in class org.apache.flink.runtime.blocklist.DefaultBlocklistHandler.Factory
- create(BlocklistContext, Function<ResourceID, String>, ComponentMainThreadExecutor, Logger) - Method in class org.apache.flink.runtime.blocklist.NoOpBlocklistHandler.Factory
- create(ResourceProfile, int) - Static method in class org.apache.flink.runtime.slots.ResourceRequirement
- create(DispatcherFactory) - Static method in class org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcessFactoryFactory
- create(DispatcherGateway, ScheduledExecutor, FatalErrorHandler) - Method in interface org.apache.flink.runtime.dispatcher.DispatcherBootstrapFactory
- create(DispatcherId, Collection<JobGraph>, Collection<JobResult>, JobGraphWriter, JobResultStore) - Method in interface org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess.DispatcherGatewayServiceFactory
- create(JobGraphRetriever) - Static method in class org.apache.flink.runtime.dispatcher.runner.JobDispatcherLeaderProcessFactoryFactory
- create(AccessExecution, String, CompletableFuture<Map<String, String>>) - Static method in class org.apache.flink.runtime.scheduler.exceptionhistory.ExceptionHistoryEntry
-
Creates an
ExceptionHistoryEntrybased on the providedExecution. - create(AccessExecution, MetricFetcher, JobID, JobVertexID, List<SubtaskExecutionAttemptDetailsInfo>) - Static method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- create(FailureHandlingResult, Function<ExecutionVertexID, Collection<Execution>>) - Static method in class org.apache.flink.runtime.scheduler.exceptionhistory.FailureHandlingResultSnapshot
-
Creates a
FailureHandlingResultSnapshotbased on the passedFailureHandlingResultandExecutionVertices. - create(PartitionTrackerFactory.TaskExecutorGatewayLookup) - Method in interface org.apache.flink.runtime.io.network.partition.PartitionTrackerFactory
-
Creates a new PartitionTracker.
- create(JobGraph) - Method in class org.apache.flink.runtime.jobmaster.factories.DefaultJobManagerJobMetricGroupFactory
- create(JobGraph) - Method in interface org.apache.flink.runtime.jobmaster.factories.JobManagerJobMetricGroupFactory
-
Create a new
JobManagerJobMetricGroup. - create(JobGraph) - Method in enum org.apache.flink.runtime.jobmaster.factories.UnregisteredJobManagerJobMetricGroupFactory
- create(TaskInvokable, CheckpointedInputGate[], IOManager, MemoryManager, TaskIOMetricGroup, TwoInputStreamOperator<IN1, IN2, ?>, WatermarkGauge, WatermarkGauge, OperatorChain<?, ?>, StreamConfig, Configuration, Configuration, ExecutionConfig, ClassLoader, Counter, InflightDataRescalingDescriptor, Function<Integer, StreamPartitioner<?>>, TaskInfo, StreamTask.CanEmitBatchOfRecordsChecker) - Static method in class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessorFactory
- create(TaskInvokable, CheckpointedInputGate[], StreamConfig.InputConfig[], IOManager, MemoryManager, TaskIOMetricGroup, Counter, MultipleInputStreamOperator<?>, WatermarkGauge[], StreamConfig, Configuration, Configuration, ExecutionConfig, ClassLoader, OperatorChain<?, ?>, InflightDataRescalingDescriptor, Function<Integer, StreamPartitioner<?>>, TaskInfo, StreamTask.CanEmitBatchOfRecordsChecker) - Static method in class org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessorFactory
- create(ExecutionDeploymentReconciliationHandler) - Method in interface org.apache.flink.runtime.jobmaster.ExecutionDeploymentReconciler.Factory
- create(JobResult, CheckpointRecoveryFactory, Configuration, Executor) - Method in enum org.apache.flink.runtime.dispatcher.cleanup.CheckpointResourcesCleanupRunnerFactory
- create(JobResult, CheckpointRecoveryFactory, Configuration, Executor) - Method in interface org.apache.flink.runtime.dispatcher.cleanup.CleanupRunnerFactory
- create(SlotPoolServiceFactory, SchedulerNGFactory) - Static method in class org.apache.flink.runtime.jobmaster.DefaultSlotPoolServiceSchedulerFactory
- create(SlotSelectionStrategy) - Static method in class org.apache.flink.runtime.jobmaster.slotpool.PreviousAllocationSlotSelectionStrategy
- create(LeaderElectionDriver.Listener) - Method in interface org.apache.flink.runtime.leaderelection.LeaderElectionDriverFactory
-
Creates a
LeaderElectionDriverfor the given leader contender description. - create(LeaderElectionDriver.Listener) - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionDriverFactory
- create(LeaderElection, FatalErrorHandler, DispatcherLeaderProcessFactory) - Static method in class org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherRunner
- create(TaskIOMetricGroup, CheckpointableKeyedStateBackend<K>, ClassLoader, KeyContext, ProcessingTimeService, Iterable<KeyGroupStatePartitionStreamProvider>, StreamTaskCancellationContext) - Method in interface org.apache.flink.streaming.api.operators.InternalTimeServiceManager.Provider
- create(TaskIOMetricGroup, CheckpointableKeyedStateBackend<K>, ClassLoader, KeyContext, ProcessingTimeService, Iterable<KeyGroupStatePartitionStreamProvider>, StreamTaskCancellationContext) - Static method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManagerImpl
-
A factory method for creating the
InternalTimeServiceManagerImpl. - create(TaskIOMetricGroup, CheckpointableKeyedStateBackend<K>, ClassLoader, KeyContext, ProcessingTimeService, Iterable<KeyGroupStatePartitionStreamProvider>, StreamTaskCancellationContext) - Static method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeServiceManager
- create(MetricRegistry, String) - Static method in class org.apache.flink.runtime.metrics.groups.ProcessMetricGroup
- create(MetricRegistry, String) - Static method in class org.apache.flink.runtime.metrics.groups.ResourceManagerMetricGroup
- create(MetricRegistry, String) - Static method in class org.apache.flink.runtime.metrics.groups.SlotManagerMetricGroup
- create(OperatorCoordinator.Context) - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator.Provider
-
Creates the
OperatorCoordinator, using the given context. - create(OperatorCoordinator.Context) - Method in class org.apache.flink.runtime.operators.coordination.RecreateOnResetOperatorCoordinator.Provider
- create(OperatorCoordinator.Context) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator.Provider
- create(OperatorCoordinator.Context, long) - Method in class org.apache.flink.runtime.operators.coordination.RecreateOnResetOperatorCoordinator.Provider
- create(ResourceManagerFactory<?>, Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, DelegationTokenManager, FatalErrorHandler, ClusterInformation, String, MetricRegistry, String, Executor) - Static method in class org.apache.flink.runtime.resourcemanager.ResourceManagerServiceImpl
- create(ProfilingInfo.ProfilingStatus, ProfilingInfo.ProfilingMode, long, long, long, String, String) - Static method in class org.apache.flink.runtime.rest.messages.ProfilingInfo
- create(SchedulingTopology, ResultPartitionAvailabilityChecker) - Method in interface org.apache.flink.runtime.executiongraph.failover.FailoverStrategy.Factory
-
Instantiates the
FailoverStrategy. - create(SchedulingTopology, ResultPartitionAvailabilityChecker) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartAllFailoverStrategy.Factory
- create(SchedulingTopology, ResultPartitionAvailabilityChecker) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionFailoverStrategy.Factory
- create(ShuffleIOOwnerContext, int, InputGateDeploymentDescriptor, PartitionProducerStateProvider, InputChannelMetrics) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGateFactory
-
Creates an input gate and all of its input channels.
- create(DirectoryStreamStateHandle, DirectoryStreamStateHandle) - Static method in class org.apache.flink.runtime.state.filemerging.EmptyFileMergingOperatorStreamStateHandle
-
Create an empty
EmptyFileMergingOperatorStreamStateHandle. - create(KeyGroupRangeOffsets, StreamStateHandle) - Method in interface org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.KeyedStateHandleFactory
- create(StateBackend, StateBackend.KeyedStateBackendParameters<K>) - Method in interface org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl.KeyedStateBackendCreator
-
Create the keyed state backend.
- create(TaskManagerLocation, ExecutionAttemptID) - Static method in class org.apache.flink.runtime.shuffle.ProducerDescriptor
- create(CheckpointedInputGate, TypeSerializer<T>, IOManager, StatusWatermarkValve, int, InflightDataRescalingDescriptor, Function<Integer, StreamPartitioner<?>>, TaskInfo, StreamTask.CanEmitBatchOfRecordsChecker) - Static method in class org.apache.flink.streaming.runtime.io.StreamTaskNetworkInputFactory
-
Factory method for
StreamTaskNetworkInputorRescalingStreamTaskNetworkInputdepending onInflightDataRescalingDescriptor. - create(RelativeClock) - Method in class org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks.TimestampsAndWatermarksContextProvider
- create(SerializedValue<OperatorCoordinator.Provider>, ExecutionJobVertex, ClassLoader, CoordinatorStore, boolean, TaskInformation, JobManagerJobMetricGroup) - Static method in class org.apache.flink.runtime.operators.coordination.OperatorCoordinatorHolder
- create(R, M) - Static method in class org.apache.flink.runtime.rest.handler.HandlerRequest
-
Short-cut for
HandlerRequest.create(RequestBody, MessageParameters, Collection)without any uploaded files. - create(R, M, Collection<File>) - Static method in class org.apache.flink.runtime.rest.handler.HandlerRequest
-
Creates a new
HandlerRequest. - createActivatorDeactivator(boolean) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
- createAllocatedSlotReport(ResourceID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolService
- createAllocatedSlotReport(ResourceID) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Create report about the allocated slots belonging to the specified task manager.
- createAllocatedSlotReport(ResourceID) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolService
-
Create report about the allocated slots belonging to the specified task manager.
- createAndRestore(List<? extends Collection<S>>, StateObject.StateObjectSizeStatsCollector) - Method in class org.apache.flink.streaming.api.operators.BackendRestorerProcedure
-
Creates a new state backend and restores it from the provided set of state snapshot alternatives.
- createAndRestoreExecutionGraph(JobGraph, CompletedCheckpointStore, CheckpointsCleaner, CheckpointIDCounter, CheckpointStatsTracker, TaskDeploymentDescriptorFactory.PartitionLocationConstraint, long, VertexAttemptNumberStore, VertexParallelismStore, ExecutionStateUpdateListener, MarkPartitionFinishedStrategy, Logger) - Method in class org.apache.flink.runtime.scheduler.DefaultExecutionGraphFactory
- createAndRestoreExecutionGraph(JobGraph, CompletedCheckpointStore, CheckpointsCleaner, CheckpointIDCounter, CheckpointStatsTracker, TaskDeploymentDescriptorFactory.PartitionLocationConstraint, long, VertexAttemptNumberStore, VertexParallelismStore, ExecutionStateUpdateListener, MarkPartitionFinishedStrategy, Logger) - Method in interface org.apache.flink.runtime.scheduler.ExecutionGraphFactory
-
Create and restore
ExecutionGraphfrom the givenJobGraphand services. - createArchivedExecutionGraph(JobStatus, Throwable) - Method in class org.apache.flink.runtime.jobmaster.factories.DefaultJobMasterServiceProcessFactory
- createArchivedExecutionGraph(JobStatus, Throwable) - Method in interface org.apache.flink.runtime.jobmaster.factories.JobMasterServiceProcessFactory
-
Creates an
ArchivedExecutionGraphfor the job for which this factory createsJobMasterServiceProcesswith the given jobStatus and failure cause. - createAsyncKeyedStateBackend(StateBackend.KeyedStateBackendParameters<K>) - Method in interface org.apache.flink.runtime.state.StateBackend
-
Creates a new
AsyncKeyedStateBackendwhich supports to access keyed state asynchronously. - createAvailableOrEmbeddedServices(Configuration, Executor, FatalErrorHandler) - Static method in class org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
- createBatch() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
Creates a batch of mails that can be taken with
TaskMailbox.tryTakeFromBatch(). - createBatch() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
- createBlobCacheService(Configuration, Reference<File>, BlobView, InetSocketAddress) - Static method in class org.apache.flink.runtime.blob.BlobUtils
-
Creates the
BlobCacheServicefrom the given configuration, fallback storage directory, blob view and blob server address. - createBlobServer(Configuration, Reference<File>, BlobStore) - Static method in class org.apache.flink.runtime.blob.BlobUtils
-
Creates the
BlobServerfrom the given configuration, fallback storage directory and blob store. - createBlobStore() - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
- createBlobStore() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Creates the BLOB store in which BLOBs are stored in a highly-available fashion.
- createBlobStore() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
- createBlobStoreFromConfig(Configuration) - Static method in class org.apache.flink.runtime.blob.BlobUtils
-
Creates a BlobStore based on the parameters set in the configuration.
- createBlockChannelReader(FileIOChannel.ID) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Creates a block channel reader that reads blocks from the given channel.
- createBlockChannelReader(FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Creates a block channel reader that reads blocks from the given channel.
- createBlockChannelReader(FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
Creates a block channel reader that reads blocks from the given channel.
- createBlockChannelWriter(FileIOChannel.ID) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Creates a block channel writer that writes to the given channel.
- createBlockChannelWriter(FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Creates a block channel writer that writes to the given channel.
- createBlockChannelWriter(FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
- createBlockChannelWriter(FileIOChannel.ID, RequestDoneCallback<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Creates a block channel writer that writes to the given channel.
- createBlockChannelWriter(FileIOChannel.ID, RequestDoneCallback<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
- createBlockCompressionFactory(NettyShuffleEnvironmentOptions.CompressionCodec) - Static method in interface org.apache.flink.runtime.io.compression.BlockCompressionFactory
-
Creates
BlockCompressionFactoryaccording to the configuration. - createBrokerIdString(JobID, String, int) - Static method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
-
Creates the identification string with which head and tail task find the shared blocking queue for the back channel.
- createBufferConsumer() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
This method always creates a
BufferConsumerstarting from the current writer offset. - createBufferConsumerFromBeginning() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
This method always creates a
BufferConsumerstarting from position 0 ofMemorySegment. - createBufferFileReader(FileIOChannel.ID, RequestDoneCallback<Buffer>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
- createBufferFileReader(FileIOChannel.ID, RequestDoneCallback<Buffer>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
- createBufferFileSegmentReader(FileIOChannel.ID, RequestDoneCallback<FileSegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
- createBufferFileSegmentReader(FileIOChannel.ID, RequestDoneCallback<FileSegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
- createBufferFileWriter(FileIOChannel.ID) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
- createBufferFileWriter(FileIOChannel.ID) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
- createBufferPool(int, int) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPoolFactory
-
Tries to create a buffer pool, which is guaranteed to provide at least the number of required buffers.
- createBufferPool(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
- createBufferPool(int, int, int, int, int) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPoolFactory
-
Tries to create a buffer pool with an owner, which is guaranteed to provide at least the number of required buffers.
- createBufferPool(int, int, int, int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
- createBulkBlockChannelReader(FileIOChannel.ID, List<MemorySegment>, int) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Creates a block channel reader that reads all blocks from the given channel directly in one bulk.
- createBulkBlockChannelReader(FileIOChannel.ID, List<MemorySegment>, int) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
Creates a block channel reader that reads all blocks from the given channel directly in one bulk.
- createChannel() - Method in interface org.apache.flink.runtime.io.disk.FileChannelManager
-
Creates an ID identifying an underlying file channel and returns it.
- createChannel() - Method in class org.apache.flink.runtime.io.disk.FileChannelManagerImpl
- createChannel() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Creates a new
FileIOChannel.IDin one of the temp directories. - createChannelEnumerator() - Method in interface org.apache.flink.runtime.io.disk.FileChannelManager
-
Creates an enumerator for channels that logically belong together and returns it.
- createChannelEnumerator() - Method in class org.apache.flink.runtime.io.disk.FileChannelManagerImpl
- createChannelEnumerator() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Creates a new
FileIOChannel.Enumerator, spreading the channels in a round-robin fashion across the temporary file directories. - createCheckpointBarrierHandler(CheckpointableTask, StreamConfig, SubtaskCheckpointCoordinator, String, List<IndexedInputGate>[], List<StreamTaskSourceInput<?>>, MailboxExecutor, TimerService) - Static method in class org.apache.flink.streaming.runtime.io.checkpointing.InputProcessorUtil
- createCheckpointDataSerializer() - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
-
Creates a the serializer to (de)serializes the data stored by this hook.
- createCheckpointDirectory(Path, long) - Static method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorageAccess
-
Creates the directory path for the data exclusive to a specific checkpoint.
- createCheckpointedMultipleInputGate(MailboxExecutor, List<IndexedInputGate>[], TaskIOMetricGroup, CheckpointBarrierHandler, StreamConfig) - Static method in class org.apache.flink.streaming.runtime.io.checkpointing.InputProcessorUtil
- createCheckpointIDCounter(JobID) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
-
Creates a
CheckpointIDCounterinstance for a job. - createCheckpointIDCounter(JobID) - Method in class org.apache.flink.runtime.checkpoint.PerJobCheckpointRecoveryFactory
- createCheckpointIDCounter(JobID) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
- createCheckpointIDCounter(JobID) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
- createCheckpointIDCounter(CuratorFramework) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Creates a
ZooKeeperCheckpointIDCounterinstance. - createCheckpointIDCounterIfCheckpointingIsEnabled(JobGraph, CheckpointRecoveryFactory) - Static method in class org.apache.flink.runtime.scheduler.SchedulerUtils
- createCheckpointRecoveryFactory() - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
-
Create the checkpoint recovery factory for the job manager.
- createCheckpointRecoveryFactory() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperLeaderElectionHaServices
- createCheckpointStateOutputStream(FileMergingSnapshotManager.SubtaskKey, long, CheckpointedStateScope) - Method in interface org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager
-
Create a new
FileMergingCheckpointStateOutputStream. - createCheckpointStateOutputStream(FileMergingSnapshotManager.SubtaskKey, long, CheckpointedStateScope) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
- createCheckpointStateOutputStream(CheckpointedStateScope) - Method in interface org.apache.flink.runtime.state.CheckpointStreamFactory
-
Creates an new
CheckpointStateOutputStream. - createCheckpointStateOutputStream(CheckpointedStateScope) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
- createCheckpointStateOutputStream(CheckpointedStateScope) - Method in class org.apache.flink.runtime.state.filesystem.FsMergingCheckpointStorageLocation
- createCheckpointStateOutputStream(CheckpointedStateScope) - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory
- createCheckpointStatsTrackerIfCheckpointingIsEnabled(JobGraph, Supplier<CheckpointStatsTracker>) - Static method in class org.apache.flink.runtime.scheduler.SchedulerUtils
- createCheckpointStorage(JobID) - Method in interface org.apache.flink.runtime.state.CheckpointStorage
-
Creates a storage for checkpoints for the given job.
- createCheckpointStorage(JobID) - Method in class org.apache.flink.runtime.state.storage.FileSystemCheckpointStorage
- createCheckpointStorage(JobID) - Method in class org.apache.flink.runtime.state.storage.JobManagerCheckpointStorage
- createCheckpointStorage(JobID) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionCheckpointStorage
- createChildGroup(String, AbstractMetricGroup.ChildType) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
- createChildGroup(String, AbstractMetricGroup.ChildType) - Method in class org.apache.flink.runtime.metrics.groups.GenericKeyMetricGroup
- createClassLoader(URL[]) - Method in interface org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager.ClassLoaderFactory
- createClient() - Method in class org.apache.flink.runtime.blob.BlobServer
- createClientHAService(Configuration, FatalErrorHandler) - Static method in class org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
- createClientHAServices(Configuration) - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServicesFactory
-
Create a
ClientHighAvailabilityServicesinstance. - createClientSSLEngineFactory() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
- createClusterPartitionReport() - Method in interface org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTracker
-
Creates a
ClusterPartitionReport, describing which cluster partitions are currently available. - createClusterPartitionReport() - Method in class org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTrackerImpl
- createCompletedCheckpoints(CuratorFramework, Configuration, int, SharedStateRegistryFactory, Executor, Executor, RecoveryClaimMode) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Creates a
DefaultCompletedCheckpointStoreinstance withZooKeeperStateHandleStore. - createCompletedCheckpointStoreIfCheckpointingIsEnabled(JobGraph, Configuration, CheckpointRecoveryFactory, Executor, Logger) - Static method in class org.apache.flink.runtime.scheduler.SchedulerUtils
- createConsumerAgent(List<TieredStorageConsumerSpec>, List<TierShuffleDescriptor>, TieredStorageNettyService) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskTierFactory
- createConsumerAgent(List<TieredStorageConsumerSpec>, List<TierShuffleDescriptor>, TieredStorageNettyService) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory.MemoryTierFactory
- createConsumerAgent(List<TieredStorageConsumerSpec>, List<TierShuffleDescriptor>, TieredStorageNettyService) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierFactory
- createConsumerAgent(List<TieredStorageConsumerSpec>, List<TierShuffleDescriptor>, TieredStorageNettyService) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierFactory
-
Creates the consumer-side agent of a Tier.
- createContext(SecurityConfiguration) - Method in class org.apache.flink.runtime.security.contexts.HadoopSecurityContextFactory
- createContext(SecurityConfiguration) - Method in class org.apache.flink.runtime.security.contexts.NoOpSecurityContextFactory
- createContext(SecurityConfiguration) - Method in interface org.apache.flink.runtime.security.contexts.SecurityContextFactory
-
create security context.
- createCopy(TypeSerializer<T>, T, T) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
Copies an instance of the given type, potentially reusing the object passed as the reuse parameter, which may be null.
- createCopy(TypeSerializer<T>, T, T) - Method in class org.apache.flink.runtime.operators.sort.NonReusingMergeInnerJoinIterator
- createCopy(TypeSerializer<T>, T, T) - Method in class org.apache.flink.runtime.operators.sort.NonReusingMergeOuterJoinIterator
- createCopy(TypeSerializer<T>, T, T) - Method in class org.apache.flink.runtime.operators.sort.ReusingMergeInnerJoinIterator
- createCopy(TypeSerializer<T>, T, T) - Method in class org.apache.flink.runtime.operators.sort.ReusingMergeOuterJoinIterator
- created(JobResult) - Static method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
- CREATED - org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess.State
- CREATED - org.apache.flink.runtime.execution.ExecutionState
- CREATED - org.apache.flink.runtime.scheduler.strategy.ResultPartitionState
-
Partition is just created or is just reset.
- createDefault() - Static method in class org.apache.flink.runtime.jobmaster.slotpool.LocationPreferenceSlotSelectionStrategy
- createDefaultJobManagerProcessSpec(int) - Static method in class org.apache.flink.runtime.jobmanager.JobManagerProcessUtils
- createDefaultJobResultStorePath(String, String) - Static method in class org.apache.flink.runtime.highavailability.FileSystemJobResultStore
- createDefaultWorkerResourceSpec(Configuration) - Method in class org.apache.flink.runtime.resourcemanager.ArbitraryWorkerResourceSpecFactory
- createDefaultWorkerResourceSpec(Configuration) - Method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpecFactory
- createDeploymentDescriptor(Execution, AllocationID, JobManagerTaskRestore, Collection<ResultPartitionDeploymentDescriptor>) - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory
- createDetailsForJob(AccessExecutionGraph) - Static method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
- createDirtyResultAsync(JobResultEntry) - Method in class org.apache.flink.runtime.highavailability.AbstractThreadsafeJobResultStore
- createDirtyResultAsync(JobResultEntry) - Method in interface org.apache.flink.runtime.highavailability.JobResultStore
-
Registers the passed
JobResultEntryinstance asdirtywhich indicates that clean-up operations still need to be performed. - createDirtyResultInternal(JobResultEntry) - Method in class org.apache.flink.runtime.highavailability.AbstractThreadsafeJobResultStore
- createDirtyResultInternal(JobResultEntry) - Method in class org.apache.flink.runtime.highavailability.FileSystemJobResultStore
- createDirtyResultInternal(JobResultEntry) - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedJobResultStore
- createDispatcher(RpcService, DispatcherId, Collection<JobGraph>, Collection<JobResult>, DispatcherBootstrapFactory, PartialDispatcherServicesWithJobPersistenceComponents) - Method in interface org.apache.flink.runtime.dispatcher.DispatcherFactory
-
Create a
Dispatcher. - createDispatcher(RpcService, DispatcherId, Collection<JobGraph>, Collection<JobResult>, DispatcherBootstrapFactory, PartialDispatcherServicesWithJobPersistenceComponents) - Method in enum org.apache.flink.runtime.dispatcher.JobDispatcherFactory
- createDispatcher(RpcService, DispatcherId, Collection<JobGraph>, Collection<JobResult>, DispatcherBootstrapFactory, PartialDispatcherServicesWithJobPersistenceComponents) - Method in enum org.apache.flink.runtime.dispatcher.SessionDispatcherFactory
- createDispatcherResourceManagerComponentFactory() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- createDispatcherResourceManagerComponentFactory(Configuration) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
- createDispatcherResourceManagerComponentFactory(Configuration) - Method in class org.apache.flink.runtime.entrypoint.StandaloneSessionClusterEntrypoint
- createDispatcherResourceManagerComponents(Configuration, MiniCluster.RpcServiceFactory, BlobServer, HeartbeatServices, DelegationTokenManager, MetricRegistry, MetricQueryServiceRetriever, FatalErrorHandler) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- createDispatcherRunner(LeaderElection, FatalErrorHandler, JobPersistenceComponentFactory, Executor, RpcService, PartialDispatcherServices) - Method in class org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherRunnerFactory
- createDispatcherRunner(LeaderElection, FatalErrorHandler, JobPersistenceComponentFactory, Executor, RpcService, PartialDispatcherServices) - Method in interface org.apache.flink.runtime.dispatcher.runner.DispatcherRunnerFactory
- createDuplicatingStream(long, CheckpointedStateScope, CheckpointStreamFactory, LocalSnapshotDirectoryProvider) - Static method in interface org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
- createErrorInfoWithNullableCause(Throwable, long) - Static method in class org.apache.flink.runtime.executiongraph.ErrorInfo
-
Instantiates an
ErrorInfoto cover inconsistent behavior due to FLINK-21376. - createEvenlySpreadOut() - Static method in class org.apache.flink.runtime.jobmaster.slotpool.LocationPreferenceSlotSelectionStrategy
- createExecutionEnvironment(Configuration) - Method in interface org.apache.flink.streaming.api.environment.StreamExecutionEnvironmentFactory
-
Creates a StreamExecutionEnvironment from this factory.
- createExecutionGraphCache(RestHandlerConfiguration) - Static method in interface org.apache.flink.runtime.rest.RestEndpointFactory
- createExecutionVertex(ExecutionJobVertex, int, IntermediateResult[], Duration, long, int, int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- createExecutionVertex(ExecutionJobVertex, int, IntermediateResult[], Duration, long, int, int) - Method in class org.apache.flink.runtime.executiongraph.SpeculativeExecutionJobVertex
- createExecutor(int) - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorFactory
-
Creates a new executor for the given priority.
- createExecutorService(int, int, String) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
- createFactory(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.failover.ExponentialDelayRestartBackoffTimeStrategy
- createFactory(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.failover.FailureRateRestartBackoffTimeStrategy
- createFactory(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.failover.FixedDelayRestartBackoffTimeStrategy
- createFactory(JobPersistenceComponentFactory, Executor, RpcService, PartialDispatcherServices, FatalErrorHandler) - Method in interface org.apache.flink.runtime.dispatcher.runner.DispatcherLeaderProcessFactoryFactory
- createFactory(JobPersistenceComponentFactory, Executor, RpcService, PartialDispatcherServices, FatalErrorHandler) - Method in class org.apache.flink.runtime.dispatcher.runner.JobDispatcherLeaderProcessFactoryFactory
- createFactory(JobPersistenceComponentFactory, Executor, RpcService, PartialDispatcherServices, FatalErrorHandler) - Method in class org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcessFactoryFactory
- createFailureHandlingResultSnapshot(FailureHandlingResult) - Method in class org.apache.flink.runtime.scheduler.DefaultScheduler
- createFileQueue() - Method in class org.apache.flink.runtime.checkpoint.filemerging.BlockingPhysicalFilePool
- createFileQueue() - Method in class org.apache.flink.runtime.checkpoint.filemerging.NonBlockingPhysicalFilePool
- createFileQueue() - Method in class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFilePool
-
Create and return a file queue.
- createFileSystemStateStorage(Configuration, String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Creates a
FileSystemStateStorageHelperinstance. - createFor(TaskExecutor) - Static method in class org.apache.flink.runtime.taskexecutor.TaskExecutorToServiceAdapter
- createForDeserializedState() - Method in interface org.apache.flink.runtime.state.StateSnapshotTransformer.StateSnapshotTransformFactory
- createForDeserializedState() - Method in class org.apache.flink.runtime.state.StateSnapshotTransformers.ListStateSnapshotTransformFactory
- createForDeserializedState() - Method in class org.apache.flink.runtime.state.StateSnapshotTransformers.MapStateSnapshotTransformFactory
- createForDeserializedState() - Method in class org.apache.flink.runtime.state.StateSnapshotTransformers.StateSnapshotTransformFactoryWrapAdaptor
- createForSerializedState() - Method in interface org.apache.flink.runtime.state.StateSnapshotTransformer.StateSnapshotTransformFactory
- createForSerializedState() - Method in class org.apache.flink.runtime.state.StateSnapshotTransformers.StateSnapshotTransformFactoryWrapAdaptor
- createFrom(Configuration, File) - Static method in class org.apache.flink.runtime.entrypoint.component.FileJobGraphRetriever
- createFrom(AccessExecutionGraph) - Static method in class org.apache.flink.runtime.jobmaster.JobResult
-
Creates the
JobResultfrom the givenAccessExecutionGraphwhich must be in a globally terminal state. - createFrom(ExecutionGraph) - Static method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
Create a
ArchivedExecutionGraphfrom the givenExecutionGraph. - createFrom(ExecutionGraph, JobStatus) - Static method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
Create a
ArchivedExecutionGraphfrom the givenExecutionGraph. - createFromConfig(ReadableConfig, ClassLoader) - Method in interface org.apache.flink.runtime.state.CheckpointStorageFactory
-
Creates the checkpoint storage, optionally using the given configuration.
- createFromConfig(ReadableConfig, ClassLoader) - Method in class org.apache.flink.runtime.state.hashmap.HashMapStateBackendFactory
- createFromConfig(ReadableConfig, ClassLoader) - Method in interface org.apache.flink.runtime.state.StateBackendFactory
-
Creates the state backend, optionally using the given configuration.
- createFromConfig(ReadableConfig, ClassLoader) - Static method in class org.apache.flink.runtime.state.storage.FileSystemCheckpointStorage
-
Creates a new
FileSystemCheckpointStorageusing the given configuration. - createFromConfig(ReadableConfig, ClassLoader) - Static method in class org.apache.flink.runtime.state.storage.JobManagerCheckpointStorage
-
Creates a new
JobManagerCheckpointStorageusing the given configuration. - createFromSlotPool(SlotPool, Clock) - Static method in class org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlotRequestBulkCheckerImpl
- createFullFlameGraphFrom(VertexThreadInfoStats) - Static method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexFlameGraphFactory
-
Converts
VertexThreadInfoStatsinto a FlameGraph. - createGateBuffersSpec(Optional<Integer>, int, int, ResultPartitionType, int, boolean) - Static method in class org.apache.flink.runtime.io.network.partition.consumer.InputGateSpecUtils
- createGateway(CompletableFuture<Tuple2<String, UUID>>) - Method in class org.apache.flink.runtime.webmonitor.retriever.impl.RpcGatewayRetriever
- createGateway(CompletableFuture<Tuple2<String, UUID>>) - Method in class org.apache.flink.runtime.webmonitor.retriever.LeaderGatewayRetriever
- createGlobal(Throwable, CompletableFuture<Map<String, String>>) - Static method in class org.apache.flink.runtime.scheduler.exceptionhistory.ExceptionHistoryEntry
-
Creates an
ExceptionHistoryEntrythat is not based on anExecution. - createGlobalResourceCleaner(ComponentMainThreadExecutor) - Method in class org.apache.flink.runtime.dispatcher.cleanup.DispatcherResourceCleanerFactory
- createGlobalResourceCleaner(ComponentMainThreadExecutor) - Method in interface org.apache.flink.runtime.dispatcher.cleanup.ResourceCleanerFactory
-
Creates
ResourceCleanerthat initiatesGloballyCleanableResource.globalCleanupAsync(JobID, Executor)calls. - createHandler(Configuration) - Method in interface org.apache.flink.runtime.io.network.netty.OutboundChannelHandlerFactory
-
Creates new instance of
ChannelHandler - createHandler(Configuration, Map<String, String>) - Method in interface org.apache.flink.runtime.io.network.netty.InboundChannelHandlerFactory
-
Creates new instance of
ChannelHandler - createHaServices(Configuration, Executor, RpcSystemUtils) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
- createHAServices(Configuration, Executor) - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServicesFactory
-
Creates a
HighAvailabilityServicesinstance. - createHeartbeatManager(ResourceID, HeartbeatListener<I, O>, ScheduledExecutor, Logger) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatServices
-
Creates a heartbeat manager which does not actively send heartbeats.
- createHeartbeatManager(ResourceID, HeartbeatListener<I, O>, ScheduledExecutor, Logger) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatServicesImpl
- createHeartbeatManager(ResourceID, HeartbeatListener<I, O>, ScheduledExecutor, Logger) - Method in class org.apache.flink.runtime.heartbeat.NoOpHeartbeatServices
- createHeartbeatManagerSender(ResourceID, HeartbeatListener<I, O>, ScheduledExecutor, Logger) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatServices
-
Creates a heartbeat manager which actively sends heartbeats to monitoring targets.
- createHeartbeatManagerSender(ResourceID, HeartbeatListener<I, O>, ScheduledExecutor, Logger) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatServicesImpl
- createHeartbeatManagerSender(ResourceID, HeartbeatListener<I, O>, ScheduledExecutor, Logger) - Method in class org.apache.flink.runtime.heartbeat.NoOpHeartbeatServices
- createHeartbeatMonitor(ResourceID, HeartbeatTarget<O>, ScheduledExecutor, HeartbeatListener<?, O>, long, int) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatMonitor.Factory
-
Create heartbeat monitor heartbeat monitor.
- createHeartbeatServices(Configuration) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
- createHighAvailabilityServices(Configuration, Executor) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- createHighAvailabilityServices(Configuration, Executor, AddressResolution, RpcSystemUtils, FatalErrorHandler) - Static method in class org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
- createHistoryServerArchivist(Configuration, JsonArchivist, Executor) - Static method in interface org.apache.flink.runtime.dispatcher.HistoryServerArchivist
- createIn(File, String) - Static method in class org.apache.flink.runtime.entrypoint.WorkingDirectory
- createInput(InputFormat<OUT, ?>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Generic method to create an input data stream with
InputFormat. - createInput(InputFormat<OUT, ?>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Generic method to create an input data stream with
InputFormat. - createInputGate(List<IndexedInputGate>) - Static method in class org.apache.flink.streaming.runtime.io.InputGateUtil
- createInputGates(ShuffleIOOwnerContext, PartitionProducerStateProvider, List<InputGateDeploymentDescriptor>) - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
- createInputGates(ShuffleIOOwnerContext, PartitionProducerStateProvider, List<InputGateDeploymentDescriptor>) - Method in interface org.apache.flink.runtime.shuffle.ShuffleEnvironment
-
Factory method for the
InputGatesto consume result partitions. - createInputIterator(MutableReader<?>, TypeSerializerFactory<?>) - Method in class org.apache.flink.runtime.operators.BatchTask
- createInputProcessor(List<IndexedInputGate>[], StreamConfig.InputConfig[], WatermarkGauge[], Function<Integer, StreamPartitioner<?>>) - Method in class org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
- createInputProcessor(List<IndexedInputGate>, List<IndexedInputGate>, Function<Integer, StreamPartitioner<?>>) - Method in class org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
- createInputProcessor(List<IndexedInputGate>, List<IndexedInputGate>, Function<Integer, StreamPartitioner<?>>) - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
- createInstance() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
- createInstance() - Method in class org.apache.flink.runtime.state.JavaSerializer
- createInstance() - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
- createInstance() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
- createInstance() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
- createInstance() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
- createInstance() - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
- createInstance() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
- createInstance() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
- createInstance() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
- createInstance(Object...) - Method in class org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
- createInstance(ExecutionSlotAllocationContext) - Method in interface org.apache.flink.runtime.scheduler.ExecutionSlotAllocatorFactory
-
Instantiates the
ExecutionSlotAllocator. - createInstance(ExecutionSlotAllocationContext) - Method in class org.apache.flink.runtime.scheduler.SimpleExecutionSlotAllocator.Factory
- createInstance(ExecutionSlotAllocationContext) - Method in class org.apache.flink.runtime.scheduler.SlotSharingExecutionSlotAllocatorFactory
- createInstance(SchedulerOperations, SchedulingTopology) - Method in class org.apache.flink.runtime.scheduler.strategy.PipelinedRegionSchedulingStrategy.Factory
- createInstance(SchedulerOperations, SchedulingTopology) - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingStrategyFactory
- createInstance(SchedulerOperations, SchedulingTopology) - Method in class org.apache.flink.runtime.scheduler.strategy.VertexwiseSchedulingStrategy.Factory
- createInstance(SchedulingTopology) - Method in class org.apache.flink.runtime.executiongraph.failover.partitionrelease.NotReleasingPartitionGroupReleaseStrategy.Factory
- createInstance(SchedulingTopology) - Method in interface org.apache.flink.runtime.executiongraph.failover.partitionrelease.PartitionGroupReleaseStrategy.Factory
- createInstance(SchedulingTopology) - Method in class org.apache.flink.runtime.executiongraph.failover.partitionrelease.RegionPartitionGroupReleaseStrategy.Factory
- createInstance(SchedulingTopology, Function<ExecutionVertexID, Boolean>) - Method in class org.apache.flink.runtime.scheduler.strategy.AllFinishedInputConsumableDecider.Factory
- createInstance(SchedulingTopology, Function<ExecutionVertexID, Boolean>) - Method in class org.apache.flink.runtime.scheduler.strategy.DefaultInputConsumableDecider.Factory
- createInstance(SchedulingTopology, Function<ExecutionVertexID, Boolean>) - Method in interface org.apache.flink.runtime.scheduler.strategy.InputConsumableDecider.Factory
- createInstance(SchedulingTopology, Function<ExecutionVertexID, Boolean>) - Method in class org.apache.flink.runtime.scheduler.strategy.PartialFinishedInputConsumableDecider.Factory
- createInstance(Logger, JobGraph, Executor, Configuration, SlotPoolService, ScheduledExecutorService, ClassLoader, CheckpointRecoveryFactory, Duration, BlobWriter, JobManagerJobMetricGroup, Duration, ShuffleMaster<?>, JobMasterPartitionTracker, ExecutionDeploymentTracker, long, ComponentMainThreadExecutor, FatalErrorHandler, JobStatusListener, Collection<FailureEnricher>, BlocklistOperations) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveSchedulerFactory
- createInstance(Logger, JobGraph, Executor, Configuration, SlotPoolService, ScheduledExecutorService, ClassLoader, CheckpointRecoveryFactory, Duration, BlobWriter, JobManagerJobMetricGroup, Duration, ShuffleMaster<?>, JobMasterPartitionTracker, ExecutionDeploymentTracker, long, ComponentMainThreadExecutor, FatalErrorHandler, JobStatusListener, Collection<FailureEnricher>, BlocklistOperations) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.AdaptiveBatchSchedulerFactory
- createInstance(Logger, JobGraph, Executor, Configuration, SlotPoolService, ScheduledExecutorService, ClassLoader, CheckpointRecoveryFactory, Duration, BlobWriter, JobManagerJobMetricGroup, Duration, ShuffleMaster<?>, JobMasterPartitionTracker, ExecutionDeploymentTracker, long, ComponentMainThreadExecutor, FatalErrorHandler, JobStatusListener, Collection<FailureEnricher>, BlocklistOperations) - Method in class org.apache.flink.runtime.scheduler.DefaultSchedulerFactory
- createInstance(Logger, JobGraph, Executor, Configuration, SlotPoolService, ScheduledExecutorService, ClassLoader, CheckpointRecoveryFactory, Duration, BlobWriter, JobManagerJobMetricGroup, Duration, ShuffleMaster<?>, JobMasterPartitionTracker, ExecutionDeploymentTracker, long, ComponentMainThreadExecutor, FatalErrorHandler, JobStatusListener, Collection<FailureEnricher>, BlocklistOperations) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNGFactory
- createInstance(Logger, ExecutionSlotAllocator, ExecutionOperations, ExecutionVertexVersioner, Duration, BiConsumer<ExecutionVertexID, AllocationID>, ComponentMainThreadExecutor) - Method in class org.apache.flink.runtime.scheduler.DefaultExecutionDeployer.Factory
- createInstance(Logger, ExecutionSlotAllocator, ExecutionOperations, ExecutionVertexVersioner, Duration, BiConsumer<ExecutionVertexID, AllocationID>, ComponentMainThreadExecutor) - Method in interface org.apache.flink.runtime.scheduler.ExecutionDeployer.Factory
-
Instantiate an
ExecutionDeployerwith the given params. - createInternalClientSSLEngineFactory(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
Creates a SSLEngineFactory to be used by internal communication client endpoints.
- createInternalServerSSLEngineFactory(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
Creates a SSLEngineFactory to be used by internal communication server endpoints.
- createIterationSourceAndSink(int, int, int, long, int, int, ResourceSpec, ResourceSpec) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- createJobComponentFactory(ResourceManagerFactory<?>, JobGraphRetriever) - Static method in class org.apache.flink.runtime.entrypoint.component.DefaultDispatcherResourceManagerComponentFactory
- createJobEventWriterExecutor() - Method in class org.apache.flink.runtime.jobmaster.event.FileSystemJobEventStore
- createJobGraph(ClassLoader, StreamGraph, JobID) - Static method in class org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator
- createJobGraph(StreamGraph) - Static method in class org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator
- createJobGraphs(CuratorFramework, Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Creates a
DefaultJobGraphStoreinstance withZooKeeperStateHandleStore,ZooKeeperJobGraphStoreWatcherandZooKeeperJobGraphStoreUtil. - createJobGraphStore() - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
-
Create the submitted job graph store for the job manager.
- createJobGraphStore() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperLeaderElectionHaServices
- createJobGraphStore() - Method in class org.apache.flink.runtime.jobmanager.HaServicesJobPersistenceComponentFactory
- createJobGraphStore() - Method in interface org.apache.flink.runtime.jobmanager.JobPersistenceComponentFactory
-
Creates a
JobGraphStore. - createJobManagerMetricGroup(MetricRegistry, String) - Static method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
- createJobManagerRunner(JobGraph, Configuration, RpcService, HighAvailabilityServices, HeartbeatServices, JobManagerSharedServices, JobManagerJobMetricGroupFactory, FatalErrorHandler, Collection<FailureEnricher>, long) - Method in interface org.apache.flink.runtime.dispatcher.JobManagerRunnerFactory
- createJobManagerRunner(JobGraph, Configuration, RpcService, HighAvailabilityServices, HeartbeatServices, JobManagerSharedServices, JobManagerJobMetricGroupFactory, FatalErrorHandler, Collection<FailureEnricher>, long) - Method in enum org.apache.flink.runtime.dispatcher.JobMasterServiceLeadershipRunnerFactory
- createJobManagerWorkingDirectory(Configuration, DeterminismEnvelope<ResourceID>) - Static method in class org.apache.flink.runtime.entrypoint.ClusterEntrypointUtils
-
Creates the working directory for the JobManager process.
- createJobMasterService(UUID, OnCompletionActions) - Method in class org.apache.flink.runtime.jobmaster.factories.DefaultJobMasterServiceFactory
- createJobMasterService(UUID, OnCompletionActions) - Method in interface org.apache.flink.runtime.jobmaster.factories.JobMasterServiceFactory
-
Creates a new
JobMasterServicefor the given leaderSessionId and onCompletionActions. - createJobResultStore() - Method in class org.apache.flink.runtime.jobmanager.HaServicesJobPersistenceComponentFactory
- createJobResultStore() - Method in interface org.apache.flink.runtime.jobmanager.JobPersistenceComponentFactory
-
Creates
JobResultStoreinstances. - createJobRunner(JobGraphRetriever) - Static method in class org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherRunnerFactory
- createKeyedStateBackend(StateBackend.KeyedStateBackendParameters<K>) - Method in class org.apache.flink.runtime.state.AbstractManagedMemoryStateBackend
- createKeyedStateBackend(StateBackend.KeyedStateBackendParameters<K>) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
- createKeyedStateBackend(StateBackend.KeyedStateBackendParameters<K>) - Method in class org.apache.flink.runtime.state.hashmap.HashMapStateBackend
- createKeyedStateBackend(StateBackend.KeyedStateBackendParameters<K>) - Method in interface org.apache.flink.runtime.state.StateBackend
-
Creates a new
CheckpointableKeyedStateBackendthat is responsible for holding keyed state and checkpointing it. - createKeyedStateBackend(StateBackend.KeyedStateBackendParameters<K>) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionStateBackend
- createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
- createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - Method in class org.apache.flink.runtime.operators.sort.NonReusingMergeInnerJoinIterator
- createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - Method in class org.apache.flink.runtime.operators.sort.NonReusingMergeOuterJoinIterator
- createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - Method in class org.apache.flink.runtime.operators.sort.ReusingMergeInnerJoinIterator
- createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - Method in class org.apache.flink.runtime.operators.sort.ReusingMergeOuterJoinIterator
- createKeyGroupPartitionReader(KeyGroupPartitioner.ElementReaderFunction<T>, KeyGroupPartitioner.KeyGroupElementsConsumer<T>) - Static method in class org.apache.flink.runtime.state.KeyGroupPartitioner
- createKeyGroupPartitions(int, int) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
-
Groups the available set of key groups into key group partitions.
- createKnownInputChannel(SingleInputGate, int, int, NettyShuffleDescriptor, ResultSubpartitionIndexSet, SingleInputGateFactory.ChannelStatistics, InputChannelMetrics) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGateFactory
- createKvStateClientProxy(String, Iterator<Integer>, int, int, KvStateRequestStats) - Static method in class org.apache.flink.runtime.query.QueryableStateUtils
-
Initializes the
client proxyresponsible for receiving requests from the external (to the cluster) client and forwarding them internally. - createKVStateIterator() - Method in interface org.apache.flink.runtime.state.FullSnapshotResources
-
Returns a
KeyValueStateIteratorfor iterating over all key-value states for this snapshot resources. - createKvStateServer(String, Iterator<Integer>, int, int, KvStateRegistry, KvStateRequestStats) - Static method in class org.apache.flink.runtime.query.QueryableStateUtils
-
Initializes the
serverresponsible for sending the requested internal state to theclient proxy. - createKvStateTaskRegistry(JobID, JobVertexID) - Method in class org.apache.flink.runtime.taskexecutor.KvStateService
- createLeaderElection(String) - Method in class org.apache.flink.runtime.leaderelection.DefaultLeaderElectionService
- createLeaderElection(String) - Method in interface org.apache.flink.runtime.leaderelection.LeaderElectionService
-
Creates a new
LeaderElectioninstance that is registered to thisLeaderElectionServiceinstance. - createLeaderElectionService(String) - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
- createLeaderRetrievalDriver(LeaderRetrievalEventHandler, FatalErrorHandler) - Method in interface org.apache.flink.runtime.leaderretrieval.LeaderRetrievalDriverFactory
-
Create a specific
LeaderRetrievalDriverand start the necessary services. - createLeaderRetrievalDriver(LeaderRetrievalEventHandler, FatalErrorHandler) - Method in class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalDriverFactory
- createLeaderRetrievalDriverFactory(CuratorFramework) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Creates a
LeaderRetrievalDriverFactoryimplemented by ZooKeeper. - createLeaderRetrievalDriverFactory(CuratorFramework, String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Creates a
LeaderRetrievalDriverFactoryimplemented by ZooKeeper. - createLeaderRetrievalDriverFactory(CuratorFramework, String, Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Creates a
LeaderRetrievalDriverFactoryimplemented by ZooKeeper. - createLeaderRetrievalService() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
- createLeaderRetrievalService(String) - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
-
Create leader retrieval service with specified leaderName.
- createLeaderRetrievalService(String) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperLeaderElectionHaServices
- createLeaderRetrievalService(CuratorFramework) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Creates a
DefaultLeaderRetrievalServiceinstance withZooKeeperLeaderRetrievalDriver. - createLeaderRetrievalService(CuratorFramework, String, Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Creates a
DefaultLeaderRetrievalServiceinstance withZooKeeperLeaderRetrievalDriver. - createLocalEnvironment() - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a
LocalStreamEnvironment. - createLocalEnvironment(int) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a
LocalStreamEnvironment. - createLocalEnvironment(int, Configuration) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a
LocalStreamEnvironment. - createLocalEnvironment(Configuration) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a
LocalStreamEnvironment. - createLocalEnvironmentWithWebUI(Configuration) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a
LocalStreamEnvironmentfor local program execution that also starts the web monitoring UI. - createLocalRecoveryConfig() - Method in interface org.apache.flink.runtime.state.TaskStateManager
-
Returns the configuration for local recovery, i.e. the base directories for all file-based local state of the owning subtask and the general mode for local recovery.
- createLocalRecoveryConfig() - Method in class org.apache.flink.runtime.state.TaskStateManagerImpl
- createLocalResourceCleaner(ComponentMainThreadExecutor) - Method in class org.apache.flink.runtime.dispatcher.cleanup.DispatcherResourceCleanerFactory
- createLocalResourceCleaner(ComponentMainThreadExecutor) - Method in interface org.apache.flink.runtime.dispatcher.cleanup.ResourceCleanerFactory
-
Creates
ResourceCleanerthat initiatesLocallyCleanableResource.localCleanupAsync(JobID, Executor)calls. - createLocalRpcService(Configuration, RpcSystem) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
Factory method to instantiate the local RPC service.
- createLogicalFile(PhysicalFile, long, long, FileMergingSnapshotManager.SubtaskKey) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
-
Create a logical file on a physical file.
- createLogicalScope(CharacterFilter, char) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
- createLogicalScope(CharacterFilter, char) - Method in class org.apache.flink.runtime.metrics.groups.GenericValueMetricGroup
- createMainOutput(PushingAsyncDataInput.DataOutput<T>, TimestampsAndWatermarks.WatermarkUpdateListener) - Method in class org.apache.flink.streaming.api.operators.source.NoOpTimestampsAndWatermarks
- createMainOutput(PushingAsyncDataInput.DataOutput<T>, TimestampsAndWatermarks.WatermarkUpdateListener) - Method in class org.apache.flink.streaming.api.operators.source.ProgressiveTimestampsAndWatermarks
- createMainOutput(PushingAsyncDataInput.DataOutput<T>, TimestampsAndWatermarks.WatermarkUpdateListener) - Method in interface org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks
-
Creates the ReaderOutput for the source reader, than internally runs the timestamp extraction and watermark generation.
- createMasterAgent(TieredStorageResourceRegistry) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskTierFactory
- createMasterAgent(TieredStorageResourceRegistry) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory.MemoryTierFactory
- createMasterAgent(TieredStorageResourceRegistry) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierFactory
- createMasterAgent(TieredStorageResourceRegistry) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierFactory
-
Creates the master-side agent of a Tier.
- createMasterTriggerRestoreHook() - Method in interface org.apache.flink.streaming.api.checkpoint.WithMasterCheckpointHook
-
Creates the hook that should be called by the checkpoint coordinator.
- createMetadataOutputStream() - Method in interface org.apache.flink.runtime.state.CheckpointStorageLocation
-
Creates the output stream to persist the checkpoint metadata to.
- createMetadataOutputStream() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
- createMetadataOutputStream() - Method in class org.apache.flink.runtime.state.memory.NonPersistentMetadataCheckpointStorageLocation
- createMetadataOutputStream() - Method in class org.apache.flink.runtime.state.memory.PersistentMetadataCheckpointStorageLocation
- createMetricQueryService(RpcService, ResourceID, long) - Static method in class org.apache.flink.runtime.metrics.dump.MetricQueryService
-
Starts the MetricQueryService actor in the given actor system.
- createMetricRegistry(Configuration, long) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
Factory method to create the metric registry for the mini cluster.
- createMetricRegistry(Configuration, PluginManager, RpcSystemUtils) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
- createModule(SecurityConfiguration) - Method in class org.apache.flink.runtime.security.modules.HadoopModuleFactory
- createModule(SecurityConfiguration) - Method in class org.apache.flink.runtime.security.modules.JaasModuleFactory
- createModule(SecurityConfiguration) - Method in interface org.apache.flink.runtime.security.modules.SecurityModuleFactory
-
Creates and returns a
SecurityModule. - createModule(SecurityConfiguration) - Method in class org.apache.flink.runtime.security.modules.ZookeeperModuleFactory
- createNettyShuffleEnvironment(NettyShuffleEnvironmentConfiguration, ResourceID, TaskEventPublisher, ResultPartitionManager, ConnectionManager, MetricGroup, Executor, int, String[]) - Static method in class org.apache.flink.runtime.io.network.NettyShuffleServiceFactory
- createNettySSLHandler(ByteBufAllocator) - Method in class org.apache.flink.runtime.io.network.netty.SSLHandlerFactory
- createNettySSLHandler(ByteBufAllocator, String, int) - Method in class org.apache.flink.runtime.io.network.netty.SSLHandlerFactory
- createNewFreeSlotTrackerWithoutBlockedSlots(Set<AllocationID>) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultFreeSlotTracker
- createNewFreeSlotTrackerWithoutBlockedSlots(Set<AllocationID>) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.FreeSlotTracker
-
Create a new free slot tracker without blocked slots.
- createNewSpeculativeExecution(long) - Method in class org.apache.flink.runtime.executiongraph.SpeculativeExecutionVertex
- createNoOpEventTimeLogic(WatermarkStrategy<E>, MetricGroup, RelativeClock) - Static method in interface org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks
- createNoTransform() - Static method in interface org.apache.flink.runtime.state.StateSnapshotTransformer.StateSnapshotTransformFactory
- createNullable(Collection<ProfilingInfo>) - Static method in class org.apache.flink.runtime.rest.messages.ProfilingInfoList
- createOffCpuFlameGraph(VertexThreadInfoStats) - Static method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexFlameGraphFactory
-
Converts
VertexThreadInfoStatsinto a FlameGraph representing blocked (Off-CPU) threads. - createOnCpuFlameGraph(VertexThreadInfoStats) - Static method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexFlameGraphFactory
-
Converts
VertexThreadInfoStatsinto a FlameGraph representing actively running (On-CPU) threads. - createOperationKey(HandlerRequest<B>) - Method in class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.TriggerHandler
-
Create the operation key under which the result future of the asynchronous operation will be stored.
- createOperationKey(HandlerRequest<EmptyRequestBody>) - Method in class org.apache.flink.runtime.rest.handler.dataset.ClusterDataSetDeleteHandlers.ClusterDataSetDeleteTriggerHandler
- createOperationKey(HandlerRequest<EmptyRequestBody>) - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingTriggerHandler
- createOperationKey(HandlerRequest<SavepointDisposalRequest>) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalTriggerHandler
- createOperator(StreamOperatorFactory<OUT>, StreamTask<OUT, ?>, StreamConfig, Output<StreamRecord<OUT>>, OperatorEventDispatcher) - Static method in class org.apache.flink.streaming.api.operators.StreamOperatorFactoryUtil
-
Creates a new operator using a factory and makes sure that all special factory traits are properly handled.
- createOperatorCoordinatorHolder(SerializedValue<OperatorCoordinator.Provider>, ClassLoader, CoordinatorStore, JobManagerJobMetricGroup) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- createOperatorCoordinatorHolder(SerializedValue<OperatorCoordinator.Provider>, ClassLoader, CoordinatorStore, JobManagerJobMetricGroup) - Method in class org.apache.flink.runtime.executiongraph.SpeculativeExecutionJobVertex
- createOperatorStateBackend(StateBackend.OperatorStateBackendParameters) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
- createOperatorStateBackend(StateBackend.OperatorStateBackendParameters) - Method in class org.apache.flink.runtime.state.hashmap.HashMapStateBackend
- createOperatorStateBackend(StateBackend.OperatorStateBackendParameters) - Method in interface org.apache.flink.runtime.state.StateBackend
-
Creates a new
OperatorStateBackendthat can be used for storing operator state. - createOperatorStateBackend(StateBackend.OperatorStateBackendParameters) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionStateBackend
- createOrUpdate(String, TypeSerializer<T>) - Method in class org.apache.flink.runtime.state.HeapPriorityQueuesManager
- createOrUpdate(String, TypeSerializer<T>, boolean) - Method in class org.apache.flink.runtime.state.HeapPriorityQueuesManager
- createOrUpdateInternalState(TypeSerializer<N>, StateDescriptor<S, SV>) - Method in interface org.apache.flink.runtime.state.KeyedStateFactory
-
Creates or updates internal state and returns a new
InternalKvState. - createOrUpdateInternalState(TypeSerializer<N>, StateDescriptor<S, SV>, StateSnapshotTransformer.StateSnapshotTransformFactory<SEV>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
- createOrUpdateInternalState(TypeSerializer<N>, StateDescriptor<S, SV>, StateSnapshotTransformer.StateSnapshotTransformFactory<SEV>) - Method in interface org.apache.flink.runtime.state.KeyedStateFactory
-
Creates or updates internal state and returns a new
InternalKvState. - createOrUpdateInternalState(TypeSerializer<N>, StateDescriptor<S, SV>, StateSnapshotTransformer.StateSnapshotTransformFactory<SEV>) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
- createOrUpdateInternalState(TypeSerializer<N>, StateDescriptor<S, SV>, StateSnapshotTransformer.StateSnapshotTransformFactory<SEV>, boolean) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
- createOrUpdateInternalState(TypeSerializer<N>, StateDescriptor<S, SV>, StateSnapshotTransformer.StateSnapshotTransformFactory<SEV>, boolean) - Method in interface org.apache.flink.runtime.state.KeyedStateFactory
-
Creates or updates internal state and returns a new
InternalKvState. - createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.runtime.state.ArrayListSerializerSnapshot
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializerSnapshot
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerSnapshot
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializerSnapshot
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.streaming.api.operators.TimerSerializerSnapshot
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerSnapshot
- createPartitionFileReader(String) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.SegmentPartitionFile
- createPartitionFileReader(Path, ProducerMergedPartitionFileIndex) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.ProducerMergedPartitionFile
- createPartitionFileWriter(String, int) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.SegmentPartitionFile
- createPartitionFileWriter(Path, ProducerMergedPartitionFileIndex) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.ProducerMergedPartitionFile
- createPartitionRequestClient(ConnectionID) - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
-
Creates a
PartitionRequestClientinstance for the givenConnectionID. - createPartitionRequestClient(ConnectionID) - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
- createPartitionRequestClient(ConnectionID) - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
- createPartitions(int, int) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
- createPhysicalFile(FileMergingSnapshotManager.SubtaskKey, CheckpointedStateScope) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
-
Create a physical file in right location (managed directory), which is specified by scope of this checkpoint and current subtask.
- createPhysicalPool() - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
-
Create physical pool by filePoolType.
- createProcessingTimeService(MailboxExecutor) - Method in interface org.apache.flink.streaming.runtime.tasks.ProcessingTimeServiceFactory
-
Creates a new processing time service with the mailbox executor.
- createProducerAgent(int, int, TieredStoragePartitionId, String, boolean, TieredStorageMemoryManager, TieredStorageNettyService, TieredStorageResourceRegistry, BatchShuffleReadBufferPool, ScheduledExecutorService, List<TierShuffleDescriptor>, int, BufferCompressor) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskTierFactory
- createProducerAgent(int, int, TieredStoragePartitionId, String, boolean, TieredStorageMemoryManager, TieredStorageNettyService, TieredStorageResourceRegistry, BatchShuffleReadBufferPool, ScheduledExecutorService, List<TierShuffleDescriptor>, int, BufferCompressor) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory.MemoryTierFactory
- createProducerAgent(int, int, TieredStoragePartitionId, String, boolean, TieredStorageMemoryManager, TieredStorageNettyService, TieredStorageResourceRegistry, BatchShuffleReadBufferPool, ScheduledExecutorService, List<TierShuffleDescriptor>, int, BufferCompressor) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierFactory
- createProducerAgent(int, int, TieredStoragePartitionId, String, boolean, TieredStorageMemoryManager, TieredStorageNettyService, TieredStorageResourceRegistry, BatchShuffleReadBufferPool, ScheduledExecutorService, List<TierShuffleDescriptor>, int, BufferCompressor) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierFactory
-
Creates the producer-side agent of a Tier.
- createProgressiveEventTimeLogic(WatermarkStrategy<E>, MetricGroup, ProcessingTimeService, long, RelativeClock, Clock, TaskIOMetricGroup) - Static method in interface org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks
- createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Creates the metric query service scope for this group.
- createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.GenericMetricGroup
- createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.InternalOperatorMetricGroup
- createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
- createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerOperatorMetricGroup
- createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.JobMetricGroup
- createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
- createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
- createReader() - Method in class org.apache.flink.runtime.state.changelog.inmemory.InMemoryStateChangelogStorage
- createReader() - Method in interface org.apache.flink.runtime.state.changelog.StateChangelogStorageView
- createReadView(BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.PipelinedApproximateSubpartition
-
To simply the view releasing threading model,
PipelinedApproximateSubpartition.releaseView()is called only before creating a new view. - createReadView(BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartition
- createReadView(BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
- createRecordWriterDelegate(StreamConfig, Environment) - Static method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- createRecoveredCompletedCheckpointStore(JobID, int, SharedStateRegistryFactory, Executor, RecoveryClaimMode) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
-
Creates a RECOVERED
CompletedCheckpointStoreinstance for a job. - createRecoveredCompletedCheckpointStore(JobID, int, SharedStateRegistryFactory, Executor, RecoveryClaimMode) - Method in class org.apache.flink.runtime.checkpoint.PerJobCheckpointRecoveryFactory
- createRecoveredCompletedCheckpointStore(JobID, int, SharedStateRegistryFactory, Executor, RecoveryClaimMode) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
- createRecoveredCompletedCheckpointStore(JobID, int, SharedStateRegistryFactory, Executor, RecoveryClaimMode) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
- createRecursiveProductFieldAccessor(int, TypeInformation<T>, FieldAccessor<R, F>, ExecutionConfig) - Method in interface org.apache.flink.streaming.util.typeutils.ScalaProductFieldAccessorFactory
-
Returns a product
FieldAccessorthat does support recursion. - createRegisterTimerCallback(MailboxExecutor, TimerService) - Static method in class org.apache.flink.streaming.runtime.io.checkpointing.BarrierAlignmentUtil
- createRemoteEnvironment(String, int, int, String...) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a
RemoteStreamEnvironment. - createRemoteEnvironment(String, int, String...) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a
RemoteStreamEnvironment. - createRemoteEnvironment(String, int, Configuration, String...) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a
RemoteStreamEnvironment. - createRemoteRpcService(Configuration, String, int, RpcSystem) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
Factory method to instantiate the remote RPC service.
- createRemoteRpcService(Configuration, String, String, String, RpcSystem) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
Factory method to instantiate the remote RPC service.
- createResourceManager(Configuration, ResourceID, RpcService, UUID, HeartbeatServices, DelegationTokenManager, FatalErrorHandler, ClusterInformation, String, ResourceManagerMetricGroup, ResourceManagerRuntimeServices, Executor) - Method in class org.apache.flink.runtime.resourcemanager.active.ActiveResourceManagerFactory
- createResourceManager(Configuration, ResourceID, RpcService, UUID, HeartbeatServices, DelegationTokenManager, FatalErrorHandler, ClusterInformation, String, ResourceManagerMetricGroup, ResourceManagerRuntimeServices, Executor) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerFactory
- createResourceManager(Configuration, ResourceID, RpcService, UUID, HeartbeatServices, DelegationTokenManager, FatalErrorHandler, ClusterInformation, String, ResourceManagerMetricGroup, ResourceManagerRuntimeServices, Executor) - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManagerFactory
- createResourceManager(ResourceManagerProcessContext, UUID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerFactory
- createResourceManagerDriver(Configuration, String, String) - Method in class org.apache.flink.runtime.resourcemanager.active.ActiveResourceManagerFactory
- createResourceManagerProcessContext(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, DelegationTokenManager, FatalErrorHandler, ClusterInformation, String, MetricRegistry, String, Executor) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerFactory
- createResourceManagerRuntimeServicesConfiguration(Configuration) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerFactory
- createResourceManagerRuntimeServicesConfiguration(Configuration) - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManagerFactory
- createRestartBackoffTimeStrategyFactory(Configuration, Configuration, boolean) - Static method in class org.apache.flink.runtime.executiongraph.failover.RestartBackoffTimeStrategyFactoryLoader
-
Creates
RestartBackoffTimeStrategy.Factoryfrom the given configuration. - createRestClientSSLEngineFactory(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
Creates a
SSLHandlerFactoryto be used by the REST Clients. - createRestEndpoint(Configuration, LeaderGatewayRetriever<DispatcherGateway>, LeaderGatewayRetriever<ResourceManagerGateway>, TransientBlobService, ScheduledExecutorService, MetricFetcher, LeaderElection, FatalErrorHandler) - Method in enum org.apache.flink.runtime.rest.JobRestEndpointFactory
- createRestEndpoint(Configuration, LeaderGatewayRetriever<DispatcherGateway>, LeaderGatewayRetriever<ResourceManagerGateway>, TransientBlobService, ScheduledExecutorService, MetricFetcher, LeaderElection, FatalErrorHandler) - Method in interface org.apache.flink.runtime.rest.RestEndpointFactory
- createRestEndpoint(Configuration, LeaderGatewayRetriever<DispatcherGateway>, LeaderGatewayRetriever<ResourceManagerGateway>, TransientBlobService, ScheduledExecutorService, MetricFetcher, LeaderElection, FatalErrorHandler) - Method in enum org.apache.flink.runtime.rest.SessionRestEndpointFactory
- createRestNettySSLContext(Configuration, boolean, ClientAuth, SslProvider) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
Creates an SSL context for the external REST SSL.
- createRestServerSSLEngineFactory(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
Creates a
SSLHandlerFactoryto be used by the REST Servers. - createRestSSLContext(Configuration, boolean) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
Creates an SSL context for clients against the external REST endpoint.
- createResult(CommandLine) - Method in class org.apache.flink.runtime.entrypoint.ClusterConfigurationParserFactory
- createResult(CommandLine) - Method in class org.apache.flink.runtime.entrypoint.DynamicParametersConfigurationParserFactory
- createResult(CommandLine) - Method in class org.apache.flink.runtime.entrypoint.EntrypointClusterConfigurationParserFactory
- createResult(CommandLine) - Method in class org.apache.flink.runtime.entrypoint.ModifiableClusterConfigurationParserFactory
- createResult(CommandLine) - Method in interface org.apache.flink.runtime.entrypoint.parser.ParserResultFactory
-
Create the result of the command line argument parsing.
- createResultPartitionDeploymentDescriptor(IntermediateResultPartition, ShuffleDescriptor) - Static method in class org.apache.flink.runtime.executiongraph.Execution
- createResultPartitionId(IntermediateResultPartitionID) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- createResultPartitionWriters(ShuffleIOOwnerContext, List<ResultPartitionDeploymentDescriptor>) - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
- createResultPartitionWriters(ShuffleIOOwnerContext, List<ResultPartitionDeploymentDescriptor>) - Method in interface org.apache.flink.runtime.shuffle.ShuffleEnvironment
-
Factory method for the
ResultPartitionWritersto produce result partitions. - createResultSubpartitionView(TieredStoragePartitionId, TieredStorageSubpartitionId, BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.TieredStorageNettyServiceImpl
-
Create a
ResultSubpartitionViewfor the netty server. - createRetryStrategy(Configuration) - Method in enum org.apache.flink.runtime.dispatcher.cleanup.CleanupRetryStrategyFactory
-
Creates the
RetryStrategyinstance based on the passedConfiguration. - createRpcService() - Method in class org.apache.flink.runtime.minicluster.MiniCluster.CommonRpcServiceFactory
- createRpcService() - Method in class org.apache.flink.runtime.minicluster.MiniCluster.DedicatedRpcServiceFactory
- createRpcService() - Method in interface org.apache.flink.runtime.minicluster.MiniCluster.RpcServiceFactory
- createRuntimeContext() - Method in class org.apache.flink.runtime.operators.DataSinkTask
- createRuntimeContext() - Method in class org.apache.flink.runtime.operators.DataSourceTask
- createRuntimeContext(OperatorMetricGroup) - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
- createRuntimeContext(OperatorMetricGroup) - Method in class org.apache.flink.runtime.operators.BatchTask
- createSavepointLocation(FileSystem, Path) - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorageAccess
- createSavepointLocation(FileSystem, Path) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageAccess
- createSavepointLocation(FileSystem, Path) - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorageAccess
- createScheduler(Logger, JobGraph, Executor, Configuration, SlotPoolService, ScheduledExecutorService, ClassLoader, CheckpointRecoveryFactory, Duration, BlobWriter, JobManagerJobMetricGroup, Duration, ShuffleMaster<?>, JobMasterPartitionTracker, ExecutionDeploymentTracker, long, ComponentMainThreadExecutor, FatalErrorHandler, JobStatusListener, Collection<FailureEnricher>, BlocklistOperations) - Method in class org.apache.flink.runtime.jobmaster.DefaultSlotPoolServiceSchedulerFactory
- createScheduler(Logger, JobGraph, Executor, Configuration, SlotPoolService, ScheduledExecutorService, ClassLoader, CheckpointRecoveryFactory, Duration, BlobWriter, JobManagerJobMetricGroup, Duration, ShuffleMaster<?>, JobMasterPartitionTracker, ExecutionDeploymentTracker, long, ComponentMainThreadExecutor, FatalErrorHandler, JobStatusListener, Collection<FailureEnricher>, BlocklistOperations) - Method in interface org.apache.flink.runtime.jobmaster.SlotPoolServiceSchedulerFactory
-
Creates a
SchedulerNG. - createScheduler(Logger, JobGraph, ExecutionConfig, Executor, Configuration, ScheduledExecutorService, ClassLoader, CheckpointRecoveryFactory, Duration, BlobWriter, JobManagerJobMetricGroup, ShuffleMaster<?>, JobMasterPartitionTracker, ExecutionDeploymentTracker, long, ComponentMainThreadExecutor, JobStatusListener, Collection<FailureEnricher>, BlocklistOperations, ExecutionOperations, ExecutionSlotAllocatorFactory, RestartBackoffTimeStrategy, ScheduledExecutor, VertexParallelismAndInputInfosDecider, BatchJobRecoveryHandler) - Static method in class org.apache.flink.runtime.scheduler.adaptivebatch.AdaptiveBatchSchedulerFactory
- createSerializableExecutionGraphStore(Configuration, ScheduledExecutor) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
- createSerializableExecutionGraphStore(Configuration, ScheduledExecutor) - Method in class org.apache.flink.runtime.entrypoint.JobClusterEntrypoint
-
Deprecated.
- createSerializableExecutionGraphStore(Configuration, ScheduledExecutor) - Method in class org.apache.flink.runtime.entrypoint.SessionClusterEntrypoint
- createSerializer(SerializerConfig) - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
- createSerializer(SerializerConfig) - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
- createSerializerInstance(CompositeSerializer.PrecomputedParameters, TypeSerializer<?>...) - Method in class org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
- createServerSSLEngineFactory() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
- createSessionComponentFactory(ResourceManagerFactory<?>) - Static method in class org.apache.flink.runtime.entrypoint.component.DefaultDispatcherResourceManagerComponentFactory
- createSessionRunner(DispatcherFactory) - Static method in class org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherRunnerFactory
- createShuffleEnvironment(ShuffleEnvironmentContext) - Method in class org.apache.flink.runtime.io.network.NettyShuffleServiceFactory
- createShuffleEnvironment(ShuffleEnvironmentContext) - Method in interface org.apache.flink.runtime.shuffle.ShuffleServiceFactory
-
Factory method to create a specific local
ShuffleEnvironmentimplementation. - createShuffleIOOwnerContext(String, ExecutionAttemptID, MetricGroup) - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
- createShuffleIOOwnerContext(String, ExecutionAttemptID, MetricGroup) - Method in interface org.apache.flink.runtime.shuffle.ShuffleEnvironment
-
Create a context of the shuffle input/output owner used to create partitions or gates belonging to the owner.
- createShuffleIOOwnerMetricGroup(MetricGroup) - Static method in class org.apache.flink.runtime.io.network.metrics.NettyShuffleMetricFactory
- createShuffleMaster(ShuffleMasterContext) - Method in class org.apache.flink.runtime.io.network.NettyShuffleServiceFactory
- createShuffleMaster(ShuffleMasterContext) - Method in interface org.apache.flink.runtime.shuffle.ShuffleServiceFactory
-
Factory method to create a specific
ShuffleMasterimplementation. - createSimpleProductFieldAccessor(int, TypeInformation<T>, ExecutionConfig) - Method in interface org.apache.flink.streaming.util.typeutils.ScalaProductFieldAccessorFactory
-
Returns a product
FieldAccessorthat does not support recursion. - createSimpleStream(CheckpointedStateScope, CheckpointStreamFactory) - Static method in interface org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
- createSlotPoolService(JobID, DeclarativeSlotPoolFactory, ComponentMainThreadExecutor) - Method in class org.apache.flink.runtime.jobmaster.DefaultSlotPoolServiceSchedulerFactory
- createSlotPoolService(JobID, DeclarativeSlotPoolFactory, ComponentMainThreadExecutor) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolBridgeServiceFactory
- createSlotPoolService(JobID, DeclarativeSlotPoolFactory, ComponentMainThreadExecutor) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolServiceFactory
- createSlotPoolService(JobID, DeclarativeSlotPoolFactory, ComponentMainThreadExecutor) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolServiceFactory
- createSlotPoolService(JobID, DeclarativeSlotPoolFactory, ComponentMainThreadExecutor) - Method in interface org.apache.flink.runtime.jobmaster.SlotPoolServiceSchedulerFactory
-
Creates a
SlotPoolService. - createSlotReport(ResourceID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
- createSlotReport(ResourceID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- createSlotSharingSlotAllocator(DeclarativeSlotPool, boolean) - Static method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveSchedulerFactory
- createSlotSharingSlotAllocator(ReserveSlotFunction, FreeSlotFunction, IsSlotAvailableAndFreeFunction, boolean) - Static method in class org.apache.flink.runtime.scheduler.adaptive.allocator.SlotSharingSlotAllocator
- createSnapshot() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
-
Creates a new snapshot of the available stats.
- createSnapshot() - Method in class org.apache.flink.runtime.checkpoint.DefaultCheckpointStatsTracker
- createSnapshot() - Method in enum org.apache.flink.runtime.checkpoint.NoOpCheckpointStatsTracker
- createSnapshot() - Method in class org.apache.flink.runtime.checkpoint.StatsSummary
-
Returns a snapshot of the current state.
- createSnapshot() - Method in class org.apache.flink.runtime.io.network.metrics.ResultPartitionBytesCounter
- createSnapshot() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- createSolutionSetUpdateOutputCollector(Collector<OT>) - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
Creates a new solution set update output collector.
- createSparseArchivedExecutionGraph(JobID, String, JobStatus, JobType, Throwable, JobCheckpointingSettings, long) - Static method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
Create a sparse ArchivedExecutionGraph for a job.
- createSparseArchivedExecutionGraphWithJobVertices(JobID, String, JobStatus, JobType, Throwable, JobCheckpointingSettings, long, Iterable<JobVertex>, VertexParallelismStore) - Static method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
- createSSLClientSocketFactory(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
Creates a factory for SSL Client Sockets from the given configuration.
- createSSLServerSocketFactory(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
Creates a factory for SSL Server Sockets from the given configuration.
- createStartWorkerFailureRater(Configuration) - Static method in class org.apache.flink.runtime.resourcemanager.active.ActiveResourceManagerFactory
- createState(N, TypeSerializer<N>, StateDescriptor<SV>) - Method in interface org.apache.flink.runtime.state.AsyncKeyedStateBackend
-
Creates and returns a new state.
- createState(N, TypeSerializer<N>, StateDescriptor<SV>) - Method in class org.apache.flink.runtime.state.v2.adaptor.AsyncKeyedStateBackendAdaptor
- createStateAndWrapWithLatencyTrackingIfEnabled(InternalKvState<K, N, ?>, StateDescriptor<S, V>, LatencyTrackingStateConfig) - Static method in class org.apache.flink.runtime.state.metrics.LatencyTrackingStateFactory
-
Create latency tracking state if enabled.
- createStateAndWrapWithTtlIfEnabled(TypeSerializer<N>, StateDescriptor<S, SV>, KeyedStateBackend<K>, TtlTimeProvider) - Static method in class org.apache.flink.runtime.state.ttl.TtlStateFactory
- createStateExecutor() - Method in interface org.apache.flink.runtime.state.AsyncKeyedStateBackend
-
Creates a
StateExecutorwhich supports to execute a batch of state requests asynchronously. - createStateExecutor() - Method in class org.apache.flink.runtime.state.v2.adaptor.AsyncKeyedStateBackendAdaptor
- createStateMap() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
- createStateMap() - Method in class org.apache.flink.runtime.state.heap.StateTable
- createStateRegistryKey() - Method in class org.apache.flink.runtime.state.filemerging.DirectoryStreamStateHandle
- createStateRequestContainer() - Method in interface org.apache.flink.runtime.asyncprocessing.StateExecutor
-
Create a
StateRequestContainerwhich is used to hold the batchedStateRequest. - createStaticExternalResourceInfoProviderFromConfig(Configuration, PluginManager) - Static method in class org.apache.flink.runtime.externalresource.ExternalResourceUtils
-
Instantiate
StaticExternalResourceInfoProviderfor all of enabled external resources. - createStorage(JobID, Configuration, TaskManagerJobMetricGroup, LocalRecoveryConfig) - Method in class org.apache.flink.runtime.state.changelog.inmemory.InMemoryStateChangelogStorageFactory
- createStorage(JobID, Configuration, TaskManagerJobMetricGroup, LocalRecoveryConfig) - Method in interface org.apache.flink.runtime.state.changelog.StateChangelogStorageFactory
-
Create the storage based on a configuration.
- createStorageView(Configuration) - Method in class org.apache.flink.runtime.state.changelog.inmemory.InMemoryStateChangelogStorageFactory
- createStorageView(Configuration) - Method in interface org.apache.flink.runtime.state.changelog.StateChangelogStorageFactory
-
Create the storage for recovery.
- createStreamOperator(StreamOperatorParameters<Object>) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorFactory
- createStreamOperator(StreamOperatorParameters<CommittableMessage<CommT>>) - Method in class org.apache.flink.streaming.runtime.operators.sink.CommitterOperatorFactory
- createStreamOperator(StreamOperatorParameters<CommittableMessage<CommT>>) - Method in class org.apache.flink.streaming.runtime.operators.sink.SinkWriterOperatorFactory
- createStreamOperator(StreamOperatorParameters<OUT>) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
- createStreamOperator(StreamOperatorParameters<OUT>) - Method in interface org.apache.flink.streaming.api.operators.CoordinatedOperatorFactory
-
The implementation should return an instance of
OperatorEventHandler. - createStreamOperator(StreamOperatorParameters<OUT>) - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
- createStreamOperator(StreamOperatorParameters<OUT>) - Method in class org.apache.flink.streaming.api.operators.SourceOperatorFactory
- createStreamOperator(StreamOperatorParameters<OUT>) - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
-
Create the operator.
- createStreamOperator(StreamOperatorParameters<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorFactory
- createStreamOperator(StreamOperatorParameters<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorFactory
- createStreamOperator(StreamOperatorParameters<T>) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperatorFactory
- createStreamTaskStateInitializer(SubTaskInitializationMetricsBuilder) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- createSubpartitionView(int, BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.BufferWritingResultPartition
- createSubpartitionView(int, BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartition
- createSubpartitionView(int, BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Returns a reader for the subpartition with the given index.
- createSubpartitionView(int, BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.SortMergeResultPartition
- createSubpartitionView(ResultPartitionID, ResultSubpartitionIndexSet, BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
- createSubpartitionView(ResultPartitionID, ResultSubpartitionIndexSet, BufferAvailabilityListener) - Method in interface org.apache.flink.runtime.io.network.partition.ResultPartitionProvider
-
Returns the requested intermediate result partition input view.
- createSubpartitionView(ResultSubpartitionIndexSet, BufferAvailabilityListener) - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
Returns a reader for the subpartition with the given index range.
- createSubpartitionView(ResultSubpartitionIndexSet, BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- createSubpartitionViewOrRegisterListener(ResultPartitionID, ResultSubpartitionIndexSet, BufferAvailabilityListener, PartitionRequestListener) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
- createSubpartitionViewOrRegisterListener(ResultPartitionID, ResultSubpartitionIndexSet, BufferAvailabilityListener, PartitionRequestListener) - Method in interface org.apache.flink.runtime.io.network.partition.ResultPartitionProvider
-
If the upstream task's partition has been registered, returns the result subpartition input view immediately, otherwise register the listener and return empty.
- createSubWorkingDirectory(String) - Method in class org.apache.flink.runtime.entrypoint.WorkingDirectory
- createTaskExecutor(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, BlobCacheService, boolean, ExternalResourceInfoProvider, WorkingDirectory, FatalErrorHandler, DelegationTokenReceiverRepository) - Method in interface org.apache.flink.runtime.taskexecutor.TaskManagerRunner.TaskExecutorServiceFactory
- createTaskExecutorService(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, BlobCacheService, boolean, ExternalResourceInfoProvider, WorkingDirectory, FatalErrorHandler, DelegationTokenReceiverRepository) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
- createTaskManagerMetricGroup(MetricRegistry, String, ResourceID) - Static method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
- createTaskManagerWorkingDirectory(Configuration, DeterminismEnvelope<ResourceID>) - Static method in class org.apache.flink.runtime.entrypoint.ClusterEntrypointUtils
-
Creates the working directory for the TaskManager process.
- createTaskOwnedCheckpointStateToolset() - Method in interface org.apache.flink.runtime.state.CheckpointStorageWorkerView
-
A complementary method to
CheckpointStorageWorkerView.createTaskOwnedStateStream(). - createTaskOwnedCheckpointStateToolset() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageAccess
- createTaskOwnedCheckpointStateToolset() - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorageAccess
- createTaskOwnedStateStream() - Method in interface org.apache.flink.runtime.state.CheckpointStorageWorkerView
-
Opens a stream to persist checkpoint state data that is owned strictly by tasks and not attached to the life cycle of a specific checkpoint.
- createTaskOwnedStateStream() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageAccess
- createTaskOwnedStateStream() - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorageAccess
- createTaskRegistry(JobID, JobVertexID) - Method in class org.apache.flink.runtime.query.KvStateRegistry
-
Creates a
TaskKvStateRegistryfacade for theTaskidentified by the given JobID and JobVertexID instance. - createThreadDump() - Static method in class org.apache.flink.runtime.util.JvmUtils
-
Creates a thread dump of the current JVM.
- createThreadInfoSample(long, int) - Static method in class org.apache.flink.runtime.util.JvmUtils
-
Creates a
ThreadInfoSamplefor a specific thread. - createThreadInfoSample(Collection<Long>, int) - Static method in class org.apache.flink.runtime.util.JvmUtils
-
Creates a
ThreadInfoSamplefor a specific thread. - createTieredResultPartition(String, int, ResultPartitionID, ResultPartitionType, int, int, int, int, Boolean, ResultPartitionManager, BufferCompressor, List<TierShuffleDescriptor>, SupplierWithException<BufferPool, IOException>, FileChannelManager, BatchShuffleReadBufferPool, ScheduledExecutorService, boolean) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartitionFactory
- createTimestampAssigner(TimestampAssignerSupplier.Context) - Method in interface org.apache.flink.streaming.runtime.operators.util.WatermarkStrategyWithPeriodicWatermarks
- createTimestampAssigner(TimestampAssignerSupplier.Context) - Method in interface org.apache.flink.streaming.runtime.operators.util.WatermarkStrategyWithPunctuatedWatermarks
- createTmpFile(String, DistributedCache.DistributedCacheEntry, JobID, ExecutionAttemptID) - Method in class org.apache.flink.runtime.filecache.FileCache
-
If the file doesn't exists locally, retrieve the file from the blob-service.
- createTreeCache(CuratorFramework, String, TreeCacheSelector) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
- createTreeCache(CuratorFramework, String, RunnableWithException) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Creates a
TreeCachethat only observes a specific node. - createUnalignedCheckpointBarrierHandler(SubtaskCheckpointCoordinator, String, CheckpointableTask, Clock, boolean, CheckpointableInput...) - Static method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
- createUnregisteredJobManagerJobMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
- createUnregisteredJobManagerMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
- createUnregisteredJobManagerOperatorMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
- createUnregisteredOperatorMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
- createUnregisteredProcessMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
- createUnregisteredResourceManagerMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
- createUnregisteredSlotManagerMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
- createUnregisteredTaskManagerJobMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
- createUnregisteredTaskManagerMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
- createUnregisteredTaskMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
- createWatermarkGenerator(WatermarkGeneratorSupplier.Context) - Method in interface org.apache.flink.streaming.runtime.operators.util.WatermarkStrategyWithPeriodicWatermarks
- createWatermarkGenerator(WatermarkGeneratorSupplier.Context) - Method in interface org.apache.flink.streaming.runtime.operators.util.WatermarkStrategyWithPunctuatedWatermarks
- createWithEndOfStreamTrigger() - Static method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
-
Creates a
WindowAssignerthat assigns all elements to the sameGlobalWindowand the window is triggered if and only if the input stream is ended. - createWithSeparateOutputs(PushingAsyncDataInput.DataOutput<E>, WatermarkOutput, WatermarkOutput, TimestampAssigner<E>, WatermarkGenerator<E>) - Static method in class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
-
Creates a new SourceOutputWithWatermarks that emits records to the given DataOutput and watermarks to the different WatermarkOutputs.
- createWorksetUpdateOutputCollector() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
- createWorksetUpdateOutputCollector(Collector<OT>) - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
Creates a new
WorksetUpdateOutputCollector. - createWriter(String, KeyGroupRange, MailboxExecutor) - Method in class org.apache.flink.runtime.state.changelog.inmemory.InMemoryStateChangelogStorage
- createWriter(String, KeyGroupRange, MailboxExecutor) - Method in interface org.apache.flink.runtime.state.changelog.StateChangelogStorage
- createZooKeeperStateHandleStore(CuratorFramework, String, RetrievableStateStorageHelper<T>) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Creates an instance of
ZooKeeperStateHandleStore. - CreatingExecutionGraph - Class in org.apache.flink.runtime.scheduler.adaptive
-
State which waits for the creation of the
ExecutionGraph. - CreatingExecutionGraph(CreatingExecutionGraph.Context, CompletableFuture<CreatingExecutionGraph.ExecutionGraphWithVertexParallelism>, Logger, CreatingExecutionGraph.OperatorCoordinatorHandlerFactory, ExecutionGraph) - Constructor for class org.apache.flink.runtime.scheduler.adaptive.CreatingExecutionGraph
- CREATOR - org.apache.flink.runtime.util.ZooKeeperUtils.ZkClientACLMode
- CreditBasedInputBuffersUsageGauge - Class in org.apache.flink.runtime.io.network.metrics
-
Gauge metric measuring the input buffers usage for
SingleInputGates under credit based mode. - CreditBasedInputBuffersUsageGauge(FloatingBuffersUsageGauge, ExclusiveBuffersUsageGauge, SingleInputGate[]) - Constructor for class org.apache.flink.runtime.io.network.metrics.CreditBasedInputBuffersUsageGauge
- CrossDriver<T1,T2,OT> - Class in org.apache.flink.runtime.operators
-
Cross task which is executed by a Task Manager.
- CrossDriver() - Constructor for class org.apache.flink.runtime.operators.CrossDriver
- crossMatchingGroup(Iterator<T1>, Iterator<T2>, FlatJoinFunction<T1, T2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
- CuratorFrameworkWithUnhandledErrorListener - Class in org.apache.flink.runtime.highavailability.zookeeper
-
A wrapper for curatorFramework and unHandledErrorListener which should be unregister from curatorFramework before closing it.
- CuratorFrameworkWithUnhandledErrorListener(CuratorFramework, UnhandledErrorListener) - Constructor for class org.apache.flink.runtime.highavailability.zookeeper.CuratorFrameworkWithUnhandledErrorListener
- CURRENT_EMIT_EVENT_TIME_LAG - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- CURRENT_FETCH_EVENT_TIME_LAG - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- CURRENT_JOB_IDS_REST_PATH - Static variable in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
- CURRENT_SEND_TIME - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- CURRENT_STATE_META_INFO_SNAPSHOT_VERSION - Static variable in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshotReadersWriters
-
Current version for the serialization format of
StateMetaInfoSnapshotReadersWriters. - CurrentAttempts(int, Set<Integer>, boolean) - Constructor for class org.apache.flink.runtime.messages.webmonitor.JobDetails.CurrentAttempts
- currentBackoff - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
The current backoff (in ms).
- currentEnumerator - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The channel enumerator that is used while processing the current partition to create channels for the spill partitions it requires.
- currentInputWatermarkName(int) - Static method in class org.apache.flink.runtime.metrics.MetricNames
- currentIteration() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
- currentNamespace - Variable in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
The current namespace, which the access methods will refer to.
- currentParallelism() - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator.Context
-
Gets the current parallelism with which this operator is executed.
- currentParallelism() - Method in class org.apache.flink.runtime.operators.coordination.OperatorCoordinatorHolder
- currentParallelism() - Method in interface org.apache.flink.runtime.operators.coordination.OperatorInfo
- currentParallelism() - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinatorContext
- currentProcessingTime() - Method in interface org.apache.flink.streaming.api.functions.sink.legacy.SinkFunction.Context
-
Deprecated.Returns the current processing time.
- currentProcessingTime() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
- currentProcessingTime() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
-
Returns the current processing time.
- currentProcessingTime() - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
-
Returns the current processing time.
- currentProcessingTime() - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
- currentProcessingTime() - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
- currentProcessingTime() - Method in class org.apache.flink.streaming.api.SimpleTimerService
- currentProcessingTime() - Method in interface org.apache.flink.streaming.api.TimerService
-
Returns the current processing time.
- currentProcessingTime() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
- currentProcessingTime() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
- currentProcessingTime() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
- currentRecursionDepth - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The recursion depth of the partition that is currently processed.
- currentSchemaSerializer() - Method in class org.apache.flink.runtime.state.StateSerializerProvider
-
Gets the serializer that recognizes the current serialization schema of the state.
- currentTimestamp() - Method in interface org.apache.flink.runtime.state.ttl.TtlTimeProvider
- currentWatermark - Variable in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
-
The local event time, as denoted by the last received
Watermark. - currentWatermark() - Method in interface org.apache.flink.streaming.api.functions.sink.legacy.SinkFunction.Context
-
Deprecated.Returns the current event-time watermark.
- currentWatermark() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
- currentWatermark() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
-
Returns the current event-time watermark.
- currentWatermark() - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
-
Returns the current event-time watermark.
- currentWatermark() - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
- currentWatermark() - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
- currentWatermark() - Method in class org.apache.flink.streaming.api.SimpleTimerService
- currentWatermark() - Method in interface org.apache.flink.streaming.api.TimerService
-
Returns the current event-time watermark.
- currentWatermark() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
- currentWatermark() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
- currentWatermark() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
- CustomHeadersDecorator<R extends RequestBody,P extends ResponseBody,M extends MessageParameters> - Class in org.apache.flink.runtime.rest.messages
-
Decorator class for
MessageHeadersthat adds the ability to include custom HTTP headers. - CustomHeadersDecorator(MessageHeaders<R, P, M>) - Constructor for class org.apache.flink.runtime.rest.messages.CustomHeadersDecorator
-
Creates a new
CustomHeadersDecoratorfor a givenMessageHeadersobject. - CustomPartitionerWrapper<K,T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that selects the channel with a user defined partitioner function on a key.
- CustomPartitionerWrapper(Partitioner<K>, KeySelector<T, K>) - Constructor for class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
- CustomSinkOperatorUidHashes - Class in org.apache.flink.streaming.api.datastream
-
This class is responsible to hold operator Uid hashes from the common operators of the sink.
- CustomSinkOperatorUidHashes.SinkOperatorUidHashesBuilder - Class in org.apache.flink.streaming.api.datastream
-
Builder to construct
CustomSinkOperatorUidHashes.
D
- DamBehavior - Enum in org.apache.flink.runtime.operators
-
Enumeration for the different dam behaviors of an algorithm or a driver strategy.
- damOnInput(int) - Method in enum org.apache.flink.runtime.operators.DriverStrategy
- dams() - Method in enum org.apache.flink.runtime.operators.util.LocalStrategy
- DashboardConfigHandler - Class in org.apache.flink.runtime.rest.handler.cluster
-
Handler which returns the dashboard configuration.
- DashboardConfigHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, DashboardConfiguration, EmptyMessageParameters>, long, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.rest.handler.cluster.DashboardConfigHandler
- DashboardConfiguration - Class in org.apache.flink.runtime.rest.messages
-
Response of the
DashboardConfigHandlercontaining general configuration values such as the time zone and the refresh interval. - DashboardConfiguration(long, String, int, String, String, DashboardConfiguration.Features) - Constructor for class org.apache.flink.runtime.rest.messages.DashboardConfiguration
- DashboardConfiguration.Features - Class in org.apache.flink.runtime.rest.messages
-
Collection of features that are enabled/disabled.
- DashboardConfigurationHeaders - Class in org.apache.flink.runtime.rest.messages
-
Message headers for the
DashboardConfigHandler. - data - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputGate.InputWithData
- DATA_BUFFER - org.apache.flink.runtime.io.network.buffer.Buffer.DataType
-
Buffer.DataType.DATA_BUFFERindicates that this buffer represents a non-event data buffer. - DATA_BUFFER_WITH_CLEAR_END - org.apache.flink.runtime.io.network.buffer.Buffer.DataType
-
Buffer.DataType.DATA_BUFFER_WITH_CLEAR_ENDindicates that this buffer represents a non-event data buffer, and that at the end of this buffer there is no data cut and split into the next buffer. - DATA_FILE_SUFFIX - Static variable in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.ProducerMergedPartitionFile
- DATA_FILE_SUFFIX - Static variable in class org.apache.flink.runtime.io.network.partition.PartitionedFile
- DataBuffer - Interface in org.apache.flink.runtime.io.network.partition
-
Data of different subpartitions can be appended to a
DataBufferand after theDataBufferis full or finished, the appended data can be copied from it in subpartition index order. - DataInputStatus - Enum in org.apache.flink.streaming.runtime.io
-
It is an internal equivalent of
InputStatusthat provides additional non public statuses. - dataPort() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
Returns the port instance's task manager expects to receive transfer envelopes on.
- DataSetMetaInfo - Class in org.apache.flink.runtime.io.network.partition
-
Container for meta-data of a data set.
- datasets() - Method in interface org.apache.flink.streaming.api.lineage.LineageVertex
- DataSinkTask<IT> - Class in org.apache.flink.runtime.operators
-
DataSinkTask which is executed by a task manager.
- DataSinkTask(Environment) - Constructor for class org.apache.flink.runtime.operators.DataSinkTask
-
Create an Invokable task and set its environment.
- DataSourceTask<OT> - Class in org.apache.flink.runtime.operators
-
DataSourceTask which is executed by a task manager.
- DataSourceTask(Environment) - Constructor for class org.apache.flink.runtime.operators.DataSourceTask
-
Create an Invokable task and set its environment.
- DataStream<T> - Class in org.apache.flink.streaming.api.datastream
-
A DataStream represents a stream of elements of the same type.
- DataStream(StreamExecutionEnvironment, Transformation<T>) - Constructor for class org.apache.flink.streaming.api.datastream.DataStream
-
Create a new
DataStreamin the given execution environment with partitioning set to forward by default. - DataStream.Collector<T> - Class in org.apache.flink.streaming.api.datastream
-
This class acts as an accessor to elements collected via
DataStream.collectAsync(Collector). - DataStreamSink<T> - Class in org.apache.flink.streaming.api.datastream
-
A Stream Sink.
- DataStreamSink(PhysicalTransformation<T>) - Constructor for class org.apache.flink.streaming.api.datastream.DataStreamSink
- DataStreamSource<T> - Class in org.apache.flink.streaming.api.datastream
-
The DataStreamSource represents the starting point of a DataStream.
- DataStreamSource(SingleOutputStreamOperator<T>) - Constructor for class org.apache.flink.streaming.api.datastream.DataStreamSource
-
Constructor for "deep" sources that manually set up (one or more) custom configured complex operators.
- DataStreamSource(StreamExecutionEnvironment, TypeInformation<T>, StreamSource<T, ?>, boolean, String) - Constructor for class org.apache.flink.streaming.api.datastream.DataStreamSource
- DataStreamSource(StreamExecutionEnvironment, TypeInformation<T>, StreamSource<T, ?>, boolean, String, Boundedness) - Constructor for class org.apache.flink.streaming.api.datastream.DataStreamSource
-
The constructor used to create legacy sources.
- DataStreamSource(StreamExecutionEnvironment, Source<T, ?, ?>, WatermarkStrategy<T>, TypeInformation<T>, String) - Constructor for class org.apache.flink.streaming.api.datastream.DataStreamSource
-
Constructor for new Sources (FLIP-27).
- DeactivatedCheckpointCompletedCheckpointStore - Enum in org.apache.flink.runtime.checkpoint
-
This class represents a
CompletedCheckpointStoreif checkpointing has been disabled. - DeactivatedCheckpointIDCounter - Enum in org.apache.flink.runtime.checkpoint
-
This class represents a
CheckpointIDCounterif checkpointing is deactivated. - deallocate() - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- deallocate() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- dealWithResponse(CollectCoordinationResponse, long) - Method in class org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
- DEBLOATED_BUFFER_SIZE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- decideParallelismAndInputInfosForVertex(JobVertexID, List<BlockingResultInfo>, int, int, int) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DefaultVertexParallelismAndInputInfosDecider
- decideParallelismAndInputInfosForVertex(JobVertexID, List<BlockingResultInfo>, int, int, int) - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.VertexParallelismAndInputInfosDecider
-
Decide the parallelism and
JobVertexInputInfos for this job vertex. - DeclarativeSlotPool - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
Slot pool interface which uses Flink's declarative resource management protocol to acquire resources.
- DeclarativeSlotPool.NewSlotsListener - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
Listener interface for newly available slots.
- DeclarativeSlotPool.NoOpNewSlotsListener - Enum in org.apache.flink.runtime.jobmaster.slotpool
-
No-op
DeclarativeSlotPool.NewSlotsListenerimplementation. - DeclarativeSlotPoolBridge - Class in org.apache.flink.runtime.jobmaster.slotpool
-
SlotPoolimplementation which uses theDeclarativeSlotPoolto allocate slots. - DeclarativeSlotPoolBridge(JobID, DeclarativeSlotPoolFactory, Clock, Duration, Duration, Duration, RequestSlotMatchingStrategy, Duration, boolean, ComponentMainThreadExecutor) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolBridge
- DeclarativeSlotPoolBridgeServiceFactory - Class in org.apache.flink.runtime.jobmaster.slotpool
-
Factory for
DeclarativeSlotPoolBridge. - DeclarativeSlotPoolBridgeServiceFactory(Clock, Duration, Duration, Duration, Duration, boolean, RequestSlotMatchingStrategy) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolBridgeServiceFactory
- DeclarativeSlotPoolFactory - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
Factory for a
DeclarativeSlotPool. - DeclarativeSlotPoolService - Class in org.apache.flink.runtime.jobmaster.slotpool
-
SlotPoolServiceimplementation for theDeclarativeSlotPool. - DeclarativeSlotPoolService(JobID, DeclarativeSlotPoolFactory, Clock, Duration, Duration, Duration, ComponentMainThreadExecutor) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolService
- DeclarativeSlotPoolServiceFactory - Class in org.apache.flink.runtime.jobmaster.slotpool
-
Factory for the
DeclarativeSlotPoolService. - DeclarativeSlotPoolServiceFactory(Clock, Duration, Duration, Duration) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolServiceFactory
- declareRequiredResources(JobMasterId, ResourceRequirements, Duration) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- declareRequiredResources(JobMasterId, ResourceRequirements, Duration) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Declares the absolute resource requirements for a job.
- declareResourceNeeded(Collection<ResourceDeclaration>) - Method in class org.apache.flink.runtime.resourcemanager.active.ActiveResourceManager
- declareResourceNeeded(Collection<ResourceDeclaration>) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.NonSupportedResourceAllocatorImpl
- declareResourceNeeded(Collection<ResourceDeclaration>) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ResourceAllocator
-
declare resource need by slot manager.
- declareResourceRequirements(ResourceRequirements) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.DeclareResourceRequirementServiceConnectionManager
-
Declares the given resource requirements at the connected service.
- declareResourceRequirements(ResourceRequirements) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.DeclareResourceRequirementServiceConnectionManager.DeclareResourceRequirementsService
- declareResourceRequirements(ResourceRequirements) - Method in enum org.apache.flink.runtime.jobmaster.slotpool.NoOpDeclareResourceRequirementServiceConnectionManager
- DeclareResourceRequirementServiceConnectionManager - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
ServiceConnectionManagerfor declaring resource requirements. - DeclareResourceRequirementServiceConnectionManager.DeclareResourceRequirementsService - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
Service that accepts resource requirements.
- declineCheckpoint(long) - Method in class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask
- declineCheckpoint(long) - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
Deprecated.
- declineCheckpoint(long) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- declineCheckpoint(long, CheckpointException) - Method in interface org.apache.flink.runtime.execution.Environment
-
Declines a checkpoint.
- declineCheckpoint(long, CheckpointException) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- declineCheckpoint(JobID, ExecutionAttemptID, long, CheckpointException) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcCheckpointResponder
- declineCheckpoint(JobID, ExecutionAttemptID, long, CheckpointException) - Method in interface org.apache.flink.runtime.taskmanager.CheckpointResponder
-
Declines the given checkpoint.
- declineCheckpoint(DeclineCheckpoint) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointCoordinatorGateway
- declineCheckpoint(DeclineCheckpoint) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- declineCheckpoint(DeclineCheckpoint) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- declineCheckpoint(DeclineCheckpoint) - Method in class org.apache.flink.runtime.scheduler.ExecutionGraphHandler
- declineCheckpoint(DeclineCheckpoint) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- declineCheckpoint(DeclineCheckpoint) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
- DeclineCheckpoint - Class in org.apache.flink.runtime.messages.checkpoint
-
This message is sent from the
TaskExecutorto theJobMasterto tell the checkpoint coordinator that a checkpoint request could not be heeded. - DeclineCheckpoint(JobID, ExecutionAttemptID, long, CheckpointException) - Constructor for class org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.apache.flink.runtime.net.RedirectingSslHandler
- decode(ChannelHandlerContext, HttpObject, List<Object>) - Method in class org.apache.flink.runtime.rest.FlinkHttpObjectAggregator
- decodedPath() - Method in class org.apache.flink.runtime.rest.handler.router.RouteResult
-
Returns the decoded request path.
- decodePathFromReference(CheckpointStorageLocationReference) - Static method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorageAccess
-
Decodes the given reference into a path.
- decompress(byte[], int, int, byte[], int) - Method in class org.apache.flink.runtime.io.compression.AirBlockDecompressor
- decompress(byte[], int, int, byte[], int) - Method in interface org.apache.flink.runtime.io.compression.BlockDecompressor
-
Decompress source data read from src and write the decompressed data to dst.
- decompress(byte[], int, int, byte[], int) - Method in class org.apache.flink.runtime.io.compression.Lz4BlockDecompressor
- decompress(ByteBuffer, int, int, ByteBuffer, int) - Method in class org.apache.flink.runtime.io.compression.AirBlockDecompressor
- decompress(ByteBuffer, int, int, ByteBuffer, int) - Method in interface org.apache.flink.runtime.io.compression.BlockDecompressor
-
Decompress source data read from (
Buffer.position()+srcOff), and write the decompressed data to dst. - decompress(ByteBuffer, int, int, ByteBuffer, int) - Method in class org.apache.flink.runtime.io.compression.Lz4BlockDecompressor
- decompressToIntermediateBuffer(Buffer) - Method in class org.apache.flink.runtime.io.network.buffer.BufferDecompressor
-
Decompresses the given
BufferusingBlockDecompressor. - decompressToOriginalBuffer(Buffer) - Method in class org.apache.flink.runtime.io.network.buffer.BufferDecompressor
-
The difference between this method and
BufferDecompressor.decompressToIntermediateBuffer(Buffer)is that this method copies the decompressed data to the inputBufferstarting from offset 0. - decorateWithCompression(InputStream) - Method in class org.apache.flink.runtime.state.StreamCompressionDecorator
-
IMPORTANT: For streams returned by this method,
InputStream.close()is not propagated to the inner stream. - decorateWithCompression(OutputStream) - Method in class org.apache.flink.runtime.state.StreamCompressionDecorator
-
Decorates the stream by wrapping it into a stream that applies a compression.
- decorateWithCompression(NonClosingInputStreamDecorator) - Method in class org.apache.flink.runtime.state.SnappyStreamCompressionDecorator
- decorateWithCompression(NonClosingInputStreamDecorator) - Method in class org.apache.flink.runtime.state.StreamCompressionDecorator
- decorateWithCompression(NonClosingInputStreamDecorator) - Method in class org.apache.flink.runtime.state.UncompressedStreamCompressionDecorator
- decorateWithCompression(NonClosingOutputStreamDecorator) - Method in class org.apache.flink.runtime.state.SnappyStreamCompressionDecorator
- decorateWithCompression(NonClosingOutputStreamDecorator) - Method in class org.apache.flink.runtime.state.StreamCompressionDecorator
- decorateWithCompression(NonClosingOutputStreamDecorator) - Method in class org.apache.flink.runtime.state.UncompressedStreamCompressionDecorator
- decreaseResourceRequirementsBy(ResourceCounter) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPool
-
Decreases the resource requirements by decrement.
- decreaseResourceRequirementsBy(ResourceCounter) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultDeclarativeSlotPool
- decrementReference(BatchTask<?, ?>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
- decrementReferenceIfHeld(BatchTask<?, ?>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
- DEDICATED - org.apache.flink.runtime.minicluster.RpcServiceSharing
- DeduplicatedQueue<T> - Class in org.apache.flink.runtime.io.network.partition
-
A basic queue with duplicated elements ignored during
DeduplicatedQueue.add(Object). - DeduplicatedQueue() - Constructor for class org.apache.flink.runtime.io.network.partition.DeduplicatedQueue
- deepCopy() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
- deepCopy() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
- deepCopy() - Method in interface org.apache.flink.runtime.state.BackendWritableBroadcastState
- deepCopy() - Method in class org.apache.flink.runtime.state.HeapBroadcastState
- deepCopy() - Method in class org.apache.flink.runtime.state.PartitionableListState
- deepCopy() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
-
Creates a deep copy of the itself.
- deepCopy() - Method in class org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
-
Creates a deep copy of the itself.
- deepCopy() - Method in class org.apache.flink.runtime.state.RegisteredPriorityQueueStateBackendMetaInfo
- DEFAULT - Static variable in interface org.apache.flink.runtime.state.ttl.TtlTimeProvider
- DEFAULT - Static variable in class org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes
-
Default instance providing no custom sink operator hashes.
- DEFAULT_BATCH_JOB_NAME - Static variable in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
- DEFAULT_CAPACITY - Static variable in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
Default capacity for a
CopyOnWriteStateMap. - DEFAULT_CHAINING_STRATEGY - Static variable in enum org.apache.flink.streaming.api.operators.ChainingStrategy
- DEFAULT_FACTORY - Static variable in interface org.apache.flink.runtime.state.SharedStateRegistry
-
A singleton object for the default implementation of a
SharedStateRegistryFactory - DEFAULT_FILE_BUFFER_SIZE - Static variable in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
- DEFAULT_JOB_ID - Static variable in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
This JobID should be used to identify the old JobManager when using the
HighAvailabilityServices. - DEFAULT_LEADER_ID - Static variable in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
This UUID should be used when no proper leader election happens, but a simple pre-configured leader is used.
- DEFAULT_LOWER_BOUND_MAX_PARALLELISM - Static variable in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
-
The default lower bound for max parallelism if nothing was configured by the user.
- DEFAULT_LOWER_BOUND_MAX_PARALLELISM - Static variable in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
- DEFAULT_MAX_CACHE_NUM - Static variable in class org.apache.flink.streaming.api.operators.MapPartitionIterator
-
Max number of caches.
- DEFAULT_MAX_REQUIRED_BUFFERS_PER_GATE_FOR_BATCH - Static variable in class org.apache.flink.runtime.io.network.partition.consumer.InputGateSpecUtils
- DEFAULT_MAX_REQUIRED_BUFFERS_PER_GATE_FOR_STREAM - Static variable in class org.apache.flink.runtime.io.network.partition.consumer.InputGateSpecUtils
- DEFAULT_MAX_STATE_SIZE - Static variable in class org.apache.flink.runtime.state.storage.JobManagerCheckpointStorage
-
The default maximal size that the snapshotted memory state may have (5 MiBytes).
- DEFAULT_OPERATOR_STATE_NAME - Static variable in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
The default namespace for state in cases where no state name is provided
- DEFAULT_OUTPUT_FLUSH_THREAD_NAME - Static variable in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
Default name for the output flush thread, if no name with a task reference is given.
- DEFAULT_PAGE_SIZE - Static variable in class org.apache.flink.runtime.io.network.partition.PageSizeUtil
-
The default page size on most systems.
- DEFAULT_PAGE_SIZE - Static variable in class org.apache.flink.runtime.memory.MemoryManager
-
The default memory page size.
- DEFAULT_SLOT_SHARING_GROUP - Static variable in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
- DEFAULT_STREAMING_JOB_NAME - Static variable in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
- DEFAULT_THRESHOLD_FOR_SPILLING - Static variable in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
- DEFAULT_ZOOKEEPER_CLIENT_PORT - Static variable in class org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
-
ZooKeeper default client port.
- DEFAULT_ZOOKEEPER_INIT_LIMIT - Static variable in class org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
-
ZooKeeper default init limit.
- DEFAULT_ZOOKEEPER_LEADER_PORT - Static variable in class org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
-
ZooKeeper default leader port.
- DEFAULT_ZOOKEEPER_PEER_PORT - Static variable in class org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
-
ZooKeeper default peer port.
- DEFAULT_ZOOKEEPER_SYNC_LIMIT - Static variable in class org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
-
ZooKeeper default sync limit.
- DefaultAllocatedSlotPool - Class in org.apache.flink.runtime.jobmaster.slotpool
-
Default
AllocatedSlotPoolimplementation. - DefaultAllocatedSlotPool() - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.DefaultAllocatedSlotPool
- DefaultBatchJobRecoveryHandler - Class in org.apache.flink.runtime.scheduler.adaptivebatch
-
Default implementation of
BatchJobRecoveryHandlerandJobEventReplayHandler. - DefaultBatchJobRecoveryHandler(JobEventManager, Configuration) - Constructor for class org.apache.flink.runtime.scheduler.adaptivebatch.DefaultBatchJobRecoveryHandler
- DefaultBlocklistHandler - Class in org.apache.flink.runtime.blocklist
-
Default implementation of
BlocklistHandler. - DefaultBlocklistHandler.Factory - Class in org.apache.flink.runtime.blocklist
-
The factory to instantiate
DefaultBlocklistHandler. - DefaultBlocklistTracker - Class in org.apache.flink.runtime.blocklist
-
Default implementation of
BlocklistTracker. - DefaultBlocklistTracker() - Constructor for class org.apache.flink.runtime.blocklist.DefaultBlocklistTracker
- DefaultBroadcastVariableInitializer<T> - Class in org.apache.flink.runtime.broadcast
-
The default
BroadcastVariableInitializerimplementation that initializes the broadcast variable into a list. - DefaultCheckpointPlan - Class in org.apache.flink.runtime.checkpoint
-
The default implementation of he
CheckpointPlan. - DefaultCheckpointPlanCalculator - Class in org.apache.flink.runtime.checkpoint
-
Default implementation for
CheckpointPlanCalculator. - DefaultCheckpointPlanCalculator(JobID, CheckpointPlanCalculatorContext, Iterable<ExecutionJobVertex>, boolean) - Constructor for class org.apache.flink.runtime.checkpoint.DefaultCheckpointPlanCalculator
- DefaultCheckpointStatsTracker - Class in org.apache.flink.runtime.checkpoint
- DefaultCheckpointStatsTracker(int, JobManagerJobMetricGroup) - Constructor for class org.apache.flink.runtime.checkpoint.DefaultCheckpointStatsTracker
-
Creates a new checkpoint stats tracker.
- DefaultCheckpointStatsTracker(int, JobManagerJobMetricGroup, CheckpointStatsListener) - Constructor for class org.apache.flink.runtime.checkpoint.DefaultCheckpointStatsTracker
-
Creates a new checkpoint stats tracker.
- defaultClassLoaderFactory(FlinkUserCodeClassLoaders.ResolveOrder, String[], FatalErrorHandler, boolean) - Static method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
- DefaultClientHighAvailabilityServicesFactory - Class in org.apache.flink.runtime.highavailability
-
Default factory for creating client high availability services.
- DefaultClientHighAvailabilityServicesFactory() - Constructor for class org.apache.flink.runtime.highavailability.DefaultClientHighAvailabilityServicesFactory
- DefaultCompletedCheckpointStore<R extends ResourceVersion<R>> - Class in org.apache.flink.runtime.checkpoint
-
Default implementation of
CompletedCheckpointStore. - DefaultCompletedCheckpointStore(int, StateHandleStore<CompletedCheckpoint, R>, CheckpointStoreUtil, Collection<CompletedCheckpoint>, SharedStateRegistry, Executor) - Constructor for class org.apache.flink.runtime.checkpoint.DefaultCompletedCheckpointStore
-
Creates a
DefaultCompletedCheckpointStoreinstance. - DefaultCompletedCheckpointStoreUtils - Class in org.apache.flink.runtime.checkpoint
-
Helper methods related to
DefaultCompletedCheckpointStore. - defaultConfiguration() - Static method in class org.apache.flink.runtime.registration.RetryingRegistrationConfiguration
- DefaultDeclarativeSlotPool - Class in org.apache.flink.runtime.jobmaster.slotpool
-
Default
DeclarativeSlotPoolimplementation. - DefaultDeclarativeSlotPool(JobID, AllocatedSlotPool, Consumer<? super Collection<ResourceRequirement>>, Duration, Duration, Duration, ComponentMainThreadExecutor) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.DefaultDeclarativeSlotPool
- DefaultDeclarativeSlotPoolFactory - Class in org.apache.flink.runtime.jobmaster.slotpool
-
Factory for
DefaultDeclarativeSlotPool. - DefaultDeclarativeSlotPoolFactory() - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.DefaultDeclarativeSlotPoolFactory
- DefaultDelegationTokenManager - Class in org.apache.flink.runtime.security.token
-
Manager for delegation tokens in a Flink cluster.
- DefaultDelegationTokenManager(Configuration, PluginManager, ScheduledExecutor, ExecutorService) - Constructor for class org.apache.flink.runtime.security.token.DefaultDelegationTokenManager
- DefaultDelegationTokenManagerFactory - Class in org.apache.flink.runtime.security.token
-
A factory for
DefaultDelegationTokenManager. - DefaultDelegationTokenManagerFactory() - Constructor for class org.apache.flink.runtime.security.token.DefaultDelegationTokenManagerFactory
- DefaultDispatcherGatewayService - Class in org.apache.flink.runtime.dispatcher.runner
-
A facade over the
Dispatcherthat exposes specific functionality. - DefaultDispatcherResourceManagerComponentFactory - Class in org.apache.flink.runtime.entrypoint.component
-
Abstract class which implements the creation of the
DispatcherResourceManagerComponentcomponents. - DefaultDispatcherResourceManagerComponentFactory(DispatcherRunnerFactory, ResourceManagerFactory<?>, RestEndpointFactory<?>) - Constructor for class org.apache.flink.runtime.entrypoint.component.DefaultDispatcherResourceManagerComponentFactory
- DefaultDispatcherRunner - Class in org.apache.flink.runtime.dispatcher.runner
-
Runner for the
Dispatcherwhich is responsible for the leader election. - DefaultDispatcherRunnerFactory - Class in org.apache.flink.runtime.dispatcher.runner
-
DispatcherRunnerFactoryimplementation which createsDefaultDispatcherRunnerinstances. - DefaultDispatcherRunnerFactory(DispatcherLeaderProcessFactoryFactory) - Constructor for class org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherRunnerFactory
- DefaultExecutionDeployer - Class in org.apache.flink.runtime.scheduler
-
Default implementation of
ExecutionDeployer. - DefaultExecutionDeployer.Factory - Class in org.apache.flink.runtime.scheduler
-
Factory to instantiate the
DefaultExecutionDeployer. - DefaultExecutionDeploymentReconciler - Class in org.apache.flink.runtime.jobmaster
-
Default
ExecutionDeploymentReconcilerimplementation. - DefaultExecutionDeploymentReconciler(ExecutionDeploymentReconciliationHandler) - Constructor for class org.apache.flink.runtime.jobmaster.DefaultExecutionDeploymentReconciler
- DefaultExecutionDeploymentTracker - Class in org.apache.flink.runtime.jobmaster
-
Default
ExecutionDeploymentTrackerimplementation. - DefaultExecutionDeploymentTracker() - Constructor for class org.apache.flink.runtime.jobmaster.DefaultExecutionDeploymentTracker
- DefaultExecutionGraph - Class in org.apache.flink.runtime.executiongraph
-
Default implementation of the
ExecutionGraph. - DefaultExecutionGraph(JobType, JobInformation, ScheduledExecutorService, Executor, Duration, int, ClassLoader, BlobWriter, PartitionGroupReleaseStrategy.Factory, ShuffleMaster<?>, JobMasterPartitionTracker, ExecutionDeploymentListener, ExecutionStateUpdateListener, long, VertexAttemptNumberStore, VertexParallelismStore, boolean, ExecutionJobVertex.Factory, List<JobStatusHook>, MarkPartitionFinishedStrategy, TaskDeploymentDescriptorFactory, List<JobStatusChangedListener>) - Constructor for class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- DefaultExecutionGraphBuilder - Class in org.apache.flink.runtime.executiongraph
-
Utility class to encapsulate the logic of building an
DefaultExecutionGraphfrom aJobGraph. - DefaultExecutionGraphCache - Class in org.apache.flink.runtime.rest.handler.legacy
-
Default implementation of
ExecutionGraphCache. - DefaultExecutionGraphCache(Duration, Duration) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.DefaultExecutionGraphCache
- DefaultExecutionGraphFactory - Class in org.apache.flink.runtime.scheduler
-
Default
ExecutionGraphFactoryimplementation. - DefaultExecutionGraphFactory(Configuration, ClassLoader, ExecutionDeploymentTracker, ScheduledExecutorService, Executor, Duration, JobManagerJobMetricGroup, BlobWriter, ShuffleMaster<?>, JobMasterPartitionTracker) - Constructor for class org.apache.flink.runtime.scheduler.DefaultExecutionGraphFactory
- DefaultExecutionGraphFactory(Configuration, ClassLoader, ExecutionDeploymentTracker, ScheduledExecutorService, Executor, Duration, JobManagerJobMetricGroup, BlobWriter, ShuffleMaster<?>, JobMasterPartitionTracker, boolean, ExecutionJobVertex.Factory, boolean) - Constructor for class org.apache.flink.runtime.scheduler.DefaultExecutionGraphFactory
- DefaultExecutionOperations - Class in org.apache.flink.runtime.scheduler
-
Default implementation of
ExecutionOperations. - DefaultExecutionOperations() - Constructor for class org.apache.flink.runtime.scheduler.DefaultExecutionOperations
- DefaultExecutionTopology - Class in org.apache.flink.runtime.scheduler.adapter
-
Adapter of
ExecutionGraphtoSchedulingTopology. - DefaultFailureEnricherContext - Class in org.apache.flink.runtime.failure
-
The default implementation of
FailureEnricher.Contextclass. - DefaultFreeSlotTracker - Class in org.apache.flink.runtime.jobmaster.slotpool
-
Default implements of
FreeSlotTracker. - DefaultFreeSlotTracker(Set<AllocationID>, Function<AllocationID, PhysicalSlot>, Function<AllocationID, AllocatedSlotPool.FreeSlotInfo>, Function<ResourceID, Double>) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.DefaultFreeSlotTracker
- DefaultGroupCache<G,K,V> - Class in org.apache.flink.runtime.util
-
Default implement of
GroupCache. - DefaultGroupCache.Factory<G,K,V> - Class in org.apache.flink.runtime.util
-
The Factory of
DefaultGroupCache. - DefaultHeartbeatMonitor<O> - Class in org.apache.flink.runtime.heartbeat
-
The default implementation of
HeartbeatMonitor. - DefaultHostNameSupplier(InetAddress) - Constructor for class org.apache.flink.runtime.taskmanager.TaskManagerLocation.DefaultHostNameSupplier
- DefaultInMemorySorterFactory<T> - Class in org.apache.flink.runtime.operators.sort
-
Default factory for
InMemorySorter. - DefaultInMemorySorterFactory(TypeSerializer<T>, TypeComparator<T>, int) - Constructor for class org.apache.flink.runtime.operators.sort.DefaultInMemorySorterFactory
- DefaultInputConsumableDecider - Class in org.apache.flink.runtime.scheduler.strategy
-
Default implementation of
InputConsumableDecider. - DefaultInputConsumableDecider.Factory - Class in org.apache.flink.runtime.scheduler.strategy
-
Factory for
DefaultInputConsumableDecider. - DefaultJobGraphStore<R extends ResourceVersion<R>> - Class in org.apache.flink.runtime.jobmanager
-
Default implementation for
JobGraphStore. - DefaultJobGraphStore(StateHandleStore<JobGraph, R>, JobGraphStoreWatcher, JobGraphStoreUtil) - Constructor for class org.apache.flink.runtime.jobmanager.DefaultJobGraphStore
- DefaultJobLeaderIdService - Class in org.apache.flink.runtime.resourcemanager
-
Service which retrieves for a registered job the current job leader id (the leader id of the job manager responsible for the job).
- DefaultJobLeaderIdService(HighAvailabilityServices, ScheduledExecutor, Duration) - Constructor for class org.apache.flink.runtime.resourcemanager.DefaultJobLeaderIdService
- DefaultJobLeaderService - Class in org.apache.flink.runtime.taskexecutor
-
Default implementation of
JobLeaderService. - DefaultJobLeaderService(UnresolvedTaskManagerLocation, RetryingRegistrationConfiguration) - Constructor for class org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService
- DefaultJobManagerJobMetricGroupFactory - Class in org.apache.flink.runtime.jobmaster.factories
-
Default implementation of
JobManagerJobMetricGroupFactorywhich creates for a givenJobGraphaJobManagerJobMetricGroup. - DefaultJobManagerJobMetricGroupFactory(JobManagerMetricGroup) - Constructor for class org.apache.flink.runtime.jobmaster.factories.DefaultJobManagerJobMetricGroupFactory
- DefaultJobManagerRunnerRegistry - Class in org.apache.flink.runtime.dispatcher
-
DefaultJobManagerRunnerRegistryis the default implementation of theJobManagerRunnerRegistryinterface. - DefaultJobManagerRunnerRegistry(int) - Constructor for class org.apache.flink.runtime.dispatcher.DefaultJobManagerRunnerRegistry
- DefaultJobMasterServiceFactory - Class in org.apache.flink.runtime.jobmaster.factories
- DefaultJobMasterServiceFactory(Executor, RpcService, JobMasterConfiguration, JobGraph, HighAvailabilityServices, SlotPoolServiceSchedulerFactory, JobManagerSharedServices, HeartbeatServices, JobManagerJobMetricGroupFactory, FatalErrorHandler, ClassLoader, Collection<FailureEnricher>, long) - Constructor for class org.apache.flink.runtime.jobmaster.factories.DefaultJobMasterServiceFactory
- DefaultJobMasterServiceProcess - Class in org.apache.flink.runtime.jobmaster
-
Default
JobMasterServiceProcesswhich is responsible for creating and running aJobMasterService. - DefaultJobMasterServiceProcess(JobID, UUID, JobMasterServiceFactory, Function<Throwable, ArchivedExecutionGraph>) - Constructor for class org.apache.flink.runtime.jobmaster.DefaultJobMasterServiceProcess
- DefaultJobMasterServiceProcessFactory - Class in org.apache.flink.runtime.jobmaster.factories
- DefaultJobMasterServiceProcessFactory(JobID, String, JobType, JobCheckpointingSettings, long, JobMasterServiceFactory) - Constructor for class org.apache.flink.runtime.jobmaster.factories.DefaultJobMasterServiceProcessFactory
- DefaultJobTable - Class in org.apache.flink.runtime.taskexecutor
-
Default implementation of the
JobTable. - DefaultKeyedStateStore - Class in org.apache.flink.runtime.state
-
Default implementation of KeyedStateStore that currently forwards state registration to a
RuntimeContext. - DefaultKeyedStateStore(KeyedStateBackend<?>, SerializerFactory) - Constructor for class org.apache.flink.runtime.state.DefaultKeyedStateStore
- DefaultKeyedStateStoreV2 - Class in org.apache.flink.runtime.state.v2
-
Default implementation of KeyedStateStoreV2.
- DefaultKeyedStateStoreV2(AsyncKeyedStateBackend) - Constructor for class org.apache.flink.runtime.state.v2.DefaultKeyedStateStoreV2
- DefaultLastStateConnectionStateListener - Class in org.apache.flink.runtime.checkpoint
-
A simple ConnectionState listener that remembers the last state.
- DefaultLastStateConnectionStateListener() - Constructor for class org.apache.flink.runtime.checkpoint.DefaultLastStateConnectionStateListener
- defaultLatencyMeasurementInterval - Variable in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
-
Default timer interval in milliseconds for triggering mailbox latency measurement.
- DefaultLeaderElectionService - Class in org.apache.flink.runtime.leaderelection
-
Default implementation for leader election service.
- DefaultLeaderElectionService(LeaderElectionDriverFactory) - Constructor for class org.apache.flink.runtime.leaderelection.DefaultLeaderElectionService
- DefaultLeaderElectionService(LeaderElectionDriverFactory, FatalErrorHandler) - Constructor for class org.apache.flink.runtime.leaderelection.DefaultLeaderElectionService
- DefaultLeaderRetrievalService - Class in org.apache.flink.runtime.leaderretrieval
-
The counterpart to the
DefaultLeaderElectionService. - DefaultLeaderRetrievalService(LeaderRetrievalDriverFactory) - Constructor for class org.apache.flink.runtime.leaderretrieval.DefaultLeaderRetrievalService
-
Creates a default leader retrieval service with specified
LeaderRetrievalDriverFactory. - DefaultLineageDataset - Class in org.apache.flink.streaming.api.lineage
-
Default implementation for
LineageDataset. - DefaultLineageDataset(String, String, Map<String, LineageDatasetFacet>) - Constructor for class org.apache.flink.streaming.api.lineage.DefaultLineageDataset
- DefaultLineageEdge - Class in org.apache.flink.streaming.api.lineage
-
Implementation of LineageEdge.
- DefaultLineageEdge(SourceLineageVertex, LineageVertex) - Constructor for class org.apache.flink.streaming.api.lineage.DefaultLineageEdge
- DefaultLineageGraph - Class in org.apache.flink.streaming.api.lineage
-
Default implementation for
LineageGraph. - DefaultLineageGraph.LineageGraphBuilder - Class in org.apache.flink.streaming.api.lineage
-
Build the default lineage graph from
LineageEdge. - DefaultLogicalEdge - Class in org.apache.flink.runtime.jobgraph.topology
-
Default implementation of
LogicalEdge. - DefaultLogicalPipelinedRegion - Class in org.apache.flink.runtime.jobgraph.topology
-
Set of
LogicalVertexthat are connected through pipelinedLogicalResult. - DefaultLogicalPipelinedRegion(Set<? extends LogicalVertex>) - Constructor for class org.apache.flink.runtime.jobgraph.topology.DefaultLogicalPipelinedRegion
- DefaultLogicalResult - Class in org.apache.flink.runtime.jobgraph.topology
-
Default implementation of
LogicalResult. - DefaultLogicalTopology - Class in org.apache.flink.runtime.jobgraph.topology
-
Default implementation of
LogicalTopology. - DefaultLogicalVertex - Class in org.apache.flink.runtime.jobgraph.topology
-
Default implementation of
LogicalVertex. - DefaultMetricFilter - Class in org.apache.flink.runtime.metrics.filter
-
Default
MetricFilterimplementation that filters metrics based onMetricOptions.REPORTER_INCLUDES/MetricOptions.REPORTER_EXCLUDES. - DefaultOperatorCoordinatorHandler - Class in org.apache.flink.runtime.scheduler
-
Default handler for the
OperatorCoordinators. - DefaultOperatorCoordinatorHandler(ExecutionGraph, GlobalFailureHandler) - Constructor for class org.apache.flink.runtime.scheduler.DefaultOperatorCoordinatorHandler
- DefaultOperatorStateBackend - Class in org.apache.flink.runtime.state
-
Default implementation of OperatorStateStore that provides the ability to make snapshots.
- DefaultOperatorStateBackend(ExecutionConfig, CloseableRegistry, Map<String, PartitionableListState<?>>, Map<String, BackendWritableBroadcastState<?, ?>>, Map<String, PartitionableListState<?>>, Map<String, BackendWritableBroadcastState<?, ?>>, SnapshotStrategyRunner<OperatorStateHandle, ?>) - Constructor for class org.apache.flink.runtime.state.DefaultOperatorStateBackend
- DefaultOperatorStateBackendBuilder - Class in org.apache.flink.runtime.state
-
Builder class for
DefaultOperatorStateBackendwhich handles all necessary initializations and clean ups. - DefaultOperatorStateBackendBuilder(ClassLoader, ExecutionConfig, boolean, Collection<OperatorStateHandle>, CloseableRegistry) - Constructor for class org.apache.flink.runtime.state.DefaultOperatorStateBackendBuilder
- DefaultPartitionWithMetrics - Class in org.apache.flink.runtime.shuffle
-
Default
PartitionWithMetricsimplementation. - DefaultPartitionWithMetrics(ShuffleDescriptor, ShuffleMetrics) - Constructor for class org.apache.flink.runtime.shuffle.DefaultPartitionWithMetrics
- DefaultPreferredLocationsRetriever - Class in org.apache.flink.runtime.scheduler
-
Default implementation of
PreferredLocationsRetriever. - DefaultRequirementMatcher - Class in org.apache.flink.runtime.slots
-
Default implementation of
RequirementMatcher. - DefaultRequirementMatcher() - Constructor for class org.apache.flink.runtime.slots.DefaultRequirementMatcher
- DefaultResourceAllocationStrategy - Class in org.apache.flink.runtime.resourcemanager.slotmanager
-
The default implementation of
ResourceAllocationStrategy. - DefaultResourceAllocationStrategy(ResourceProfile, int, TaskManagerOptions.TaskManagerLoadBalanceMode, Duration, int, CPUResource, MemorySize) - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.DefaultResourceAllocationStrategy
- DefaultResourceCleaner<T> - Class in org.apache.flink.runtime.dispatcher.cleanup
-
DefaultResourceCleaneris the default implementation ofResourceCleaner. - DefaultResourceCleaner.Builder<T> - Class in org.apache.flink.runtime.dispatcher.cleanup
-
Builderfor creatingDefaultResourceCleanerinstances. - DefaultResourceTracker - Class in org.apache.flink.runtime.resourcemanager.slotmanager
-
Default
ResourceTrackerimplementation. - DefaultResourceTracker() - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.DefaultResourceTracker
- DefaultScheduler - Class in org.apache.flink.runtime.scheduler
-
The future default scheduler.
- DefaultScheduler(Logger, JobGraph, Executor, Configuration, Consumer<ComponentMainThreadExecutor>, ScheduledExecutor, ClassLoader, CheckpointsCleaner, CheckpointRecoveryFactory, JobManagerJobMetricGroup, SchedulingStrategyFactory, FailoverStrategy.Factory, RestartBackoffTimeStrategy, ExecutionOperations, ExecutionVertexVersioner, ExecutionSlotAllocatorFactory, long, ComponentMainThreadExecutor, JobStatusListener, Collection<FailureEnricher>, ExecutionGraphFactory, ShuffleMaster<?>, Duration, VertexParallelismStore, ExecutionDeployer.Factory) - Constructor for class org.apache.flink.runtime.scheduler.DefaultScheduler
- DefaultSchedulerComponents - Class in org.apache.flink.runtime.scheduler
-
Components to create a
DefaultScheduler. - DefaultSchedulerFactory - Class in org.apache.flink.runtime.scheduler
-
Factory for
DefaultScheduler. - DefaultSchedulerFactory() - Constructor for class org.apache.flink.runtime.scheduler.DefaultSchedulerFactory
- DefaultSchedulingPipelinedRegion - Class in org.apache.flink.runtime.scheduler.adapter
-
Default implementation of
SchedulingPipelinedRegion. - DefaultSchedulingPipelinedRegion(Set<DefaultExecutionVertex>, Function<IntermediateResultPartitionID, DefaultResultPartition>) - Constructor for class org.apache.flink.runtime.scheduler.adapter.DefaultSchedulingPipelinedRegion
- DefaultShuffleMasterSnapshotContext - Class in org.apache.flink.runtime.shuffle
-
Default
ShuffleMasterSnapshotContextimplementation. - DefaultShuffleMasterSnapshotContext() - Constructor for class org.apache.flink.runtime.shuffle.DefaultShuffleMasterSnapshotContext
- DefaultShuffleMetrics - Class in org.apache.flink.runtime.shuffle
-
Default
ShuffleMetricsimplementation. - DefaultShuffleMetrics(ResultPartitionBytes) - Constructor for class org.apache.flink.runtime.shuffle.DefaultShuffleMetrics
- DefaultSlotAssigner - Class in org.apache.flink.runtime.scheduler.adaptive.allocator
-
Simple
SlotAssignerthat treats all slots and slot sharing groups equally. - DefaultSlotAssigner() - Constructor for class org.apache.flink.runtime.scheduler.adaptive.allocator.DefaultSlotAssigner
- DefaultSlotPoolServiceSchedulerFactory - Class in org.apache.flink.runtime.jobmaster
-
Default
SlotPoolServiceSchedulerFactoryimplementation. - DefaultSlotStatusSyncer - Class in org.apache.flink.runtime.resourcemanager.slotmanager
-
Default implementation of
SlotStatusSyncerfor fine-grained slot management. - DefaultSlotStatusSyncer(Duration) - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.DefaultSlotStatusSyncer
- DefaultSpeculativeExecutionHandler - Class in org.apache.flink.runtime.scheduler.adaptivebatch
-
The default implementation of
SpeculativeExecutionHandler. - DefaultSpeculativeExecutionHandler(Configuration, BlocklistOperations, Function<ExecutionVertexID, ExecutionVertex>, Supplier<Map<ExecutionAttemptID, Execution>>, BiConsumer<List<Execution>, Collection<ExecutionVertexID>>, Logger) - Constructor for class org.apache.flink.runtime.scheduler.adaptivebatch.DefaultSpeculativeExecutionHandler
- DefaultStateTransitionManager - Class in org.apache.flink.runtime.scheduler.adaptive
-
DefaultStateTransitionManageris a state machine which manages theAdaptiveScheduler's state transitions based on the previous transition time and the available resources. - DefaultSubtaskAttemptNumberStore - Class in org.apache.flink.runtime.executiongraph
-
Simple container for subtask attempt counts backed by a list.
- DefaultSubtaskAttemptNumberStore(List<Integer>) - Constructor for class org.apache.flink.runtime.executiongraph.DefaultSubtaskAttemptNumberStore
- DefaultTimerService<K> - Class in org.apache.flink.runtime.taskexecutor.slot
-
Service to register timeouts for a given key.
- DefaultTimerService(ScheduledExecutorService, long) - Constructor for class org.apache.flink.runtime.taskexecutor.slot.DefaultTimerService
- DefaultVertexAttemptNumberStore - Class in org.apache.flink.runtime.executiongraph
-
Maintains the attempt number per subtask.
- DefaultVertexAttemptNumberStore() - Constructor for class org.apache.flink.runtime.executiongraph.DefaultVertexAttemptNumberStore
- DefaultVertexParallelismAndInputInfosDecider - Class in org.apache.flink.runtime.scheduler.adaptivebatch
-
Default implementation of
VertexParallelismAndInputInfosDecider. - DefaultVertexParallelismInfo - Class in org.apache.flink.runtime.scheduler
-
A
VertexParallelismInformationimplementation that provides common validation. - DefaultVertexParallelismInfo(int, int, int, Function<Integer, Optional<String>>) - Constructor for class org.apache.flink.runtime.scheduler.DefaultVertexParallelismInfo
- DefaultVertexParallelismInfo(int, int, Function<Integer, Optional<String>>) - Constructor for class org.apache.flink.runtime.scheduler.DefaultVertexParallelismInfo
-
Create
VertexParallelismInformationwith max parallelism rescaling validation for a vertex. - DefaultVertexParallelismStore - Class in org.apache.flink.runtime.scheduler
-
Maintains the configured parallelisms for vertices, which should be defined by a scheduler.
- DefaultVertexParallelismStore() - Constructor for class org.apache.flink.runtime.scheduler.DefaultVertexParallelismStore
- delegate - Variable in class org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
- DelegatingStateBackend - Interface in org.apache.flink.runtime.state.delegate
-
An interface to delegate state backend.
- DelegationTokenContainer - Class in org.apache.flink.runtime.security.token
-
Container for delegation tokens.
- DelegationTokenContainer() - Constructor for class org.apache.flink.runtime.security.token.DelegationTokenContainer
- DelegationTokenManager - Interface in org.apache.flink.runtime.security.token
-
Manager for delegation tokens in a Flink cluster.
- DelegationTokenManager.Listener - Interface in org.apache.flink.runtime.security.token
-
Listener for events in the
DelegationTokenManager. - DelegationTokenReceiverRepository - Class in org.apache.flink.runtime.security.token
-
Repository for delegation token receivers.
- DelegationTokenReceiverRepository(Configuration, PluginManager) - Constructor for class org.apache.flink.runtime.security.token.DelegationTokenReceiverRepository
- delegationTokensRequired() - Method in class org.apache.flink.runtime.security.token.hadoop.HadoopFSDelegationTokenProvider
- delegationTokensRequired() - Method in class org.apache.flink.runtime.security.token.hadoop.HBaseDelegationTokenProvider
- delete() - Method in class org.apache.flink.runtime.entrypoint.WorkingDirectory
- delete(JobID, BlobKey) - Method in interface org.apache.flink.runtime.blob.BlobStore
-
Tries to delete a blob from storage.
- delete(JobID, BlobKey) - Method in class org.apache.flink.runtime.blob.FileSystemBlobStore
- delete(JobID, BlobKey) - Method in class org.apache.flink.runtime.blob.VoidBlobStore
- DELETE - org.apache.flink.runtime.rest.HttpMethodWrapper
- DELETE_ON_COMMIT - Static variable in class org.apache.flink.runtime.highavailability.JobResultStoreOptions
- deleteAll(JobID) - Method in interface org.apache.flink.runtime.blob.BlobStore
-
Tries to delete all blobs for the given job from storage.
- deleteAll(JobID) - Method in class org.apache.flink.runtime.blob.FileSystemBlobStore
- deleteAll(JobID) - Method in class org.apache.flink.runtime.blob.VoidBlobStore
- deleteAllocationSnapshot(int) - Method in class org.apache.flink.runtime.taskexecutor.slot.FileSlotAllocationSnapshotPersistenceService
- deleteAllocationSnapshot(int) - Method in enum org.apache.flink.runtime.taskexecutor.slot.NoOpSlotAllocationSnapshotPersistenceService
- deleteAllocationSnapshot(int) - Method in interface org.apache.flink.runtime.taskexecutor.slot.SlotAllocationSnapshotPersistenceService
-
Delete the slot allocation snapshot identified by the slot index.
- deleteBlobs(List<PermanentBlobKey>) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- deleteBlobs(List<PermanentBlobKey>) - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
- deleteChannel() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
- deleteChannel() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
-
Deletes the file underlying this I/O channel.
- deleteChannel(FileIOChannel.ID) - Static method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Deletes the file underlying the given channel.
- deleteCleanupTimer(W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Deletes the cleanup timer set for the contents of the provided window.
- deleteDirectory(File) - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
Helper method to delete a directory.
- deleteEventTimeTimer(long) - Method in class org.apache.flink.streaming.api.SimpleTimerService
- deleteEventTimeTimer(long) - Method in interface org.apache.flink.streaming.api.TimerService
-
Deletes the event-time timer with the given trigger time.
- deleteEventTimeTimer(long) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Delete the event-time trigger for the given time.
- deleteEventTimeTimer(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
- deleteEventTimeTimer(N, long) - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
-
Deletes the timer for the given key and namespace.
- deleteEventTimeTimer(N, long) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
- deleteEventTimeTimer(N, long) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
- deleteFromCache(JobID, TransientBlobKey) - Method in class org.apache.flink.runtime.blob.BlobServer
-
Deletes the file associated with the blob key in the local storage of the blob server.
- deleteFromCache(JobID, TransientBlobKey) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
- deleteFromCache(JobID, TransientBlobKey) - Method in interface org.apache.flink.runtime.blob.TransientBlobService
-
Deletes the file associated with the provided job ID and blob key from the local cache.
- deleteFromCache(TransientBlobKey) - Method in class org.apache.flink.runtime.blob.BlobServer
-
Deletes the (job-unrelated) file associated with the blob key in the local storage of the blob server.
- deleteFromCache(TransientBlobKey) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
- deleteFromCache(TransientBlobKey) - Method in interface org.apache.flink.runtime.blob.TransientBlobService
-
Deletes the (job-unrelated) file associated with the provided blob key from the local cache.
- deleteIfNecessary() - Method in class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFile
-
Delete this physical file if there is no reference count from logical files (all discarded), and this physical file is closed (no further writing on it).
- deleteLeaderInformation(String) - Method in interface org.apache.flink.runtime.leaderelection.LeaderElectionDriver
-
Deletes the leader information for the given component.
- deleteLeaderInformation(String) - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionDriver
- deletePathQuietly(String) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.SegmentPartitionFile
- deletePermanent(JobID, PermanentBlobKey) - Method in class org.apache.flink.runtime.blob.BlobServer
-
Delete the uploaded data with the given
JobIDandPermanentBlobKey. - deletePermanent(JobID, PermanentBlobKey) - Method in interface org.apache.flink.runtime.blob.BlobWriter
-
Delete the uploaded data with the given
JobIDandPermanentBlobKey. - deletePermanent(JobID, PermanentBlobKey) - Method in class org.apache.flink.runtime.blob.VoidBlobWriter
- deletePhysicalFile(Path, long) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
-
Delete a physical file by given file path.
- deleteProcessingTimeTimer(long) - Method in class org.apache.flink.streaming.api.SimpleTimerService
- deleteProcessingTimeTimer(long) - Method in interface org.apache.flink.streaming.api.TimerService
-
Deletes the processing-time timer with the given trigger time.
- deleteProcessingTimeTimer(long) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Delete the processing time trigger for the given time.
- deleteProcessingTimeTimer(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
- deleteProcessingTimeTimer(N, long) - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
-
Deletes the timer for the given key and namespace.
- deleteProcessingTimeTimer(N, long) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
- deleteProcessingTimeTimer(N, long) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
- deleteQuietly() - Method in class org.apache.flink.runtime.io.network.partition.PartitionedFile
- deleteZNode(String) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperLeaderElectionHaServices
- deleteZNode(CuratorFramework, String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
- deliverCoordinationRequestToCoordinator(JobID, String, SerializedValue<CoordinationRequest>) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- deliverCoordinationRequestToCoordinator(JobID, String, SerializedValue<CoordinationRequest>, Duration) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- deliverCoordinationRequestToCoordinator(JobID, String, SerializedValue<CoordinationRequest>, Duration) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Deliver a coordination request to a specified coordinator and return the response.
- deliverCoordinationRequestToCoordinator(OperatorID, CoordinationRequest) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- deliverCoordinationRequestToCoordinator(OperatorID, CoordinationRequest) - Method in class org.apache.flink.runtime.scheduler.DefaultOperatorCoordinatorHandler
- deliverCoordinationRequestToCoordinator(OperatorID, CoordinationRequest) - Method in interface org.apache.flink.runtime.scheduler.OperatorCoordinatorHandler
-
Deliver coordination request from the client to the coordinator.
- deliverCoordinationRequestToCoordinator(OperatorID, CoordinationRequest) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- deliverCoordinationRequestToCoordinator(OperatorID, CoordinationRequest) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
-
Delivers a coordination request to the
OperatorCoordinatorwith the givenOperatorIDand returns the coordinator's response. - deliverCoordinationRequestToCoordinator(OperatorID, SerializedValue<CoordinationRequest>, Duration) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- deliverCoordinationRequestToCoordinator(OperatorID, SerializedValue<CoordinationRequest>, Duration) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Deliver a coordination request to a specified coordinator and return the response.
- deliverOperatorEvent(OperatorID, SerializedValue<OperatorEvent>) - Method in class org.apache.flink.runtime.taskmanager.Task
-
Dispatches an operator event to the invokable task.
- deliverOperatorEventToCoordinator(ExecutionAttemptID, OperatorID, OperatorEvent) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- deliverOperatorEventToCoordinator(ExecutionAttemptID, OperatorID, OperatorEvent) - Method in class org.apache.flink.runtime.scheduler.DefaultOperatorCoordinatorHandler
- deliverOperatorEventToCoordinator(ExecutionAttemptID, OperatorID, OperatorEvent) - Method in interface org.apache.flink.runtime.scheduler.OperatorCoordinatorHandler
-
Delivers an OperatorEvent to a
OperatorCoordinator. - deliverOperatorEventToCoordinator(ExecutionAttemptID, OperatorID, OperatorEvent) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- deliverOperatorEventToCoordinator(ExecutionAttemptID, OperatorID, OperatorEvent) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
-
Delivers the given OperatorEvent to the
OperatorCoordinatorwith the givenOperatorID. - deploy() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Deploys the execution to the previously assigned resource.
- deploy() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- deploy() - Method in class org.apache.flink.runtime.executiongraph.SpeculativeExecutionVertex
- deploy(Execution) - Method in class org.apache.flink.runtime.scheduler.DefaultExecutionOperations
- deploy(Execution) - Method in interface org.apache.flink.runtime.scheduler.ExecutionOperations
-
Deploy the execution.
- DEPLOYED - org.apache.flink.runtime.jobmaster.ExecutionDeploymentState
-
The deployment has been acknowledged by the TaskExecutor.
- DEPLOYING - org.apache.flink.runtime.execution.ExecutionState
- DeploymentStateTimeMetrics - Class in org.apache.flink.runtime.scheduler.metrics
-
Metrics that capture how long a job was deploying tasks.
- DeploymentStateTimeMetrics(JobType, MetricOptions.JobStatusMetricsSettings) - Constructor for class org.apache.flink.runtime.scheduler.metrics.DeploymentStateTimeMetrics
- deployToSlot(LogicalSlot) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- deployToSlot(LogicalSlot) - Method in class org.apache.flink.runtime.executiongraph.SpeculativeExecutionVertex
- deprecated() - Static method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
- DEPRECATED - org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureStatus
- DEPRECATED_FIELD_NAME_BACKPRESSURE_LEVEL - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
- DEPRECATED_FIELD_NAME_BACKPRESSURE_LEVEL - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
- deregisterApplication(ApplicationStatus, String) - Method in interface org.apache.flink.runtime.resourcemanager.active.ResourceManagerDriver
-
The deployment specific code to deregister the application.
- deregisterApplication(ApplicationStatus, String) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
Cleanup application and shut down cluster.
- deregisterApplication(ApplicationStatus, String) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Deregister Flink from the underlying resource management system.
- deregisterApplication(ApplicationStatus, String) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerService
-
Deregister the Flink application from the resource management system by signalling the
ResourceManager. - deregisterApplication(ApplicationStatus, String) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerServiceImpl
- deregisterBlocklistListener(BlocklistListener) - Method in interface org.apache.flink.runtime.blocklist.BlocklistHandler
-
Deregister a blocklist listener.
- deregisterBlocklistListener(BlocklistListener) - Method in class org.apache.flink.runtime.blocklist.DefaultBlocklistHandler
- deregisterBlocklistListener(BlocklistListener) - Method in class org.apache.flink.runtime.blocklist.NoOpBlocklistHandler
- deregisterExecution(Execution) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- deregisterExecution(Execution) - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
- deregisterKeySelectionListener(KeyedStateBackend.KeySelectionListener<K>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- deregisterKeySelectionListener(KeyedStateBackend.KeySelectionListener<K>) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
-
Stop calling listener registered in
KeyedStateBackend.registerKeySelectionListener(org.apache.flink.runtime.state.KeyedStateBackend.KeySelectionListener<K>). - deregisterKeySelectionListener(KeyedStateBackend.KeySelectionListener<K>) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
- deriveFromRequiredFineGrainedOptions(Configuration) - Method in interface org.apache.flink.runtime.util.config.memory.FlinkMemoryUtils
- deriveFromRequiredFineGrainedOptions(Configuration) - Method in class org.apache.flink.runtime.util.config.memory.jobmanager.JobManagerFlinkMemoryUtils
- deriveFromRequiredFineGrainedOptions(Configuration) - Method in class org.apache.flink.runtime.util.config.memory.taskmanager.TaskExecutorFlinkMemoryUtils
- deriveFromTotalFlinkMemory(Configuration, MemorySize) - Method in interface org.apache.flink.runtime.util.config.memory.FlinkMemoryUtils
- deriveFromTotalFlinkMemory(Configuration, MemorySize) - Method in class org.apache.flink.runtime.util.config.memory.jobmanager.JobManagerFlinkMemoryUtils
- deriveFromTotalFlinkMemory(Configuration, MemorySize) - Method in class org.apache.flink.runtime.util.config.memory.taskmanager.TaskExecutorFlinkMemoryUtils
- deriveJobStatus() - Method in enum org.apache.flink.runtime.clusterframework.ApplicationStatus
-
Derives the
JobStatusfrom theApplicationStatus. - deriveJvmMetaspaceAndOverheadFromTotalFlinkMemory(Configuration, MemorySize) - Method in class org.apache.flink.runtime.util.config.memory.ProcessMemoryUtils
- deriveWithFraction(String, MemorySize, RangeFraction) - Static method in class org.apache.flink.runtime.util.config.memory.ProcessMemoryUtils
- deriveWithInverseFraction(String, MemorySize, RangeFraction) - Static method in class org.apache.flink.runtime.util.config.memory.ProcessMemoryUtils
- DescriptiveStatisticsHistogram - Class in org.apache.flink.runtime.metrics
-
The
DescriptiveStatisticsHistogramuse a DescriptiveStatisticsDescriptiveStatisticsas a FlinkHistogram. - DescriptiveStatisticsHistogram(int) - Constructor for class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogram
- DescriptiveStatisticsHistogramStatistics - Class in org.apache.flink.runtime.metrics
-
DescriptiveStatistics histogram statistics implementation returned by
DescriptiveStatisticsHistogram. - DescriptiveStatisticsHistogramStatistics(double[]) - Constructor for class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
- DescriptiveStatisticsHistogramStatistics(DescriptiveStatisticsHistogram.CircularDoubleArray) - Constructor for class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
- deserializationDelegate - Variable in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
- DeserializationDelegate<T> - Interface in org.apache.flink.runtime.plugable
-
The deserialization delegate is used during deserialization to read an arbitrary element as if it implements
IOReadableWritable, with the help of a type serializer. - deserialize(byte[]) - Static method in class org.apache.flink.runtime.security.token.hadoop.HadoopDelegationTokenConverter
-
Deserializes delegation tokens.
- deserialize(byte[]) - Static method in class org.apache.flink.runtime.util.StateHandleStoreUtils
-
Deserializes the passed data into a
RetrievableStateHandle. - deserialize(int, byte[]) - Method in class org.apache.flink.runtime.jobmaster.event.GenericJobEventSerializer
- deserialize(int, byte[]) - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageSerializer
- deserialize(int, byte[]) - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollectorSerializer
- deserialize(DataInputStream, ClassLoader, String) - Method in interface org.apache.flink.runtime.checkpoint.metadata.MetadataSerializer
-
Deserializes a savepoint from an input stream.
- deserialize(DataInputStream, ClassLoader, String) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV1Serializer
- deserialize(DataInputStream, ClassLoader, String) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV2Serializer
- deserialize(DataInputStream, ClassLoader, String) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV3Serializer
- deserialize(DataInputStream, ClassLoader, String) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV4Serializer
- deserialize(ArrayList<T>, DataInputView) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.runtime.state.JavaSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
- deserialize(DataInputView) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
- deserialize(DataInputView) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
- deserialize(DataInputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
- deserialize(MetricDumpSerialization.MetricSerializationResult) - Method in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricDumpDeserializer
-
De-serializes metrics from the given byte array and returns them as a list of
MetricDump. - deserialize(VoidNamespace, DataInputView) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
- deserialize(JsonParser, DeserializationContext) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingModeDeserializer
- deserialize(JsonParser, DeserializationContext) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetricsResponseBody.Deserializer
- deserialize(JsonParser, DeserializationContext) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricCollectionResponseBody.Deserializer
- deserialize(JsonParser, DeserializationContext) - Method in class org.apache.flink.runtime.rest.messages.JobConfigInfo.Deserializer
- deserialize(JsonParser, DeserializationContext) - Method in class org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson.Deserializer
- deserialize(JsonParser, DeserializationContext) - Method in class org.apache.flink.runtime.rest.messages.json.JobIDDeserializer
- deserialize(JsonParser, DeserializationContext) - Method in class org.apache.flink.runtime.rest.messages.json.JobResultDeserializer
- deserialize(JsonParser, DeserializationContext) - Method in class org.apache.flink.runtime.rest.messages.json.JobVertexIDDeserializer
- deserialize(JsonParser, DeserializationContext) - Method in class org.apache.flink.runtime.rest.messages.json.RawJsonDeserializer
- deserialize(JsonParser, DeserializationContext) - Method in class org.apache.flink.runtime.rest.messages.json.ResourceIDDeserializer
- deserialize(JsonParser, DeserializationContext) - Method in class org.apache.flink.runtime.rest.messages.json.SerializedThrowableDeserializer
- deserialize(JsonParser, DeserializationContext) - Method in class org.apache.flink.runtime.rest.messages.json.SerializedValueDeserializer
- deserialize(JsonParser, DeserializationContext) - Method in class org.apache.flink.runtime.rest.messages.json.SlotSharingGroupIDDeserializer
- deserialize(JsonParser, DeserializationContext) - Method in class org.apache.flink.runtime.rest.messages.TriggerId.TriggerIdDeserializer
- deserialize(CoGroupedStreams.TaggedUnion<T1, T2>, DataInputView) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
- deserialize(IntervalJoinOperator.BufferEntry<T>, DataInputView) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
- deserialize(TimerHeapInternalTimer<K, N>, DataInputView) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
- deserialize(TimerHeapInternalTimer<K, N>, DataInputView) - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
- deserialize(GlobalWindow, DataInputView) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
- deserialize(TimeWindow, DataInputView) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
- deserialize(StreamElement, DataInputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
- deserialize(T, DataInputView) - Method in class org.apache.flink.runtime.state.JavaSerializer
- deserializeAccumulatorResult(byte[]) - Static method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
- deserializeInputChannelStateHandle(DataInputStream) - Static method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV3Serializer
- deserializeInputChannelStateHandle(DataInputStream, MetadataV2V3SerializerBase.DeserializationContext) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV2V3SerializerBase
- deserializeInputChannelStateHandle(DataInputStream, MetadataV2V3SerializerBase.DeserializationContext) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV3Serializer
- deserializeKey(String, DeserializationContext) - Method in class org.apache.flink.runtime.rest.messages.json.JobVertexIDKeyDeserializer
- deserializeKeyedStateHandleUtil(DataInputStream) - Static method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV3Serializer
- deserializeList(byte[], TypeSerializer<T>) - Method in class org.apache.flink.runtime.state.ListDelimitedSerializer
- deserializeMasterState(DataInputStream) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV2V3SerializerBase
- deserializeMetadata(DataInputStream, String) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV2V3SerializerBase
- deserializeNextElement(DataInputDeserializer, TypeSerializer<T>) - Static method in class org.apache.flink.runtime.state.ListDelimitedSerializer
-
Deserializes a single element from a serialized list.
- deserializeOperatorState(DataInputStream, MetadataV2V3SerializerBase.DeserializationContext) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV2Serializer
- deserializeOperatorState(DataInputStream, MetadataV2V3SerializerBase.DeserializationContext) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV2V3SerializerBase
- deserializeOperatorState(DataInputStream, MetadataV2V3SerializerBase.DeserializationContext) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV3Serializer
- deserializeOperatorState(DataInputStream, MetadataV2V3SerializerBase.DeserializationContext) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV5Serializer
- deserializeOperatorStateHandleUtil(DataInputStream) - Static method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV3Serializer
- Deserializer() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetricsResponseBody.Deserializer
- Deserializer() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.MetricCollectionResponseBody.Deserializer
- Deserializer() - Constructor for class org.apache.flink.runtime.rest.messages.JobConfigInfo.Deserializer
- Deserializer() - Constructor for class org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson.Deserializer
- deserializeResultSubpartitionStateHandle(DataInputStream) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV3Serializer
- deserializeResultSubpartitionStateHandle(DataInputStream, MetadataV2V3SerializerBase.DeserializationContext) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV2V3SerializerBase
- deserializeResultSubpartitionStateHandle(DataInputStream, MetadataV2V3SerializerBase.DeserializationContext) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV3Serializer
- deserializeStreamStateHandle(DataInputStream) - Static method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV3Serializer
- deserializeSubtaskIndexAndFinishedState(DataInputStream) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV3Serializer
- deserializeSubtaskState(DataInputStream, MetadataV2V3SerializerBase.DeserializationContext) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV2Serializer
- deserializeSubtaskState(DataInputStream, MetadataV2V3SerializerBase.DeserializationContext) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV2V3SerializerBase
- deserializeTaskStateSnapshot(SerializedValue<TaskStateSnapshot>, ClassLoader) - Static method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
- deserializeUserAccumulators(ClassLoader) - Method in class org.apache.flink.runtime.accumulators.AccumulatorSnapshot
-
Gets the user-defined accumulators values.
- destroy() - Method in class org.apache.flink.runtime.io.disk.BatchShuffleReadBufferPool
-
Destroys this buffer pool and after which, no buffer can be allocated any more.
- destroy() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
- destroyAllBufferPools() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
Destroys all buffer pools that allocate their buffers from this buffer pool (created via
NetworkBufferPool.createBufferPool(int, int)). - destroyBufferPool(BufferPool) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPoolFactory
-
Destroy callback for updating factory book keeping.
- destroyBufferPool(BufferPool) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
- DETACHED - org.apache.flink.runtime.entrypoint.ClusterEntrypoint.ExecutionMode
-
Directly stops after the job has finished.
- determineParallelism(JobInformation, Collection<? extends SlotInfo>) - Method in interface org.apache.flink.runtime.scheduler.adaptive.allocator.SlotAllocator
-
Determines the parallelism at which the vertices could be scheduled given the collection of slots.
- determineParallelism(JobInformation, Collection<? extends SlotInfo>) - Method in class org.apache.flink.runtime.scheduler.adaptive.allocator.SlotSharingSlotAllocator
- determineParallelismAndCalculateAssignment(JobInformation, Collection<? extends SlotInfo>, JobAllocationsInformation) - Method in interface org.apache.flink.runtime.scheduler.adaptive.allocator.SlotAllocator
-
Same as
SlotAllocator.determineParallelism(JobInformation, Collection)but additionally determine assignment of slots to execution slot sharing groups. - determineParallelismAndCalculateAssignment(JobInformation, Collection<? extends SlotInfo>, JobAllocationsInformation) - Method in class org.apache.flink.runtime.scheduler.adaptive.allocator.SlotSharingSlotAllocator
- DeterminismEnvelope<T> - Class in org.apache.flink.runtime.entrypoint
-
Envelope that carries whether the wrapped value is deterministic or not.
- deterministicValue(T) - Static method in class org.apache.flink.runtime.entrypoint.DeterminismEnvelope
- directory - Variable in class org.apache.flink.runtime.state.SnapshotDirectory
-
This path describes the underlying directory for the snapshot.
- DirectoryStateHandle - Class in org.apache.flink.runtime.state
-
This state handle represents a directory.
- DirectoryStateHandle(Path, long) - Constructor for class org.apache.flink.runtime.state.DirectoryStateHandle
- DirectoryStreamStateHandle - Class in org.apache.flink.runtime.state.filemerging
-
This state handle represents a directory, usually used to be registered to
SharedStateRegistryto track the life cycle of the directory. - DirectoryStreamStateHandle(Path) - Constructor for class org.apache.flink.runtime.state.filemerging.DirectoryStreamStateHandle
- disableBatchSlotRequestTimeoutCheck() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolBridge
- disableBatchSlotRequestTimeoutCheck() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlotProvider
-
Disables batch slot request timeout check.
- disableBatchSlotRequestTimeoutCheck() - Method in class org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlotProviderImpl
- disableBatchSlotRequestTimeoutCheck() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Disables batch slot request timeout check.
- disableChaining() - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Turns off chaining for this operator so thread co-location will not be used as an optimization.
- disableChaining() - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Turns off chaining for this operator so thread co-location will not be used as an optimization.
- disableCheckpointing() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Disables checkpointing.
- disabled() - Static method in class org.apache.flink.runtime.state.metrics.LatencyTrackingStateConfig
- disabled() - Static method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
-
Gets the configuration describing the queryable state as deactivated.
- disabled() - Static method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexFlameGraph
- DISABLED_CHECKPOINT_INTERVAL - Static variable in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
- disabledHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>) - Static method in class org.apache.flink.runtime.rest.handler.job.JobVertexFlameGraphHandler
- disableOperatorChaining() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Disables operator chaining for streaming operators.
- disableUnalignedCheckpoints() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardForConsecutiveHashPartitioner
- disableUnalignedCheckpoints() - Method in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
- discard() - Method in interface org.apache.flink.runtime.checkpoint.Checkpoint.DiscardObject
- discard() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint.CompletedCheckpointDiscardObject
- discard() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint.PendingCheckpointDiscardObject
-
Discard state.
- discard(Throwable) - Method in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator.PendingStatsRequest
- discardAsync(Executor) - Method in interface org.apache.flink.runtime.checkpoint.Checkpoint.DiscardObject
- discardAsync(Executor) - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint.CompletedCheckpointDiscardObject
- discardAsync(Executor) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint.PendingCheckpointDiscardObject
- discardCheckpoint(long) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
-
The callback which will be triggered when all subtasks discarded (aborted or subsumed).
- discardCheckpoint(long) - Method in class org.apache.flink.runtime.checkpoint.filemerging.WithinCheckpointFileMergingSnapshotManager
- DISCARDED - org.apache.flink.runtime.checkpoint.PendingCheckpoint.TaskAcknowledgeResult
- discardExecutor - Variable in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
Executor that runs the discarding of released state objects.
- discardSingleLogicalFile(LogicalFile, long) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
- discardState() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- discardState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
- discardState() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- discardState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
Deprecated.
- discardState() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- discardState() - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
- discardState() - Method in class org.apache.flink.runtime.state.AbstractChannelStateHandle
- discardState() - Method in class org.apache.flink.runtime.state.ChainedStateHandle
- discardState() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl
- discardState() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendLocalHandle
- discardState() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateHandleStreamImpl
- discardState() - Method in class org.apache.flink.runtime.state.changelog.inmemory.InMemoryChangelogStateHandle
- discardState() - Method in class org.apache.flink.runtime.state.DirectoryStateHandle
- discardState() - Method in class org.apache.flink.runtime.state.filemerging.DirectoryStreamStateHandle
- discardState() - Method in class org.apache.flink.runtime.state.filemerging.FileMergingOperatorStreamStateHandle
- discardState() - Method in class org.apache.flink.runtime.state.filemerging.SegmentFileStateHandle
-
This method should be empty, so that JM is not in charge of the lifecycle of files in a file-merging checkpoint.
- discardState() - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
-
Discard the state by deleting the file that stores the state.
- discardState() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
- discardState() - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
- discardState() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
- discardState() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
- discardState() - Method in class org.apache.flink.runtime.state.OperatorStreamStateHandle
- discardState() - Method in class org.apache.flink.runtime.state.PlaceholderStreamStateHandle
- discardState() - Method in class org.apache.flink.runtime.state.RetrievableStreamStateHandle
- discardState() - Method in class org.apache.flink.runtime.state.SharedStateRegistryImpl.EmptyDiscardStateObjectForRegister
- discardState() - Method in class org.apache.flink.runtime.state.SnapshotResult
- discardState() - Method in interface org.apache.flink.runtime.state.StateObject
-
Discards the state referred to and solemnly owned by this handle, to free up resources in the persistent storage.
- discardStateFuture(Future<? extends StateObject>) - Static method in class org.apache.flink.runtime.state.StateUtil
-
Discards the given state future by first trying to cancel it.
- discardStateObjectQuietly(StateObject) - Static method in class org.apache.flink.runtime.state.StateUtil
- discardUpToCheckpoint(long) - Method in interface org.apache.flink.runtime.state.changelog.LocalChangelogRegistry
-
Called upon ChangelogKeyedStateBackend#notifyCheckpointComplete and ChangelogKeyedStateBackend#notifyCheckpointSubsumed.
- discardUpToCheckpoint(long) - Method in class org.apache.flink.runtime.state.changelog.LocalChangelogRegistryImpl
- discardWithCheckpointId(long) - Method in class org.apache.flink.runtime.checkpoint.filemerging.LogicalFile
-
When a checkpoint that uses this logical file is subsumed or aborted, discard this logical file.
- disconnect() - Method in interface org.apache.flink.runtime.jobmaster.ServiceConnectionManager
-
Disconnect from the current service.
- disconnect() - Method in class org.apache.flink.runtime.jobmaster.slotpool.AbstractServiceConnectionManager
- disconnect() - Method in enum org.apache.flink.runtime.jobmaster.slotpool.NoOpDeclareResourceRequirementServiceConnectionManager
- disconnect() - Method in interface org.apache.flink.runtime.taskexecutor.JobTable.Connection
-
Disconnects the connection, closing all associated services thereby and returning the remaining job.
- disconnectJobManager(JobID, Exception) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- disconnectJobManager(JobID, Exception) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Disconnects the given JobManager from the TaskManager.
- disconnectJobManager(JobID, Exception) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- disconnectJobManager(JobID, JobStatus, Exception) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- disconnectJobManager(JobID, JobStatus, Exception) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Disconnects a JobManager specified by the given resourceID from the
ResourceManager. - disconnectResourceManager() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolService
- disconnectResourceManager() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Disconnects the slot pool from its current Resource Manager.
- disconnectResourceManager() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolService
-
Disconnects the slot pool from its current Resource Manager.
- disconnectResourceManager(Exception) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- disconnectResourceManager(Exception) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Disconnects the ResourceManager from the TaskManager.
- disconnectResourceManager(Exception) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- disconnectResourceManager(ResourceManagerId, Exception) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- disconnectResourceManager(ResourceManagerId, Exception) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Disconnects the resource manager from the job manager because of the given cause.
- disconnectTaskManager(ResourceID, Exception) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- disconnectTaskManager(ResourceID, Exception) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Disconnects the given
TaskExecutorfrom theJobMaster. - disconnectTaskManager(ResourceID, Exception) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- disconnectTaskManager(ResourceID, Exception) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Disconnects a TaskManager specified by the given resourceID from the
ResourceManager. - DiskIOScheduler - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk
-
The
DiskIOScheduleris a scheduler that controls the reading of data from shuffle files. - DiskIOScheduler(TieredStoragePartitionId, BatchShuffleReadBufferPool, ScheduledExecutorService, int, Duration, BiFunction<Integer, Integer, Integer>, PartitionFileReader) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskIOScheduler
- DiskTierConsumerAgent - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk
-
The data client is used to fetch data from disk tier.
- DiskTierConsumerAgent(List<TieredStorageConsumerSpec>, TieredStorageNettyService) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskTierConsumerAgent
- DiskTierFactory - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk
-
The implementation of
TierFactoryfor disk tier. - DiskTierFactory() - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskTierFactory
- DiskTierProducerAgent - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk
-
The disk tier implementation of
TierProducerAgent. - Dispatcher - Class in org.apache.flink.runtime.dispatcher
-
Base class for the Dispatcher component.
- Dispatcher(RpcService, DispatcherId, Collection<JobGraph>, Collection<JobResult>, DispatcherBootstrapFactory, DispatcherServices) - Constructor for class org.apache.flink.runtime.dispatcher.Dispatcher
- Dispatcher(RpcService, DispatcherId, Collection<JobGraph>, Collection<JobResult>, DispatcherBootstrapFactory, DispatcherServices, JobManagerRunnerRegistry, ResourceCleanerFactory) - Constructor for class org.apache.flink.runtime.dispatcher.Dispatcher
- DISPATCHER_NAME - Static variable in class org.apache.flink.runtime.dispatcher.Dispatcher
- Dispatcher.ExecutionType - Enum in org.apache.flink.runtime.dispatcher
-
Enum to distinguish between initial job submission and re-submission for recovery.
- DispatcherBootstrap - Interface in org.apache.flink.runtime.dispatcher
-
An interface containing the logic of bootstrapping the
Dispatcherof a cluster. - DispatcherBootstrapFactory - Interface in org.apache.flink.runtime.dispatcher
-
A factory to create a
DispatcherBootstrap. - DispatcherCachedOperationsHandler - Class in org.apache.flink.runtime.dispatcher
-
A handler for async operations triggered by the
Dispatcherwhose keys and results are cached. - DispatcherException - Exception in org.apache.flink.runtime.dispatcher
-
Base class for
Dispatcherrelated exceptions. - DispatcherException(String) - Constructor for exception org.apache.flink.runtime.dispatcher.DispatcherException
- DispatcherException(String, Throwable) - Constructor for exception org.apache.flink.runtime.dispatcher.DispatcherException
- DispatcherException(Throwable) - Constructor for exception org.apache.flink.runtime.dispatcher.DispatcherException
- DispatcherFactory - Interface in org.apache.flink.runtime.dispatcher
-
Dispatcherfactory interface. - DispatcherGateway - Interface in org.apache.flink.runtime.dispatcher
-
Gateway for the Dispatcher component.
- DispatcherId - Class in org.apache.flink.runtime.dispatcher
-
Fencing token of the
Dispatcher. - DispatcherLeaderProcessFactory - Interface in org.apache.flink.runtime.dispatcher.runner
-
Factory for the
DispatcherLeaderProcess. - DispatcherLeaderProcessFactoryFactory - Interface in org.apache.flink.runtime.dispatcher.runner
-
Factory for
DispatcherLeaderProcessFactory. - DispatcherOperationCaches - Class in org.apache.flink.runtime.dispatcher
-
Encapsulates caches for results of asynchronous operations triggered by the
Dispatcher. - DispatcherOperationCaches() - Constructor for class org.apache.flink.runtime.dispatcher.DispatcherOperationCaches
- DispatcherOperationCaches(Duration) - Constructor for class org.apache.flink.runtime.dispatcher.DispatcherOperationCaches
- DispatcherResourceCleanerFactory - Class in org.apache.flink.runtime.dispatcher.cleanup
-
DispatcherResourceCleanerFactoryinstantiatesResourceCleanerinstances that clean cleanable resources from theDispatcher. - DispatcherResourceCleanerFactory(Executor, RetryStrategy, JobManagerRunnerRegistry, JobGraphWriter, BlobServer, HighAvailabilityServices, JobManagerMetricGroup) - Constructor for class org.apache.flink.runtime.dispatcher.cleanup.DispatcherResourceCleanerFactory
- DispatcherResourceCleanerFactory(JobManagerRunnerRegistry, DispatcherServices) - Constructor for class org.apache.flink.runtime.dispatcher.cleanup.DispatcherResourceCleanerFactory
- DispatcherResourceManagerComponent - Class in org.apache.flink.runtime.entrypoint.component
- DispatcherResourceManagerComponentFactory - Interface in org.apache.flink.runtime.entrypoint.component
-
Factory for the
DispatcherResourceManagerComponent. - DispatcherRestEndpoint - Class in org.apache.flink.runtime.dispatcher
-
REST endpoint for the
Dispatchercomponent. - DispatcherRestEndpoint(GatewayRetriever<DispatcherGateway>, Configuration, RestHandlerConfiguration, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, ScheduledExecutorService, MetricFetcher, LeaderElection, ExecutionGraphCache, FatalErrorHandler) - Constructor for class org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint
- DispatcherRunner - Interface in org.apache.flink.runtime.dispatcher.runner
-
The
DispatcherRunnerencapsulates how aDispatcheris being executed. - DispatcherRunnerFactory - Interface in org.apache.flink.runtime.dispatcher.runner
-
Factory interface for the
DispatcherRunner. - DispatcherServices - Class in org.apache.flink.runtime.dispatcher
-
Dispatcherservices container. - DispatcherThreadFactory - Class in org.apache.flink.runtime.taskmanager
-
Thread factory that creates threads with a given name, associates them with a given thread group, and set them to daemon mode.
- DispatcherThreadFactory(ThreadGroup, String) - Constructor for class org.apache.flink.runtime.taskmanager.DispatcherThreadFactory
-
Creates a new thread factory.
- dispatchOperatorEvent(OperatorID, SerializedValue<OperatorEvent>) - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
- dispatchOperatorEvent(OperatorID, SerializedValue<OperatorEvent>) - Method in interface org.apache.flink.runtime.jobgraph.tasks.CoordinatedTask
- dispatchOperatorEvent(OperatorID, SerializedValue<OperatorEvent>) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
- dispatchOperatorEvent(OperatorID, SerializedValue<OperatorEvent>) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- dispatchOperatorEvent(OperatorID, SerializedValue<OperatorEvent>) - Method in class org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
- dispatchOperatorEvent(OperatorID, SerializedValue<OperatorEvent>) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- dispose() - Method in class org.apache.flink.runtime.checkpoint.metadata.CheckpointMetadata
- dispose() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
- dispose() - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Disposes the sorter.
- dispose() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
- dispose() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
Closes the state backend, releasing all internal resources, but does not delete any persistent checkpoint data.
- dispose() - Method in interface org.apache.flink.runtime.state.AsyncKeyedStateBackend
- dispose() - Method in class org.apache.flink.runtime.state.ChangelogTaskLocalStateStore
- dispose() - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
- dispose() - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
- dispose() - Method in class org.apache.flink.runtime.state.NoOpTaskLocalStateStoreImpl
- dispose() - Method in interface org.apache.flink.runtime.state.OperatorStateBackend
- dispose() - Method in interface org.apache.flink.runtime.state.OwnedTaskLocalStateStore
-
Disposes the task local state store.
- dispose() - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
Disposes the state of all local snapshots managed by this object.
- dispose() - Method in class org.apache.flink.runtime.state.v2.adaptor.AsyncKeyedStateBackendAdaptor
- dispose() - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
- dispose() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
- disposeAllOperatorCoordinators() - Method in class org.apache.flink.runtime.scheduler.DefaultOperatorCoordinatorHandler
- disposeAllOperatorCoordinators() - Method in interface org.apache.flink.runtime.scheduler.OperatorCoordinatorHandler
-
Dispose all operator coordinators.
- disposed - Variable in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
Status flag if this store was already discarded.
- disposeOnFailure() - Method in interface org.apache.flink.runtime.state.CheckpointStorageLocation
-
Disposes the checkpoint location in case the checkpoint has failed.
- disposeOnFailure() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
- disposeOnFailure() - Method in class org.apache.flink.runtime.state.memory.NonPersistentMetadataCheckpointStorageLocation
- disposeOnFailure() - Method in class org.apache.flink.runtime.state.memory.PersistentMetadataCheckpointStorageLocation
- disposeSavepoint(String) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- disposeSavepoint(String, Duration) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- disposeSavepoint(String, Duration) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Dispose the given savepoint.
- disposeSavepoint(String, Configuration, ClassLoader, Logger) - Static method in class org.apache.flink.runtime.checkpoint.Checkpoints
- disposeSavepoint(String, CheckpointStorage, ClassLoader) - Static method in class org.apache.flink.runtime.checkpoint.Checkpoints
- disposeStorageLocation() - Method in interface org.apache.flink.runtime.state.CompletedCheckpointStorageLocation
-
Disposes the storage location.
- disposeStorageLocation() - Method in class org.apache.flink.runtime.state.filesystem.FsCompletedCheckpointStorageLocation
- DistributedCacheFile(String, String) - Constructor for class org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody.DistributedCacheFile
- DistributedRuntimeUDFContext - Class in org.apache.flink.runtime.operators.util
-
A standalone implementation of the
RuntimeContext, created by runtime UDF operators. - DistributedRuntimeUDFContext(JobInfo, TaskInfo, UserCodeClassLoader, ExecutionConfig, Map<String, Future<Path>>, Map<String, Accumulator<?, ?>>, OperatorMetricGroup, ExternalResourceInfoProvider) - Constructor for class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
- DistributionPattern - Enum in org.apache.flink.runtime.jobgraph
-
A distribution pattern determines, which sub tasks of a producing task are connected to which consuming sub tasks.
- doAdvance() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
- doLogin(boolean) - Method in class org.apache.flink.runtime.security.token.hadoop.KerberosLoginProvider
-
Does kerberos login and sets current user.
- doLoginAndReturnUGI() - Method in class org.apache.flink.runtime.security.token.hadoop.KerberosLoginProvider
-
Does kerberos login and doesn't set current user, just returns a new UGI instance.
- done() - Method in class org.apache.flink.runtime.state.AsyncSnapshotCallable.AsyncSnapshotTask
- DoneFuture<T> - Class in org.apache.flink.runtime.state
-
A
Futurethat is always done and will just yield the object that was given at creation time. - DoneFuture(T) - Constructor for class org.apache.flink.runtime.state.DoneFuture
- doTransform(String, TypeInformation<R>, StreamOperatorFactory<R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
- doTransform(String, TypeInformation<R>, StreamOperatorFactory<R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
- DOWNLOAD_STATE_DURATION - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- DownTimeGauge - Class in org.apache.flink.runtime.executiongraph.metrics
-
A gauge that returns (in milliseconds) how long a job has not been not running any more, in case it is in a failing/recovering situation.
- DownTimeGauge(JobStatusProvider) - Constructor for class org.apache.flink.runtime.executiongraph.metrics.DownTimeGauge
- drain() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
Finishes running all mails in the mailbox.
- drain() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
Drains the mailbox and returns all mails that were still enqueued.
- drain() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
- DRAIN - org.apache.flink.runtime.io.network.api.StopMode
- DRAINED - org.apache.flink.runtime.io.PullingAsyncDataInput.EndOfDataStatus
- drainInflightRecords(int) - Method in class org.apache.flink.runtime.asyncprocessing.AsyncExecutionController
-
A helper function to drain in-flight records util
AsyncExecutionController.inFlightRecordNumwithin the limit of giventargetNum. - driver - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The driver that invokes the user code (the stub implementation).
- Driver<S extends org.apache.flink.api.common.functions.Function,OT> - Interface in org.apache.flink.runtime.operators
-
The interface to be implemented by all drivers that run alone (or as the primary driver) in a task.
- DriverStrategy - Enum in org.apache.flink.runtime.operators
-
Enumeration of all available operator strategies.
- DualKeyLinkedMap<A,B,V> - Class in org.apache.flink.runtime.util
-
Map which stores values under two different indices.
- DualKeyLinkedMap() - Constructor for class org.apache.flink.runtime.util.DualKeyLinkedMap
- DummyBatchJobRecoveryHandler - Class in org.apache.flink.runtime.scheduler.adaptivebatch
-
A dummy implementation of the
BatchJobRecoveryHandler. - DummyBatchJobRecoveryHandler() - Constructor for class org.apache.flink.runtime.scheduler.adaptivebatch.DummyBatchJobRecoveryHandler
- DummySpeculativeExecutionHandler - Class in org.apache.flink.runtime.scheduler.adaptivebatch
-
The dummy implementation of
SpeculativeExecutionHandler. - DummySpeculativeExecutionHandler() - Constructor for class org.apache.flink.runtime.scheduler.adaptivebatch.DummySpeculativeExecutionHandler
- dumpAndCreate(int) - Static method in class org.apache.flink.runtime.rest.messages.ThreadDumpInfo
- duplicate() - Method in class org.apache.flink.runtime.query.KvStateInfo
-
Creates a deep copy of the current
KvStateInfoby duplicating all the included serializers. - duplicate() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
- duplicate() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
- duplicate() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
- duplicate() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
- duplicate() - Method in class org.apache.flink.streaming.api.operators.sortpartition.FixedLengthByteKeyAndValueComparator
- duplicate() - Method in class org.apache.flink.streaming.api.operators.sortpartition.VariableLengthByteKeyAndValueComparator
- duplicate() - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
- duplicate() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
- duplicate(List<StreamStateHandle>) - Method in interface org.apache.flink.runtime.state.CheckpointStateToolset
-
Duplicates
StreamStateHandlesinto the path embedded inside of the class. - duplicate(List<StreamStateHandle>) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStateToolset
- duplicate(List<StreamStateHandle>) - Method in class org.apache.flink.runtime.state.NotDuplicatingCheckpointStateToolset
- duplicate(List<StreamStateHandle>, CheckpointedStateScope) - Method in interface org.apache.flink.runtime.state.CheckpointStreamFactory
-
Duplicates
StreamStateHandleinto the path corresponding to * the givenCheckpointedStateScope. - duplicate(List<StreamStateHandle>, CheckpointedStateScope) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
- duplicate(List<StreamStateHandle>, CheckpointedStateScope) - Method in class org.apache.flink.runtime.state.filesystem.FsMergingCheckpointStorageLocation
- duplicate(List<StreamStateHandle>, CheckpointedStateScope) - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory
- DUPLICATE - org.apache.flink.runtime.checkpoint.PendingCheckpoint.TaskAcknowledgeResult
- DuplicateJobSubmissionException - Exception in org.apache.flink.runtime.client
-
Exception which is returned upon job submission if the submitted job is currently being executed.
- DuplicatingCheckpointOutputStream - Class in org.apache.flink.runtime.state
-
A CheckpointStateOutputStream that wraps a primary and a secondary CheckpointStateOutputStream and duplicates all writes into both streams.
- DuplicatingCheckpointOutputStream(CheckpointStateOutputStream, CheckpointStateOutputStream) - Constructor for class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
- DuplicatingCheckpointOutputStream(CheckpointStateOutputStream, CheckpointStateOutputStream, int) - Constructor for class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
- DYNAMIC_PROPERTY_OPTION - Static variable in class org.apache.flink.runtime.entrypoint.parser.CommandLineOptions
- DynamicConfiguration - Class in org.apache.flink.runtime.security
-
A dynamic JAAS configuration.
- DynamicConfiguration(Configuration) - Constructor for class org.apache.flink.runtime.security.DynamicConfiguration
-
Create a dynamic configuration.
- DynamicParametersConfigurationParserFactory - Class in org.apache.flink.runtime.entrypoint
-
DynamicParametersConfigurationParserFactorycan be used to extract the dynamic parameters from command line. - DynamicParametersConfigurationParserFactory() - Constructor for class org.apache.flink.runtime.entrypoint.DynamicParametersConfigurationParserFactory
E
- EdgeManager - Class in org.apache.flink.runtime.executiongraph
-
Class that manages all the connections between tasks.
- EdgeManager() - Constructor for class org.apache.flink.runtime.executiongraph.EdgeManager
- EdgeManagerBuildUtil - Class in org.apache.flink.runtime.executiongraph
-
Utilities for building
EdgeManager. - EdgeManagerBuildUtil() - Constructor for class org.apache.flink.runtime.executiongraph.EdgeManagerBuildUtil
- ElementOrder - Enum in org.apache.flink.streaming.runtime.operators.asyncprocessing
-
This enum defines the element order of being processed.
- elementPriorityComparator - Variable in class org.apache.flink.runtime.state.heap.HeapPriorityQueue
-
Comparator for the priority of contained elements.
- EmbeddedCompletedCheckpointStore - Class in org.apache.flink.runtime.checkpoint
-
An embedded in-memory checkpoint store, which supports shutdown and suspend.
- EmbeddedCompletedCheckpointStore() - Constructor for class org.apache.flink.runtime.checkpoint.EmbeddedCompletedCheckpointStore
- EmbeddedCompletedCheckpointStore(int) - Constructor for class org.apache.flink.runtime.checkpoint.EmbeddedCompletedCheckpointStore
- EmbeddedCompletedCheckpointStore(int, Collection<CompletedCheckpoint>, RecoveryClaimMode) - Constructor for class org.apache.flink.runtime.checkpoint.EmbeddedCompletedCheckpointStore
- EmbeddedCompletedCheckpointStore(int, Collection<CompletedCheckpoint>, SharedStateRegistry) - Constructor for class org.apache.flink.runtime.checkpoint.EmbeddedCompletedCheckpointStore
- EmbeddedHaServices - Class in org.apache.flink.runtime.highavailability.nonha.embedded
-
An implementation of the
HighAvailabilityServicesfor the non-high-availability case where all participants (ResourceManager, JobManagers, TaskManagers) run in the same process. - EmbeddedHaServices(Executor) - Constructor for class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
- EmbeddedHaServicesWithLeadershipControl - Class in org.apache.flink.runtime.highavailability.nonha.embedded
-
EmbeddedHaServicesextension to expose leadership granting and revoking. - EmbeddedHaServicesWithLeadershipControl(Executor) - Constructor for class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServicesWithLeadershipControl
- EmbeddedHaServicesWithLeadershipControl(Executor, CheckpointRecoveryFactory) - Constructor for class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServicesWithLeadershipControl
- EmbeddedJobResultStore - Class in org.apache.flink.runtime.highavailability.nonha.embedded
-
A thread-safe in-memory implementation of the
JobResultStore. - EmbeddedJobResultStore() - Constructor for class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedJobResultStore
- EmbeddedLeaderService - Class in org.apache.flink.runtime.highavailability.nonha.embedded
-
A simple leader election service, which selects a leader among contenders and notifies listeners.
- EmbeddedLeaderService(Executor) - Constructor for class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
- emit() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.ReduceFacade
-
Emits all elements currently held by the table to the collector.
- emit(ByteBuffer, int) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
- emit(T) - Method in class org.apache.flink.runtime.io.network.api.writer.BroadcastRecordWriter
- emit(T) - Method in class org.apache.flink.runtime.io.network.api.writer.ChannelSelectorRecordWriter
- emit(T) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
This is used to send regular records.
- emit(T, int) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
- emitAndReset() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.ReduceFacade
-
Emits all elements currently held by the table to the collector, and resets the table.
- emitImmediateWatermark(long) - Method in class org.apache.flink.streaming.api.operators.source.NoOpTimestampsAndWatermarks
- emitImmediateWatermark(long) - Method in class org.apache.flink.streaming.api.operators.source.ProgressiveTimestampsAndWatermarks
- emitImmediateWatermark(long) - Method in interface org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks
-
Emit a watermark immediately.
- emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.CountingOutput
- emitLatencyMarker(LatencyMarker) - Method in interface org.apache.flink.streaming.api.operators.Output
- emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
- emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.runtime.io.FinishedDataOutput
- emitLatencyMarker(LatencyMarker) - Method in interface org.apache.flink.streaming.runtime.io.PushingAsyncDataInput.DataOutput
- emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
- emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
- emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask.AsyncDataOutputToOutput
- emitNext(PushingAsyncDataInput.DataOutput<IN>) - Method in class org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput
- emitNext(PushingAsyncDataInput.DataOutput<OUT>) - Method in class org.apache.flink.streaming.api.operators.SourceOperator
- emitNext(PushingAsyncDataInput.DataOutput<T>) - Method in class org.apache.flink.streaming.api.operators.sort.SortingDataInput
- emitNext(PushingAsyncDataInput.DataOutput<T>) - Method in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
- emitNext(PushingAsyncDataInput.DataOutput<T>) - Method in interface org.apache.flink.streaming.runtime.io.PushingAsyncDataInput
-
Pushes elements to the output from current data input, and returns the input status to indicate whether there are more available data in current input.
- emitNext(PushingAsyncDataInput.DataOutput<T>) - Method in class org.apache.flink.streaming.runtime.io.StreamTaskExternallyInducedSourceInput
- emitNext(PushingAsyncDataInput.DataOutput<T>) - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
- emitNext(PushingAsyncDataInput.DataOutput<T>) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskFinishedOnRestoreSourceInput
- emitPeriodicWatermark() - Method in class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
- emitRecord(ByteBuffer, int) - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
Writes the given serialized record to the target subpartition.
- emitRecord(ByteBuffer, int) - Method in class org.apache.flink.runtime.io.network.partition.BufferWritingResultPartition
- emitRecord(ByteBuffer, int) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartition
- emitRecord(ByteBuffer, int) - Method in class org.apache.flink.runtime.io.network.partition.SortMergeResultPartition
- emitRecord(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.io.FinishedDataOutput
- emitRecord(StreamRecord<T>) - Method in interface org.apache.flink.streaming.runtime.io.PushingAsyncDataInput.DataOutput
- emitRecord(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask.AsyncDataOutputToOutput
- emitRecordAttributes(RecordAttributes) - Method in class org.apache.flink.streaming.api.operators.CountingOutput
- emitRecordAttributes(RecordAttributes) - Method in interface org.apache.flink.streaming.api.operators.Output
-
Emits a
RecordAttributesfrom an operator. - emitRecordAttributes(RecordAttributes) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
- emitRecordAttributes(RecordAttributes) - Method in class org.apache.flink.streaming.runtime.io.FinishedDataOutput
- emitRecordAttributes(RecordAttributes) - Method in interface org.apache.flink.streaming.runtime.io.PushingAsyncDataInput.DataOutput
- emitRecordAttributes(RecordAttributes) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
- emitRecordAttributes(RecordAttributes) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
- emitRecordAttributes(RecordAttributes) - Method in class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask.AsyncDataOutputToOutput
- emitsProgressiveWatermarks() - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
Deprecated.
- emitWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
- emitWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.source.WatermarkToDataOutput
- emitWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator.WatermarkEmitter
- emitWatermark(Watermark) - Method in interface org.apache.flink.streaming.api.functions.source.legacy.SourceFunction.SourceContext
-
Deprecated.Emits the given
Watermark. - emitWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.CountingOutput
- emitWatermark(Watermark) - Method in interface org.apache.flink.streaming.api.operators.Output
-
Emits a
Watermarkfrom an operator. - emitWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
- emitWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.io.FinishedDataOutput
- emitWatermark(Watermark) - Method in interface org.apache.flink.streaming.runtime.io.PushingAsyncDataInput.DataOutput
- emitWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
- emitWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
- emitWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask.AsyncDataOutputToOutput
- emitWatermarkInsideMailbox(Watermark) - Method in class org.apache.flink.streaming.api.operators.MailboxWatermarkProcessor
- emitWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.streaming.api.operators.CountingOutput
- emitWatermarkStatus(WatermarkStatus) - Method in interface org.apache.flink.streaming.api.operators.Output
- emitWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
- emitWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.streaming.runtime.io.FinishedDataOutput
- emitWatermarkStatus(WatermarkStatus) - Method in interface org.apache.flink.streaming.runtime.io.PushingAsyncDataInput.DataOutput
- emitWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
- emitWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
- emitWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask.AsyncDataOutputToOutput
- empty() - Static method in class org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
- empty() - Static method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummarySnapshot
- empty() - Static method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- empty() - Static method in class org.apache.flink.runtime.checkpoint.StatsSummarySnapshot
- empty() - Static method in class org.apache.flink.runtime.jobgraph.JobResourceRequirements
- empty() - Static method in class org.apache.flink.runtime.leaderelection.LeaderInformation
- empty() - Static method in class org.apache.flink.runtime.leaderelection.LeaderInformationRegister
- empty() - Static method in class org.apache.flink.runtime.resourcemanager.ResourceOverview
- empty() - Static method in class org.apache.flink.runtime.rest.messages.LogListInfo
- empty() - Static method in class org.apache.flink.runtime.rest.messages.ProfilingInfoList
- empty() - Static method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
- empty() - Static method in class org.apache.flink.runtime.scheduler.adaptive.allocator.JobAllocationsInformation
- empty() - Static method in class org.apache.flink.runtime.scheduler.adaptive.allocator.VertexParallelism
- empty() - Static method in class org.apache.flink.runtime.scheduler.adaptive.JobSchedulingPlan
-
Create an empty
JobSchedulingPlanwith no information about vertices or allocations. - empty() - Static method in class org.apache.flink.runtime.state.SnapshotResult
- empty() - Static method in class org.apache.flink.runtime.taskexecutor.TaskExecutorToJobManagerHeartbeatPayload
- empty() - Static method in class org.apache.flink.runtime.util.ResourceCounter
-
Creates an empty resource counter.
- empty() - Static method in interface org.apache.flink.runtime.webmonitor.WebMonitorExtension
- empty(long) - Static method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
- empty(JobID, String) - Static method in class org.apache.flink.runtime.slots.ResourceRequirements
- EMPTY - Static variable in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter.ChannelStateWriteResult
- EMPTY - Static variable in class org.apache.flink.runtime.rest.handler.FileUploads
- EMPTY - Static variable in class org.apache.flink.runtime.util.IntArrayList
- EMPTY_FAILURE_LABELS - Static variable in class org.apache.flink.runtime.failure.FailureEnricherUtils
- EMPTY_KEY_GROUP_RANGE - Static variable in class org.apache.flink.runtime.state.KeyGroupRange
-
The empty key-group
- EMPTY_RECORD_ATTRIBUTES - Static variable in class org.apache.flink.streaming.runtime.streamrecord.RecordAttributes
- EmptyDiscardStateObjectForRegister(StateHandleID) - Constructor for class org.apache.flink.runtime.state.SharedStateRegistryImpl.EmptyDiscardStateObjectForRegister
- EmptyFileMergingOperatorStreamStateHandle - Class in org.apache.flink.runtime.state.filemerging
-
An empty
FileMergingOperatorStreamStateHandlethat is only used as a placeholder to prevent file merging directory from being deleted. - EmptyFileMergingOperatorStreamStateHandle(DirectoryStreamStateHandle, DirectoryStreamStateHandle, Map<String, OperatorStateHandle.StateMetaInfo>, StreamStateHandle) - Constructor for class org.apache.flink.runtime.state.filemerging.EmptyFileMergingOperatorStreamStateHandle
- emptyIfNull(StateObjectCollection<T>) - Static method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- EmptyIterator<E> - Class in org.apache.flink.runtime.util
-
An empty iterator that never returns anything.
- EmptyIterator() - Constructor for class org.apache.flink.runtime.util.EmptyIterator
- EmptyMessageParameters - Class in org.apache.flink.runtime.rest.messages
-
MessageParameters implementation which has no parameters.
- EmptyMutableObjectIterator<E> - Class in org.apache.flink.runtime.util
-
An empty mutable object iterator that never returns anything.
- EmptyMutableObjectIterator() - Constructor for class org.apache.flink.runtime.util.EmptyMutableObjectIterator
- emptyNotRestored() - Static method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns an empty
PrioritizedOperatorSubtaskStatesingleton for an empty, not-restored operator state. - EmptyRequestBody - Class in org.apache.flink.runtime.rest.messages
-
Request which do not have a request payload.
- EmptyResponseBody - Class in org.apache.flink.runtime.rest.messages
-
Empty
ResponseBodyimplementation. - EmptySegmentFileStateHandle - Class in org.apache.flink.runtime.state.filemerging
-
An empty
SegmentFileStateHandlethat is only used as a placeholder. - EmptyShuffleMasterSnapshot - Class in org.apache.flink.runtime.shuffle
-
A singleton implementation of
ShuffleMasterSnapshotthat represents an empty snapshot of shuffle master. - EmptyShuffleMasterSnapshot() - Constructor for class org.apache.flink.runtime.shuffle.EmptyShuffleMasterSnapshot
- enableApproximateLocalRecovery(boolean) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
- enableApproximateLocalRecovery(boolean) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Enables the approximate local recovery mode.
- enableChangelogStateBackend(boolean) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Enable the change log for current state backend.
- enableCheckpointing(long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Enables checkpointing for the streaming job.
- enableCheckpointing(long, CheckpointingMode) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Enables checkpointing for the streaming job.
- enableCheckpointing(long, CheckpointingMode) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Deprecated.
- enableCheckpointing(CheckpointCoordinatorConfiguration, List<MasterTriggerRestoreHook<?>>, CheckpointIDCounter, CompletedCheckpointStore, StateBackend, CheckpointStorage, CheckpointStatsTracker, CheckpointsCleaner, String) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- enableCheckpointing(CheckpointCoordinatorConfiguration, List<MasterTriggerRestoreHook<?>>, CheckpointIDCounter, CompletedCheckpointStore, StateBackend, CheckpointStorage, CheckpointStatsTracker, CheckpointsCleaner, String) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- enableSpilling(IOManager) - Method in class org.apache.flink.runtime.operators.sort.ExternalSorterBuilder
- enableSpilling(IOManager, double) - Method in class org.apache.flink.runtime.operators.sort.ExternalSorterBuilder
- enableTimeToLive(StateTtlConfig) - Method in class org.apache.flink.runtime.state.v2.StateDescriptor
-
Configures optional activation of state time-to-live (TTL).
- enableUnalignedCheckpoints() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Enables unaligned checkpoints, which greatly reduce checkpointing times under backpressure.
- enableUnalignedCheckpoints(boolean) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Enables unaligned checkpoints, which greatly reduce checkpointing times under backpressure.
- enableUnalignedCheckpointsInterruptibleTimers(boolean) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
- encodePathAsReference(Path) - Static method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorageAccess
-
Encodes the given path as a reference in bytes.
- ENCODING - Static variable in class org.apache.flink.runtime.rest.handler.util.HandlerRedirectUtils
- END_OF_DATA - org.apache.flink.runtime.io.network.buffer.Buffer.DataType
-
Buffer.DataType.END_OF_DATAindicates that there will be no more data buffer in a subpartition. - END_OF_DATA - org.apache.flink.streaming.runtime.io.DataInputStatus
-
Indicator that the input has reached the end of data.
- END_OF_INPUT - org.apache.flink.streaming.runtime.io.DataInputStatus
-
Indicator that the input has reached the end of data and control events.
- END_OF_KEY_GROUP_MARK - Static variable in class org.apache.flink.runtime.state.FullSnapshotUtil
- END_OF_PARTITION - org.apache.flink.runtime.io.network.buffer.Buffer.DataType
-
Buffer.DataType.END_OF_PARTITIONmarks a subpartition as fully consumed. - END_OF_RECOVERY - org.apache.flink.streaming.runtime.io.DataInputStatus
-
Indicator that all persisted data of the data exchange has been successfully restored.
- END_OF_SEGMENT - org.apache.flink.runtime.io.network.buffer.Buffer.DataType
-
Buffer.DataType.END_OF_SEGMENTindicates that a segment is finished in a subpartition. - endData(StopMode) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- endIndex - Variable in class org.apache.flink.runtime.executiongraph.IndexRange
- endInput() - Method in interface org.apache.flink.streaming.api.operators.BoundedOneInput
-
It is notified that no more data will arrive from the input.
- endInput() - Method in class org.apache.flink.streaming.api.operators.MapPartitionOperator
- endInput() - Method in class org.apache.flink.streaming.api.operators.PartitionAggregateOperator
- endInput() - Method in class org.apache.flink.streaming.api.operators.PartitionReduceOperator
- endInput() - Method in class org.apache.flink.streaming.api.operators.sortpartition.KeyedSortPartitionOperator
- endInput() - Method in class org.apache.flink.streaming.api.operators.sortpartition.SortPartitionOperator
- endInput(int) - Method in interface org.apache.flink.streaming.api.operators.BoundedMultiInput
-
It is notified that no more data will arrive from the input identified by the
inputId. - endInput(int) - Method in class org.apache.flink.streaming.api.operators.co.BatchCoBroadcastWithKeyedOperator
- endInput(int) - Method in class org.apache.flink.streaming.api.operators.co.BatchCoBroadcastWithNonKeyedOperator
- endInput(int) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
- endInput(int) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
Ends the main operator input specified by
inputId). - endInput(int) - Method in class org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
- EndOfChannelStateEvent - Class in org.apache.flink.runtime.io.network.partition.consumer
-
Marks the end of recovered state of
RecoveredInputChannelof this subtask orResultSubpartitionon the upstream. - EndOfData - Class in org.apache.flink.runtime.io.network.api
-
This event indicates there will be no more data records in a subpartition.
- EndOfData(StopMode) - Constructor for class org.apache.flink.runtime.io.network.api.EndOfData
- EndOfPartitionEvent - Class in org.apache.flink.runtime.io.network.api
-
This event marks a subpartition as fully consumed.
- EndOfSegmentEvent - Class in org.apache.flink.runtime.io.network.api
-
EndOfSegmentEventis used to notify the downstream switch tiers in tiered storage shuffle mode. - EndOfStreamTrigger() - Constructor for class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.EndOfStreamTrigger
- EndOfSuperstepEvent - Class in org.apache.flink.runtime.io.network.api
-
Marks the end of a superstep of one particular iteration superstep.
- endOperatorInput(int) - Method in class org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper
-
Ends an input of the operator contained by this wrapper.
- enrichNetworkMemory(SlotSharingGroup, Function<JobVertexID, ExecutionJobVertex>, ShuffleMaster<?>) - Static method in class org.apache.flink.runtime.scheduler.SsgNetworkMemoryCalculationUtils
-
Calculates network memory requirement of
ExecutionJobVertexand updateResourceProfileof corresponding slot sharing group. - ensureCapacity(int) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemoryManager
-
Try best to reserve enough buffers that are guaranteed reclaimable along with the additional ones.
- ensureCapacity(int) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemoryManagerImpl
- ensureWritable(int) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- entries() - Method in class org.apache.flink.runtime.state.HeapBroadcastState
- entries() - Method in class org.apache.flink.runtime.state.v2.AbstractMapState
- entries() - Method in class org.apache.flink.runtime.state.v2.adaptor.MapStateAdaptor
- EntryIterator() - Constructor for class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.EntryIterator
- entryName - Variable in class org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody.DistributedCacheFile
- EntrypointClusterConfiguration - Class in org.apache.flink.runtime.entrypoint
-
Basic
ClusterConfigurationfor entry points. - EntrypointClusterConfiguration(String, Properties, String[]) - Constructor for class org.apache.flink.runtime.entrypoint.EntrypointClusterConfiguration
- EntrypointClusterConfigurationParserFactory - Class in org.apache.flink.runtime.entrypoint
-
Parser factory for
EntrypointClusterConfiguration. - EntrypointClusterConfigurationParserFactory() - Constructor for class org.apache.flink.runtime.entrypoint.EntrypointClusterConfigurationParserFactory
- Enumerator(File[], Random) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.Enumerator
- environment - Variable in class org.apache.flink.streaming.api.datastream.ConnectedStreams
- environment - Variable in class org.apache.flink.streaming.api.datastream.DataStream
- Environment - Interface in org.apache.flink.runtime.execution
-
The Environment gives the code executed in a task access to the task's properties (such as name, parallelism), the configurations, the data stream readers and writers, as well as the various components that are provided by the TaskManager, such as memory manager, I/O manager, ...
- EnvironmentError - org.apache.flink.runtime.throwable.ThrowableType
-
This indicates an error related to the running environment, such as hardware error, service issue, in which case we should consider blacklisting the machine.
- EnvironmentInfo - Class in org.apache.flink.runtime.rest.messages
-
The response of environment info.
- EnvironmentInfo(EnvironmentInfo.JVMInfo, List<String>) - Constructor for class org.apache.flink.runtime.rest.messages.EnvironmentInfo
- EnvironmentInformation - Class in org.apache.flink.runtime.util
-
Utility class that gives access to the execution environment of the JVM, like the executing user, startup options, or the JVM version.
- EnvironmentInformation.RevisionInformation - Class in org.apache.flink.runtime.util
-
Revision information encapsulates information about the source code revision of the Flink code.
- EOI - Static variable in interface org.apache.flink.streaming.api.connector.sink2.CommittableMessage
-
Special value for checkpointId for the end of input in case of batch commit or final checkpoint.
- Epoch(long) - Constructor for class org.apache.flink.runtime.asyncprocessing.EpochManager.Epoch
- EpochManager - Class in org.apache.flink.runtime.asyncprocessing
-
Epoch manager segments inputs into distinct epochs, marked by the arrival of non-records(e.g.
- EpochManager(AsyncExecutionController<?>) - Constructor for class org.apache.flink.runtime.asyncprocessing.EpochManager
- EpochManager.Epoch - Class in org.apache.flink.runtime.asyncprocessing
-
All inputs are segment into distinct epochs, marked by the arrival of non-record inputs.
- EpochManager.ParallelMode - Enum in org.apache.flink.runtime.asyncprocessing
-
This enum defines whether parallel execution between epochs is allowed.
- equals(Object) - Method in class org.apache.flink.runtime.asyncprocessing.RecordContext
- equals(Object) - Method in class org.apache.flink.runtime.blob.BlobKey
- equals(Object) - Method in class org.apache.flink.runtime.blocklist.BlockedNode
- equals(Object) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.channel.InputChannelInfo
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.channel.ResultSubpartitionInfo
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetaData
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.CheckpointType
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager.SpaceStat
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager.SubtaskKey
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.filemerging.LogicalFile
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFile
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.FinishedOperatorSubtaskState
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.FullyFinishedOperatorState
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.InflightDataRescalingDescriptor
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.InflightDataRescalingDescriptor.InflightDataGateOrPartitionRescalingDescriptor
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.RescaleMappings
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.SavepointType
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.SubTaskInitializationMetrics
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
- equals(Object) - Method in class org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
- equals(Object) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceID
- equals(Object) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
- equals(Object) - Method in class org.apache.flink.runtime.clusterframework.types.SlotID
- equals(Object) - Method in class org.apache.flink.runtime.executiongraph.ExecutionAttemptID
- equals(Object) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertexInputInfo
- equals(Object) - Method in class org.apache.flink.runtime.executiongraph.IndexRange
- equals(Object) - Method in class org.apache.flink.runtime.executiongraph.JobInformation
- equals(Object) - Method in class org.apache.flink.runtime.executiongraph.JobVertexInputInfo
- equals(Object) - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
- equals(Object) - Method in class org.apache.flink.runtime.instance.HardwareDescription
- equals(Object) - Method in class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
- equals(Object) - Method in class org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
- equals(Object) - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
- equals(Object) - Method in class org.apache.flink.runtime.io.network.api.EndOfData
- equals(Object) - Method in class org.apache.flink.runtime.io.network.api.EndOfPartitionEvent
- equals(Object) - Method in class org.apache.flink.runtime.io.network.api.EndOfSegmentEvent
- equals(Object) - Method in class org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
- equals(Object) - Method in class org.apache.flink.runtime.io.network.api.EventAnnouncement
- equals(Object) - Method in class org.apache.flink.runtime.io.network.api.RecoveryMetadata
- equals(Object) - Method in class org.apache.flink.runtime.io.network.api.SubtaskConnectionDescriptor
- equals(Object) - Method in class org.apache.flink.runtime.io.network.ConnectionID
- equals(Object) - Method in class org.apache.flink.runtime.io.network.partition.consumer.EndOfChannelStateEvent
- equals(Object) - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGateID
- equals(Object) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageBytesBasedDataIdentifier
- equals(Object) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageInputChannelId
- equals(Object) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStoragePartitionId
- equals(Object) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageSubpartitionId
- equals(Object) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyConnectionId
- equals(Object) - Method in class org.apache.flink.runtime.io.network.partition.PrioritizedDeque
- equals(Object) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionID
- equals(Object) - Method in class org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionInfo
- equals(Object) - Method in class org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
- equals(Object) - Method in class org.apache.flink.runtime.jobgraph.JobResourceRequirements
- equals(Object) - Method in class org.apache.flink.runtime.jobgraph.JobVertexResourceRequirements
- equals(Object) - Method in class org.apache.flink.runtime.jobgraph.JobVertexResourceRequirements.Parallelism
- equals(Object) - Method in class org.apache.flink.runtime.jobgraph.OperatorInstanceID
- equals(Object) - Method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
- equals(Object) - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
- equals(Object) - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
- equals(Object) - Method in exception org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
- equals(Object) - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunnerResult
- equals(Object) - Method in class org.apache.flink.runtime.jobmaster.ResourceManagerAddress
- equals(Object) - Method in class org.apache.flink.runtime.leaderelection.LeaderInformation
- equals(Object) - Method in class org.apache.flink.runtime.messages.Acknowledge
- equals(Object) - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
- equals(Object) - Method in class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
- equals(Object) - Method in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
- equals(Object) - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
- equals(Object) - Method in class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview
- equals(Object) - Method in class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview.JobIdWithStatus
- equals(Object) - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
- equals(Object) - Method in class org.apache.flink.runtime.messages.webmonitor.JobStatusInfo
- equals(Object) - Method in class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
- equals(Object) - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
- equals(Object) - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobsOverview
- equals(Object) - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobsWithIDsOverview
- equals(Object) - Method in class org.apache.flink.runtime.messages.webmonitor.RequestStatusOverview
- equals(Object) - Method in class org.apache.flink.runtime.persistence.IntegerResourceVersion
- equals(Object) - Method in class org.apache.flink.runtime.persistence.StringResourceVersion
- equals(Object) - Method in class org.apache.flink.runtime.query.KvStateInfo
- equals(Object) - Method in class org.apache.flink.runtime.query.KvStateLocation
- equals(Object) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceDeclaration
- equals(Object) - Method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec
- equals(Object) - Method in class org.apache.flink.runtime.rest.handler.async.OperationKey
- equals(Object) - Method in class org.apache.flink.runtime.rest.handler.async.OperationResult
- equals(Object) - Method in class org.apache.flink.runtime.rest.handler.job.AsynchronousJobOperationKey
- equals(Object) - Method in class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
- equals(Object) - Method in class org.apache.flink.runtime.rest.HttpHeader
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.AggregatedTaskDetailsInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ExternalizedCheckpointInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.CompletedCheckpointStatistics
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.FailedCheckpointStatistics
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.PendingCheckpointStatistics
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.StatsSummaryDto
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.ConfigurationInfoEntry
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration.Features
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.EnvironmentInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.job.JobResourceRequirementsBody
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody.DistributedCacheFile
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitResponseBody
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.job.UserAccumulator
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.JobConfigInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.ExceptionInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.JobExceptionHistory
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.RootExceptionInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.JobPlanInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.LogInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.LogListInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.LogUrlResponse
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.ProfilingInfoList
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.ResourceProfileInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.taskmanager.SlotInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo.GarbageCollectorInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.ThreadDumpInfo.ThreadInfo
- equals(Object) - Method in class org.apache.flink.runtime.scheduler.strategy.ExecutionVertexID
- equals(Object) - Method in class org.apache.flink.runtime.slots.ResourceRequirement
- equals(Object) - Method in class org.apache.flink.runtime.slots.ResourceRequirements
- equals(Object) - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinator.WatermarkElement
- equals(Object) - Method in class org.apache.flink.runtime.source.event.IsProcessingBacklogEvent
- equals(Object) - Method in class org.apache.flink.runtime.source.event.ReportedWatermarkEvent
- equals(Object) - Method in class org.apache.flink.runtime.source.event.RequestSplitEvent
- equals(Object) - Method in class org.apache.flink.runtime.source.event.WatermarkAlignmentEvent
- equals(Object) - Method in class org.apache.flink.runtime.state.AbstractChannelStateHandle
- equals(Object) - Method in class org.apache.flink.runtime.state.AbstractIncrementalStateHandle
- equals(Object) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
- equals(Object) - Method in class org.apache.flink.runtime.state.ChainedStateHandle
- equals(Object) - Method in class org.apache.flink.runtime.state.changelog.SequenceNumber.GenericSequenceNumber
- equals(Object) - Method in class org.apache.flink.runtime.state.CheckpointStorageLocationReference
- equals(Object) - Method in class org.apache.flink.runtime.state.DirectoryStateHandle
- equals(Object) - Method in class org.apache.flink.runtime.state.filemerging.DirectoryStreamStateHandle
- equals(Object) - Method in class org.apache.flink.runtime.state.filemerging.FileMergingOperatorStreamStateHandle
- equals(Object) - Method in class org.apache.flink.runtime.state.filemerging.SegmentFileStateHandle
- equals(Object) - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
- equals(Object) - Method in class org.apache.flink.runtime.state.filesystem.RelativeFileStateHandle
- equals(Object) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap.StateMapEntry
- equals(Object) - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle.HandleAndLocalPath
- equals(Object) - Method in class org.apache.flink.runtime.state.KeyGroupRange
- equals(Object) - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
- equals(Object) - Method in class org.apache.flink.runtime.state.KeyGroupsSavepointStateHandle
- equals(Object) - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
- equals(Object) - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
- equals(Object) - Method in class org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
- equals(Object) - Method in class org.apache.flink.runtime.state.OperatorStreamStateHandle
- equals(Object) - Method in class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
- equals(Object) - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
- equals(Object) - Method in class org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
- equals(Object) - Method in class org.apache.flink.runtime.state.RegisteredStateMetaInfoBase.Key
- equals(Object) - Method in class org.apache.flink.runtime.state.SharedStateRegistryImpl.EmptyDiscardStateObjectForRegister
- equals(Object) - Method in class org.apache.flink.runtime.state.SnapshotDirectory
- equals(Object) - Method in class org.apache.flink.runtime.state.storage.FileSystemCheckpointStorage
- equals(Object) - Method in class org.apache.flink.runtime.state.v2.MapStateDescriptor
- equals(Object) - Method in class org.apache.flink.runtime.state.v2.RegisteredKeyValueStateBackendMetaInfo
- equals(Object) - Method in class org.apache.flink.runtime.state.v2.StateDescriptor
- equals(Object) - Method in class org.apache.flink.runtime.state.VoidNamespace
- equals(Object) - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
- equals(Object) - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotAllocationSnapshot
- equals(Object) - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotOffer
- equals(Object) - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
- equals(Object) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
- equals(Object) - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- equals(Object) - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
- equals(Object) - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
- equals(Object) - Method in class org.apache.flink.runtime.util.config.memory.CommonProcessMemorySpec
- equals(Object) - Method in class org.apache.flink.runtime.util.config.memory.jobmanager.JobManagerFlinkMemory
- equals(Object) - Method in class org.apache.flink.runtime.util.config.memory.JvmMetaspaceAndOverhead
- equals(Object) - Method in class org.apache.flink.runtime.util.config.memory.taskmanager.TaskExecutorFlinkMemory
- equals(Object) - Method in class org.apache.flink.runtime.util.OperatorSubtaskDescriptionText
- equals(Object) - Method in class org.apache.flink.runtime.util.ResourceCounter
- equals(Object) - Method in class org.apache.flink.runtime.webmonitor.history.ArchivedJson
- equals(Object) - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
- equals(Object) - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableSummary
- equals(Object) - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableWithLineage
- equals(Object) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
- equals(Object) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
- equals(Object) - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
- equals(Object) - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
- equals(Object) - Method in class org.apache.flink.streaming.api.graph.StreamConfig.SourceInputConfig
- equals(Object) - Method in class org.apache.flink.streaming.api.graph.StreamEdge
- equals(Object) - Method in class org.apache.flink.streaming.api.graph.StreamNode
- equals(Object) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
- equals(Object) - Method in class org.apache.flink.streaming.api.operators.InputSelection
- equals(Object) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
- equals(Object) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
- equals(Object) - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
- equals(Object) - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
- equals(Object) - Method in class org.apache.flink.streaming.api.watermark.InternalWatermark
- equals(Object) - Method in class org.apache.flink.streaming.api.watermark.Watermark
- equals(Object) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow
- equals(Object) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
- equals(Object) - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
- equals(Object) - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
- equals(Object) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
- equals(Object) - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
- equals(Object) - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
- equals(Object) - Method in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
- equals(Object) - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
- equals(Object) - Method in class org.apache.flink.streaming.runtime.streamrecord.RecordAttributes
- equals(Object) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
- equals(Object) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
- equals(Object) - Method in class org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
- equalTo(KeySelector<T2, KEY>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.Where
-
Specifies a
KeySelectorfor elements from the second input. - equalTo(KeySelector<T2, KEY>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.Where
-
Specifies a
KeySelectorfor elements from the second input. - equalTo(KeySelector<T2, KEY>, TypeInformation<KEY>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.Where
-
Specifies a
KeySelectorfor elements from the second input with explicit type information for the key type. - equalTo(KeySelector<T2, KEY>, TypeInformation<KEY>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.Where
-
Specifies a
KeySelectorfor elements from the second input with explicit type information for the key type. - equalToReference(Tuple2<byte[], INPUT>) - Method in class org.apache.flink.streaming.api.operators.sortpartition.FixedLengthByteKeyAndValueComparator
- equalToReference(Tuple2<byte[], INPUT>) - Method in class org.apache.flink.streaming.api.operators.sortpartition.VariableLengthByteKeyAndValueComparator
- eraseTimestamp() - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
- eraseTimestamp() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
- ErrorInfo - Class in org.apache.flink.runtime.executiongraph
-
Simple container to hold an exception and the corresponding timestamp.
- ErrorInfo(Throwable, long) - Constructor for class org.apache.flink.runtime.executiongraph.ErrorInfo
- ErrorResponseBody - Class in org.apache.flink.runtime.rest.messages
-
Generic response body for communicating errors on the server.
- ErrorResponseBody(String) - Constructor for class org.apache.flink.runtime.rest.messages.ErrorResponseBody
- ErrorResponseBody(List<String>) - Constructor for class org.apache.flink.runtime.rest.messages.ErrorResponseBody
- errors - Variable in class org.apache.flink.runtime.rest.messages.ErrorResponseBody
- escapeForDifferentOS(String) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Escape all the dynamic property values.
- escapeWithDoubleQuote(String) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
- escapeWithSingleQuote(String) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
- estimate(ExecutionVertexID) - Method in class org.apache.flink.runtime.scheduler.adaptive.allocator.StateSizeEstimates
- ESTIMATED_TIME_TO_CONSUME_BUFFERS - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- estimateFalsePositiveProbability(long, int) - Static method in class org.apache.flink.runtime.operators.util.BloomFilter
-
Compute the false positive probability based on given input entries and bits size.
- EVENT_BUFFER - org.apache.flink.runtime.io.network.buffer.Buffer.DataType
-
Buffer.DataType.EVENT_BUFFERindicates that this buffer represents serialized data of an event. - EVENT_TIME - org.apache.flink.streaming.api.TimeDomain
-
Time is based on the timestamp of events.
- EventAnnouncement - Class in org.apache.flink.runtime.io.network.api
-
EventAnnouncementis announcing presence or receiving of anAbstractEvent. - EventAnnouncement(AbstractEvent, int) - Constructor for class org.apache.flink.runtime.io.network.api.EventAnnouncement
- EventListener<T> - Interface in org.apache.flink.runtime.util.event
- EventSerializer - Class in org.apache.flink.runtime.io.network.api.serialization
-
Utility class to serialize and deserialize task events.
- EventSerializer() - Constructor for class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
- eventTimeTimersQueue - Variable in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
-
Event time timers that are currently in-flight.
- EventTimeTrigger - Class in org.apache.flink.streaming.api.windowing.triggers
-
A
Triggerthat fires once the watermark passes the end of the window to which a pane belongs. - eventualOutputs - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The output writers for the data that this task forwards to the next task.
- evictAfter(Iterable<TimestampedValue<Object>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.CountEvictor
- evictAfter(Iterable<TimestampedValue<T>>, int, W, Evictor.EvictorContext) - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor
-
Optionally evicts elements.
- evictBefore(Iterable<TimestampedValue<Object>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.CountEvictor
- evictBefore(Iterable<TimestampedValue<T>>, int, W, Evictor.EvictorContext) - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor
-
Optionally evicts elements.
- EvictingWindowOperator<K,IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
A
WindowOperatorthat also allows anEvictorto be used. - EvictingWindowOperator(WindowAssigner<? super IN, W>, TypeSerializer<W>, KeySelector<IN, K>, TypeSerializer<K>, StateDescriptor<? extends ListState<StreamRecord<IN>>, ?>, InternalWindowFunction<Iterable<IN>, OUT, K, W>, Trigger<? super IN, ? super W>, Evictor<? super IN, ? super W>, long, OutputTag<IN>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
- EvictingWindowOperatorFactory<K,IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
- EvictingWindowOperatorFactory(WindowAssigner<? super IN, W>, TypeSerializer<W>, KeySelector<IN, K>, TypeSerializer<K>, StateDescriptor<? extends ListState<StreamRecord<IN>>, ?>, InternalWindowFunction<Iterable<IN>, OUT, K, W>, Trigger<? super IN, ? super W>, Evictor<? super IN, ? super W>, long, OutputTag<IN>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorFactory
- evictor(Evictor<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
-
Sets the
Evictorthat should be used to evict elements from a window before emission. - evictor(Evictor<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Sets the
Evictorthat should be used to evict elements from a window before emission. - evictor(Evictor<? super T, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Sets the
Evictorthat should be used to evict elements from a window before emission. - evictor(Evictor<? super T, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Sets the
Evictorthat should be used to evict elements from a window before emission. - evictor(Evictor<? super T, ? super W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
- Evictor<T,W extends Window> - Interface in org.apache.flink.streaming.api.windowing.evictors
-
An
Evictorcan remove elements from a pane before/after the evaluation of WindowFunction and after the window evaluation gets triggered by aTrigger - Evictor.EvictorContext - Interface in org.apache.flink.streaming.api.windowing.evictors
-
A context object that is given to
Evictormethods. - EXACTLY_ONCE - org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingMode
- EXACTLY_ONCE - org.apache.flink.streaming.api.CheckpointingMode
-
Deprecated.Sets the checkpointing mode to "exactly once".
- EXCEEDED_CHECKPOINT_TOLERABLE_FAILURE_MESSAGE - Static variable in class org.apache.flink.runtime.checkpoint.CheckpointFailureManager
- exception - Variable in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
An exception that was encountered by the asynchronous request handling thread.
- exceptionalOperationResultResponse(Throwable) - Method in class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.StatusHandler
-
Create an exceptional operation result from the given
Throwable. - exceptionalOperationResultResponse(Throwable) - Method in class org.apache.flink.runtime.rest.handler.dataset.ClusterDataSetDeleteHandlers.ClusterDataSetDeleteStatusHandler
- exceptionalOperationResultResponse(Throwable) - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingStatusHandler
- exceptionalOperationResultResponse(Throwable) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalStatusHandler
- exceptionalOperationResultResponse(Throwable) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointStatusHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.flink.runtime.rest.handler.PipelineErrorHandler
- ExceptionHandler<E extends Throwable> - Interface in org.apache.flink.runtime.operators.sort
-
Interface to be implemented by classes that handle exceptions.
- ExceptionHistoryEntry - Class in org.apache.flink.runtime.scheduler.exceptionhistory
-
ExceptionHistoryEntrycollects information about a single failure that triggered the scheduler's failure handling. - ExceptionHistoryEntry(Throwable, long, CompletableFuture<Map<String, String>>, String, TaskManagerLocation) - Constructor for class org.apache.flink.runtime.scheduler.exceptionhistory.ExceptionHistoryEntry
-
Instantiates a
ExceptionHistoryEntry. - ExceptionHistoryEntry.ArchivedTaskManagerLocation - Class in org.apache.flink.runtime.scheduler.exceptionhistory
-
ArchivedTaskManagerLocationrepresents a archived (static) version of aTaskManagerLocation. - ExceptionInChainedOperatorException - Exception in org.apache.flink.streaming.runtime.tasks
-
A special exception that signifies that the cause exception came from a chained operator.
- ExceptionInChainedOperatorException(String, Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.ExceptionInChainedOperatorException
- ExceptionInChainedOperatorException(Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.ExceptionInChainedOperatorException
- ExceptionInChainedStubException - Exception in org.apache.flink.runtime.operators.chaining
-
A special exception to indicate that an exception occurred in the nested call of a chained stub.
- ExceptionInChainedStubException(String, Exception) - Constructor for exception org.apache.flink.runtime.operators.chaining.ExceptionInChainedStubException
- ExceptionInfo(String, String, long) - Constructor for class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.ExceptionInfo
- ExceptionInfo(String, String, long, Map<String, String>, String, String, String) - Constructor for class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.ExceptionInfo
- exceptionUnwrap(Exception) - Static method in exception org.apache.flink.runtime.operators.chaining.ExceptionInChainedStubException
- excludeFromReset(int) - Method in class org.apache.flink.runtime.operators.BatchTask
- EXCLUSIVE - org.apache.flink.runtime.state.CheckpointedStateScope
-
Exclusive state belongs exclusively to one specific checkpoint / savepoint.
- ExclusiveBuffersUsageGauge - Class in org.apache.flink.runtime.io.network.metrics
-
Gauge metric measuring the exclusive buffers usage gauge for
SingleInputGates. - ExclusiveBuffersUsageGauge(SingleInputGate[]) - Constructor for class org.apache.flink.runtime.io.network.metrics.ExclusiveBuffersUsageGauge
- exclusivePhysicalFilePool - Variable in class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFilePool
-
Queue maintaining exclusive physical files for reusing.
- execute() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Triggers the program execution.
- execute(Runnable) - Method in enum org.apache.flink.runtime.concurrent.UnsupportedOperationExecutor
- execute(String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Triggers the program execution.
- execute(MailboxExecutor.MailOptions, ThrowingRunnable<? extends Exception>, String, Object...) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
- execute(StreamGraph) - Method in class org.apache.flink.streaming.api.environment.LocalStreamEnvironment
- execute(StreamGraph) - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
- execute(StreamGraph) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Triggers the program execution.
- executeAndCollect() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Triggers the distributed execution of the streaming dataflow and returns an iterator over the elements of the given DataStream.
- executeAndCollect(int) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Triggers the distributed execution of the streaming dataflow and returns an iterator over the elements of the given DataStream.
- executeAndCollect(String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Triggers the distributed execution of the streaming dataflow and returns an iterator over the elements of the given DataStream.
- executeAndCollect(String, int) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Triggers the distributed execution of the streaming dataflow and returns an iterator over the elements of the given DataStream.
- executeAsync() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Triggers the program asynchronously.
- executeAsync(String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Triggers the program execution asynchronously.
- executeAsync(StreamGraph) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Triggers the program execution asynchronously.
- executeBatchRequests(StateRequestContainer) - Method in interface org.apache.flink.runtime.asyncprocessing.StateExecutor
-
Execute a batch of state requests.
- executeJobBlocking(JobGraph) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
This method runs a job in blocking mode.
- Execution - Class in org.apache.flink.runtime.executiongraph
-
A single execution of a vertex.
- Execution(Executor, ExecutionVertex, int, long, Duration) - Constructor for class org.apache.flink.runtime.executiongraph.Execution
-
Creates a new Execution attempt.
- EXECUTION_PREFIX - Static variable in class org.apache.flink.runtime.util.bash.BashJavaUtils
- executionAttemptFailed(int, int, Throwable) - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator
-
Called when any subtask execution attempt of the task running the coordinated operator is failed/canceled.
- executionAttemptFailed(int, int, Throwable) - Method in class org.apache.flink.runtime.operators.coordination.OperatorCoordinatorHolder
- executionAttemptFailed(int, int, Throwable) - Method in class org.apache.flink.runtime.operators.coordination.RecreateOnResetOperatorCoordinator
- executionAttemptFailed(int, int, Throwable) - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinator
- executionAttemptFailed(int, int, Throwable) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
- ExecutionAttemptID - Class in org.apache.flink.runtime.executiongraph
-
Unique identifier for the attempt to execute a tasks.
- ExecutionAttemptID(ExecutionGraphID, ExecutionVertexID, int) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionAttemptID
- executionAttemptReady(int, int, OperatorCoordinator.SubtaskGateway) - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator
-
This is called when a subtask execution attempt of the Operator becomes ready to receive events.
- executionAttemptReady(int, int, OperatorCoordinator.SubtaskGateway) - Method in class org.apache.flink.runtime.operators.coordination.RecreateOnResetOperatorCoordinator
- executionAttemptReady(int, int, OperatorCoordinator.SubtaskGateway) - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinator
- executionAttemptReady(int, int, OperatorCoordinator.SubtaskGateway) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
- executionConfig - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
- executionConfig - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
- executionConfig - Variable in class org.apache.flink.runtime.state.DefaultOperatorStateBackendBuilder
-
The execution configuration.
- ExecutionConfigInfo(String, int, boolean, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
- executionDeployer - Variable in class org.apache.flink.runtime.scheduler.DefaultScheduler
- ExecutionDeployer - Interface in org.apache.flink.runtime.scheduler
-
This deployer is responsible for deploying executions.
- ExecutionDeployer.Factory - Interface in org.apache.flink.runtime.scheduler
-
Factory to instantiate the
ExecutionDeployer. - ExecutionDeploymentListener - Interface in org.apache.flink.runtime.executiongraph
-
A listener that is called when the deployment of an execution has been started/completed.
- ExecutionDeploymentReconciler - Interface in org.apache.flink.runtime.jobmaster
-
Component for reconciling the deployment state of executions.
- ExecutionDeploymentReconciler.Factory - Interface in org.apache.flink.runtime.jobmaster
-
Factory for
ExecutionDeploymentReconciler. - ExecutionDeploymentReconciliationHandler - Interface in org.apache.flink.runtime.jobmaster
-
Interface for triggering actions in case of state mismatches.
- ExecutionDeploymentReport - Class in org.apache.flink.runtime.taskexecutor
-
A report about the currently deployed executions of a TaskExecutor.
- ExecutionDeploymentReport(Set<ExecutionAttemptID>) - Constructor for class org.apache.flink.runtime.taskexecutor.ExecutionDeploymentReport
- ExecutionDeploymentState - Enum in org.apache.flink.runtime.jobmaster
-
Possible states for the deployment of an execution.
- ExecutionDeploymentTracker - Interface in org.apache.flink.runtime.jobmaster
-
A tracker for deployed executions.
- ExecutionDeploymentTrackerDeploymentListenerAdapter - Class in org.apache.flink.runtime.jobmaster
-
An adapter for using an
ExecutionDeploymentTrackeras anExecutionDeploymentListener. - ExecutionDeploymentTrackerDeploymentListenerAdapter(ExecutionDeploymentTracker) - Constructor for class org.apache.flink.runtime.jobmaster.ExecutionDeploymentTrackerDeploymentListenerAdapter
- ExecutionFailureHandler - Class in org.apache.flink.runtime.executiongraph.failover
-
This handler deals with task failures to return a
FailureHandlingResultwhich contains tasks to restart to recover from failures. - ExecutionFailureHandler(Configuration, SchedulingTopology, FailoverStrategy, RestartBackoffTimeStrategy, ComponentMainThreadExecutor, Collection<FailureEnricher>, FailureEnricher.Context, FailureEnricher.Context, MetricGroup) - Constructor for class org.apache.flink.runtime.executiongraph.failover.ExecutionFailureHandler
-
Creates the handler to deal with task failures.
- ExecutionGraph - Interface in org.apache.flink.runtime.executiongraph
-
The execution graph is the central data structure that coordinates the distributed execution of a data flow.
- ExecutionGraphCache - Interface in org.apache.flink.runtime.rest.handler.legacy
-
Cache for
ExecutionGraphInfowhich are obtained from the Flink cluster. - ExecutionGraphCheckpointPlanCalculatorContext - Class in org.apache.flink.runtime.executiongraph
-
A
CheckpointPlanCalculatorContextimplementation based on the information from anExecutionGraph. - ExecutionGraphCheckpointPlanCalculatorContext(ExecutionGraph) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionGraphCheckpointPlanCalculatorContext
- ExecutionGraphException - Exception in org.apache.flink.runtime.executiongraph
-
Base class for exceptions occurring in the
ExecutionGraph. - ExecutionGraphException - Exception in org.apache.flink.runtime.jobmaster
-
Exceptions thrown by operations on the
ExecutionGraphby theJobMaster. - ExecutionGraphException(String) - Constructor for exception org.apache.flink.runtime.executiongraph.ExecutionGraphException
- ExecutionGraphException(String) - Constructor for exception org.apache.flink.runtime.jobmaster.ExecutionGraphException
- ExecutionGraphException(String, Throwable) - Constructor for exception org.apache.flink.runtime.executiongraph.ExecutionGraphException
- ExecutionGraphException(String, Throwable) - Constructor for exception org.apache.flink.runtime.jobmaster.ExecutionGraphException
- ExecutionGraphException(Throwable) - Constructor for exception org.apache.flink.runtime.executiongraph.ExecutionGraphException
- ExecutionGraphException(Throwable) - Constructor for exception org.apache.flink.runtime.jobmaster.ExecutionGraphException
- ExecutionGraphFactory - Interface in org.apache.flink.runtime.scheduler
-
Factory for creating an
ExecutionGraph. - ExecutionGraphHandler - Class in org.apache.flink.runtime.scheduler
-
Handler for the
ExecutionGraphwhich offers some common operations. - ExecutionGraphHandler(ExecutionGraph, Logger, Executor, ComponentMainThreadExecutor) - Constructor for class org.apache.flink.runtime.scheduler.ExecutionGraphHandler
- ExecutionGraphID - Class in org.apache.flink.runtime.executiongraph
-
A class for statistically unique execution graph IDs.
- ExecutionGraphID() - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionGraphID
- ExecutionGraphID(byte[]) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionGraphID
- ExecutionGraphInfo - Class in org.apache.flink.runtime.scheduler
-
ExecutionGraphInfoserves as a composite class that provides differentExecutionGraph-related information. - ExecutionGraphInfo(ArchivedExecutionGraph) - Constructor for class org.apache.flink.runtime.scheduler.ExecutionGraphInfo
- ExecutionGraphInfo(ArchivedExecutionGraph, Iterable<RootExceptionHistoryEntry>) - Constructor for class org.apache.flink.runtime.scheduler.ExecutionGraphInfo
- ExecutionGraphInfoStore - Interface in org.apache.flink.runtime.dispatcher
-
Interface for a
ExecutionGraphInfostore. - ExecutionGraphResultPartitionAvailabilityChecker - Class in org.apache.flink.runtime.executiongraph
-
A
ResultPartitionAvailabilityCheckerwhich decides the intermediate result partition availability based on whether the corresponding result partition in the execution graph is tracked. - ExecutionGraphToInputsLocationsRetrieverAdapter - Class in org.apache.flink.runtime.scheduler
-
An implementation of
InputsLocationsRetrieverbased on theExecutionGraph. - ExecutionGraphToInputsLocationsRetrieverAdapter(ExecutionGraph) - Constructor for class org.apache.flink.runtime.scheduler.ExecutionGraphToInputsLocationsRetrieverAdapter
- ExecutionGraphUtils - Class in org.apache.flink.runtime.executiongraph
-
Utility methods related to
ExecutionGraph. - ExecutionGraphUtils() - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionGraphUtils
- ExecutionHistory - Class in org.apache.flink.runtime.executiongraph
-
This class hosts the historical executions of an
ExecutionVertexin aLinkedHashMapwith a size bound. - ExecutionHistory(int) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionHistory
- executionId() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
- ExecutionJobVertex - Class in org.apache.flink.runtime.executiongraph
- ExecutionJobVertex(InternalExecutionGraphAccessor, JobVertex, VertexParallelismInformation, CoordinatorStore, JobManagerJobMetricGroup) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- ExecutionJobVertex.Factory - Class in org.apache.flink.runtime.executiongraph
-
Factory to create
ExecutionJobVertex. - ExecutionJobVertexInitializedEvent - Class in org.apache.flink.runtime.jobmaster.event
-
This class is used to record the initialization info of
ExecutionJobVertex. - ExecutionJobVertexInitializedEvent(JobVertexID, int, Map<IntermediateDataSetID, JobVertexInputInfo>) - Constructor for class org.apache.flink.runtime.jobmaster.event.ExecutionJobVertexInitializedEvent
- ExecutionOperations - Interface in org.apache.flink.runtime.scheduler
-
Operations on the
Execution. - executionSlotAllocator - Variable in class org.apache.flink.runtime.scheduler.DefaultScheduler
- ExecutionSlotAllocator - Interface in org.apache.flink.runtime.scheduler
-
Component responsible for assigning slots to a collection of
Execution. - ExecutionSlotAllocatorFactory - Interface in org.apache.flink.runtime.scheduler
-
Interface for
ExecutionSlotAllocatorfactories. - ExecutionState - Enum in org.apache.flink.runtime.execution
-
An enumeration of all states that a task can be in during its execution.
- ExecutionStateUpdateListener - Interface in org.apache.flink.runtime.executiongraph
-
A listener that is called when an execution switched to a new state.
- ExecutionTimeBasedSlowTaskDetector - Class in org.apache.flink.runtime.scheduler.slowtaskdetector
-
The slow task detector which detects slow tasks based on their execution time.
- ExecutionTimeBasedSlowTaskDetector(Configuration) - Constructor for class org.apache.flink.runtime.scheduler.slowtaskdetector.ExecutionTimeBasedSlowTaskDetector
- ExecutionVertex - Class in org.apache.flink.runtime.executiongraph
-
The ExecutionVertex is a parallel subtask of the execution.
- ExecutionVertex(ExecutionJobVertex, int, IntermediateResult[], Duration, long, int, int) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
Creates an ExecutionVertex.
- ExecutionVertexFinishedEvent - Class in org.apache.flink.runtime.jobmaster.event
-
This class is used to record the state of
ExecutionVertex. - ExecutionVertexFinishedEvent(ExecutionAttemptID, TaskManagerLocation, Map<OperatorID, CompletableFuture<byte[]>>, CompletableFuture<ShuffleMasterSnapshot>, IOMetrics, Map<String, Accumulator<?, ?>>) - Constructor for class org.apache.flink.runtime.jobmaster.event.ExecutionVertexFinishedEvent
- ExecutionVertexID - Class in org.apache.flink.runtime.scheduler.strategy
-
Id identifying
ExecutionVertex. - ExecutionVertexID(JobVertexID, int) - Constructor for class org.apache.flink.runtime.scheduler.strategy.ExecutionVertexID
- ExecutionVertexInputInfo - Class in org.apache.flink.runtime.executiongraph
-
This class describe the inputs(partitions and subpartitions that belong to the same intermediate result) information of an execution vertex.
- ExecutionVertexInputInfo(int, IndexRange, IndexRange) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionVertexInputInfo
- ExecutionVertexResetEvent - Class in org.apache.flink.runtime.jobmaster.event
-
This class is used to record the
ExecutionVertexthat has been reset. - ExecutionVertexResetEvent(List<ExecutionVertexID>) - Constructor for class org.apache.flink.runtime.jobmaster.event.ExecutionVertexResetEvent
- ExecutionVertexVersion - Class in org.apache.flink.runtime.scheduler
-
This class helps to record version of an execution vertex.
- executionVertexVersioner - Variable in class org.apache.flink.runtime.scheduler.SchedulerBase
- ExecutionVertexVersioner - Class in org.apache.flink.runtime.scheduler
-
Records modifications of
ExecutionVertices, and allows for checking whether a vertex was modified. - ExecutionVertexVersioner() - Constructor for class org.apache.flink.runtime.scheduler.ExecutionVertexVersioner
- executor - Variable in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator
-
Executor used to run the futures.
- executor - Variable in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
- ExecutorNotifier - Class in org.apache.flink.runtime.source.coordinator
-
This class is used to coordinate between two components, where one component has an executor following the mailbox model and the other component notifies it when needed.
- ExecutorNotifier(ScheduledExecutorService, Executor) - Constructor for class org.apache.flink.runtime.source.coordinator.ExecutorNotifier
- executorService - Variable in class org.apache.flink.runtime.io.disk.iomanager.IOManager
- exists() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
- exists(String) - Method in interface org.apache.flink.runtime.persistence.StateHandleStore
-
Returns resource version of state handle with specific name on the underlying storage.
- exists(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Returns the version of the node if it exists and is not marked for deletion or
-1. - expired(long, long, long) - Static method in class org.apache.flink.runtime.state.ttl.TtlUtils
- ExponentialDelayRestartBackoffTimeStrategy - Class in org.apache.flink.runtime.executiongraph.failover
-
Restart strategy which tries to restart indefinitely number of times with an exponential backoff time in between.
- ExponentialDelayRestartBackoffTimeStrategy.ExponentialDelayRestartBackoffTimeStrategyFactory - Class in org.apache.flink.runtime.executiongraph.failover
-
The factory for creating
ExponentialDelayRestartBackoffTimeStrategy. - ExponentialDelayRestartBackoffTimeStrategyFactory(long, long, double, long, double, int) - Constructor for class org.apache.flink.runtime.executiongraph.failover.ExponentialDelayRestartBackoffTimeStrategy.ExponentialDelayRestartBackoffTimeStrategyFactory
- EXTERNAL_POINTER - Static variable in class org.apache.flink.runtime.state.memory.NonPersistentMetadataCheckpointStorageLocation
-
The external pointer returned for checkpoints that are not externally addressable.
- ExternalizedCheckpointInfo(boolean, boolean) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ExternalizedCheckpointInfo
- ExternallyInducedSource<T,CD> - Interface in org.apache.flink.streaming.api.checkpoint
-
Deprecated.This interface is based on the
SourceFunctionAPI, which is due to be removed. Use the newSourceAPI instead. - ExternallyInducedSource.CheckpointTrigger - Interface in org.apache.flink.streaming.api.checkpoint
-
Deprecated.Through the
CheckpointTrigger, the source function notifies the Flink source operator when to trigger the checkpoint. - ExternalResourceInfoProvider - Interface in org.apache.flink.runtime.externalresource
-
Provide the information of external resources.
- ExternalResourceUtils - Class in org.apache.flink.runtime.externalresource
-
Utility class for external resource framework.
- ExternalSorter<E> - Class in org.apache.flink.runtime.operators.sort
-
The
ExternalSorteris a full fledged sorter. - ExternalSorterBuilder<T> - Class in org.apache.flink.runtime.operators.sort
-
A builder for an
ExternalSorter. - extractAndUploadJobGraphFiles(JobGraph, SupplierWithException<BlobClient, IOException>) - Static method in enum org.apache.flink.runtime.client.ClientUtils
-
Extracts all files required for the execution from the given
JobGraphand uploads them using theBlobClientfrom the givenSupplier. - extractFieldTypes(int[], TypeInformation<?>) - Static method in class org.apache.flink.streaming.api.datastream.StreamProjection
- extractFromSystem(long) - Static method in class org.apache.flink.runtime.instance.HardwareDescription
- extractIntersectingState(Collection<? extends KeyedStateHandle>, KeyGroupRange, List<KeyedStateHandle>) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
-
Extracts certain key group ranges from the given state handles and adds them to the collector.
- extractKeyFromElement(T) - Method in interface org.apache.flink.runtime.state.KeyExtractorFunction
-
Returns the key for the given element by which the key-group can be computed.
- extractKeyGroup(int, byte[]) - Static method in class org.apache.flink.runtime.state.CompositeKeySerializationUtils
- extractKeys(Object, Object[], int) - Method in class org.apache.flink.streaming.api.operators.sortpartition.FixedLengthByteKeyAndValueComparator
- extractKeys(Object, Object[], int) - Method in class org.apache.flink.streaming.api.operators.sortpartition.VariableLengthByteKeyAndValueComparator
- extractTriggerId(SavepointTriggerRequestBody) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointTriggerHandler
- extractTriggerId(StopWithSavepointRequestBody) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.StopWithSavepointHandler
F
- facets() - Method in class org.apache.flink.streaming.api.lineage.DefaultLineageDataset
- facets() - Method in interface org.apache.flink.streaming.api.lineage.LineageDataset
- Factory() - Constructor for class org.apache.flink.runtime.blocklist.NoOpBlocklistHandler.Factory
- Factory() - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionJobVertex.Factory
- Factory() - Constructor for class org.apache.flink.runtime.executiongraph.failover.partitionrelease.NotReleasingPartitionGroupReleaseStrategy.Factory
- Factory() - Constructor for class org.apache.flink.runtime.executiongraph.failover.partitionrelease.RegionPartitionGroupReleaseStrategy.Factory
- Factory() - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartAllFailoverStrategy.Factory
- Factory() - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionFailoverStrategy.Factory
- Factory() - Constructor for class org.apache.flink.runtime.executiongraph.SpeculativeExecutionJobVertex.Factory
- Factory() - Constructor for class org.apache.flink.runtime.scheduler.DefaultExecutionDeployer.Factory
- Factory() - Constructor for class org.apache.flink.runtime.scheduler.strategy.PipelinedRegionSchedulingStrategy.Factory
- Factory() - Constructor for class org.apache.flink.runtime.util.DefaultGroupCache.Factory
- Factory(int, long, int, FileDataIndexRegionHelper<T>) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.index.FileDataIndexSpilledRegionManagerImpl.Factory
- Factory(Duration) - Constructor for class org.apache.flink.runtime.blocklist.DefaultBlocklistHandler.Factory
- Factory(Duration, int, Ticker) - Constructor for class org.apache.flink.runtime.util.DefaultGroupCache.Factory
- Factory(PhysicalSlotProvider, boolean) - Constructor for class org.apache.flink.runtime.scheduler.SimpleExecutionSlotAllocator.Factory
- Factory(InputConsumableDecider.Factory) - Constructor for class org.apache.flink.runtime.scheduler.strategy.VertexwiseSchedulingStrategy.Factory
- FACTORY_CLASS - org.apache.flink.runtime.jobmanager.HighAvailabilityMode
- fail(String) - Method in class org.apache.flink.runtime.rest.messages.ProfilingInfo
- fail(Throwable) - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStatePendingResult
- fail(Throwable) - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter.ChannelStateWriteResult
- fail(Throwable) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
This method fails the vertex due to an external condition.
- fail(Throwable) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- fail(Throwable) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- fail(Throwable) - Method in class org.apache.flink.runtime.executiongraph.SpeculativeExecutionVertex
- fail(Throwable) - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
Fail the production of the partition.
- fail(Throwable) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- fail(Throwable) - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot.Payload
-
Fail the payload with the given cause.
- failAllFutures(Throwable) - Method in class org.apache.flink.runtime.operators.coordination.util.IncompleteFuturesTracker
- failAllocation(ResourceID, AllocationID, Exception) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolService
- failAllocation(ResourceID, AllocationID, Exception) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolService
-
Fails the allocation with the given allocationId.
- failConsumption(Throwable) - Method in interface org.apache.flink.runtime.io.network.partition.PartitionProducerStateProvider.ResponseHandle
-
Fail the partition consumptions as a result of state check.
- FAILED - org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
-
Checkpoint that failed.
- FAILED - org.apache.flink.runtime.checkpoint.InitializationStatus
- FAILED - org.apache.flink.runtime.clusterframework.ApplicationStatus
-
Application encountered an unrecoverable failure or error.
- FAILED - org.apache.flink.runtime.execution.ExecutionState
- FAILED - org.apache.flink.runtime.rest.messages.ProfilingInfo.ProfilingStatus
- FAILED - org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestState
- FAILED_COMMITTABLES - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- FailedCheckpointStatistics(long, CheckpointStatsStatus, boolean, String, long, long, long, long, long, long, long, long, int, int, CheckpointStatistics.RestAPICheckpointType, Map<JobVertexID, TaskCheckpointStatistics>, long, String) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.FailedCheckpointStatistics
- FailedCheckpointStats - Class in org.apache.flink.runtime.checkpoint
-
Statistics for a failed checkpoint.
- failExternally(Throwable) - Method in interface org.apache.flink.runtime.execution.Environment
-
Marks task execution failed for an external reason (a reason other than the task code itself throwing an exception).
- failExternally(Throwable) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotPayload
-
Fail the payload with the given throwable.
- failExternally(Throwable) - Method in class org.apache.flink.runtime.taskmanager.NoOpTaskActions
- failExternally(Throwable) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- failExternally(Throwable) - Method in class org.apache.flink.runtime.taskmanager.Task
-
Marks task execution failed for an external reason (a reason other than the task code itself throwing an exception).
- failExternally(Throwable) - Method in interface org.apache.flink.runtime.taskmanager.TaskActions
-
Fail the owning task with the given throwable.
- failGlobal(Throwable) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- failGlobal(Throwable) - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
-
Fails the execution graph globally.
- failJob(Throwable) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointFailureManager.FailJobCallback
-
Fails the whole job graph.
- failJob(Throwable) - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator.Context
-
Fails the job and trigger a global failover operation.
- failJob(Throwable, long) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- failJob(Throwable, long) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- failJob(Throwable, long, CompletableFuture<Map<String, String>>) - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.BatchJobRecoveryContext
-
Trigger job failure.
- failJob(Throwable, long, CompletableFuture<Map<String, String>>) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- failJobDueToTaskFailure(Throwable, ExecutionAttemptID) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointFailureManager.FailJobCallback
-
Fails the whole job graph due to task failure.
- failoverStrategy - Variable in class org.apache.flink.runtime.scheduler.DefaultScheduler
- FailoverStrategy - Interface in org.apache.flink.runtime.executiongraph.failover
-
New interface for failover strategies.
- FailoverStrategy.Factory - Interface in org.apache.flink.runtime.executiongraph.failover
-
The factory to instantiate
FailoverStrategy. - FailoverStrategyFactoryLoader - Class in org.apache.flink.runtime.executiongraph.failover
-
A utility class to load NG failover strategy factories from the configuration.
- failSlot(ResourceID, AllocationID, Exception) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- failSlot(ResourceID, AllocationID, Exception) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Fails the slot with the given allocation id and cause.
- failTask(ExecutionAttemptID, Throwable) - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerActions
-
Tells the task manager to fail the given task.
- failure(Throwable) - Static method in class org.apache.flink.runtime.rest.handler.async.OperationResult
- Failure(Throwable) - Constructor for class org.apache.flink.runtime.registration.RegistrationResponse.Failure
-
Creates a new failure message.
- FAILURE - org.apache.flink.runtime.rest.handler.async.OperationResultStatus
- FAILURE - org.apache.flink.runtime.taskexecutor.TaskManagerRunner.Result
- FAILURE_EXIT_CODE - Static variable in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
- FAILURE_LABEL_ATTRIBUTE_PREFIX - Static variable in class org.apache.flink.runtime.executiongraph.failover.ExecutionFailureHandler
- FAILURE_LABEL_ATTRIBUTE_PREFIX - Static variable in class org.apache.flink.runtime.scheduler.adaptive.JobFailureMetricReporter
- FailureEnricherUtils - Class in org.apache.flink.runtime.failure
-
Utils class for loading and running pluggable failure enrichers.
- FailureEnricherUtils() - Constructor for class org.apache.flink.runtime.failure.FailureEnricherUtils
- FailureHandlingResult - Class in org.apache.flink.runtime.executiongraph.failover
-
Result containing the tasks to restart upon a task failure.
- FailureHandlingResultSnapshot - Class in org.apache.flink.runtime.scheduler.exceptionhistory
-
FailureHandlingResultSnapshotcreates a snapshot of aFailureHandlingResultproviding the actualExecutions. - FailureLabel(String, String) - Constructor for class org.apache.flink.runtime.rest.messages.job.FailureLabelFilterParameter.FailureLabel
- FailureLabelFilterParameter - Class in org.apache.flink.runtime.rest.messages.job
-
Specifies a collections of failure labels, filtering the exceptions returned for JobExceptionsHandler.
- FailureLabelFilterParameter() - Constructor for class org.apache.flink.runtime.rest.messages.job.FailureLabelFilterParameter
- FailureLabelFilterParameter.FailureLabel - Class in org.apache.flink.runtime.rest.messages.job
-
Represents a failure label consisting of a KV pair of strings.
- FailureRateRestartBackoffTimeStrategy - Class in org.apache.flink.runtime.executiongraph.failover
-
Restart strategy which can restart when failure rate is not exceeded.
- FailureRateRestartBackoffTimeStrategy.FailureRateRestartBackoffTimeStrategyFactory - Class in org.apache.flink.runtime.executiongraph.failover
-
The factory for creating
FailureRateRestartBackoffTimeStrategy. - FailureRateRestartBackoffTimeStrategyFactory(int, long, long) - Constructor for class org.apache.flink.runtime.executiongraph.failover.FailureRateRestartBackoffTimeStrategy.FailureRateRestartBackoffTimeStrategyFactory
- FailureResultUtil - Class in org.apache.flink.runtime.scheduler.adaptive
-
FailureResultUtilcontains helper methods forFailureResult. - FailureResultUtil() - Constructor for class org.apache.flink.runtime.scheduler.adaptive.FailureResultUtil
- fairSelectNextIndex(long, int) - Method in class org.apache.flink.streaming.api.operators.InputSelection
-
Fairly select one of the available inputs for reading.
- fairSelectNextIndex(long, long, int) - Static method in class org.apache.flink.streaming.api.operators.InputSelection
-
Fairly select one of the available inputs for reading.
- fairSelectNextIndexOutOf2(int, int) - Method in class org.apache.flink.streaming.api.operators.InputSelection
-
Fairly select one of the two inputs for reading.
- fairSelectNextIndexOutOf2(int, int, int) - Static method in class org.apache.flink.streaming.api.operators.InputSelection
-
Fairly select one of the two inputs for reading.
- Features(boolean, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.rest.messages.DashboardConfiguration.Features
- FeedbackTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This represents a feedback point in a topology.
- FeedbackTransformation(Transformation<T>, Long) - Constructor for class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
Creates a new
FeedbackTransformationfrom the given input. - FIELD_NAME_ABORTED - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
- FIELD_NAME_ACC_BACK_PRESSURE - Static variable in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- FIELD_NAME_ACC_BUSY - Static variable in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- FIELD_NAME_ACC_IDLE - Static variable in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- FIELD_NAME_ACC_NAME - Static variable in class org.apache.flink.runtime.rest.messages.job.UserAccumulator
- FIELD_NAME_ACC_NAME - Static variable in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
- FIELD_NAME_ACC_TYPE - Static variable in class org.apache.flink.runtime.rest.messages.job.UserAccumulator
- FIELD_NAME_ACC_TYPE - Static variable in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
- FIELD_NAME_ACC_VALUE - Static variable in class org.apache.flink.runtime.rest.messages.job.UserAccumulator
- FIELD_NAME_ACC_VALUE - Static variable in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
- FIELD_NAME_ACK_TIMESTAMP - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
- FIELD_NAME_ADDRESS - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- FIELD_NAME_AGGREGATED - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
- FIELD_NAME_ALIGNED_CHECKPOINT_TIMEOUT - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
- FIELD_NAME_ALIGNMENT - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
- FIELD_NAME_ALIGNMENT - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
- FIELD_NAME_ALIGNMENT_BUFFERED - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
- FIELD_NAME_ALIGNMENT_BUFFERED - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- FIELD_NAME_ALIGNMENT_BUFFERED - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
- FIELD_NAME_ALIGNMENT_BUFFERED - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
- FIELD_NAME_ALIGNMENT_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
- FIELD_NAME_ALIGNMENT_PERSISTED - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
- FIELD_NAME_ALIGNMENT_PROCESSED - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
- FIELD_NAME_ALLOCATED_SLOTS - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsInfo
- FIELD_NAME_ASYNC_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
- FIELD_NAME_ASYNCHRONOUS_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
- FIELD_NAME_ATTEMPT - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- FIELD_NAME_ATTEMPT_NUM - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsInfo
- FIELD_NAME_ATTEMPT_NUM - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo
- FIELD_NAME_ATTEMPT_NUMBER - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
- FIELD_NAME_AVAILABLE_RESOURCE - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- FIELD_NAME_AVERAGE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.StatsSummaryDto
- FIELD_NAME_BACK_PRESSURED_RATIO - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
- FIELD_NAME_BACKPRESSURE_LEVEL - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
- FIELD_NAME_BACKPRESSURE_LEVEL - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
- FIELD_NAME_BLOCKED - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- FIELD_NAME_BUFFERED_DATA - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
- FIELD_NAME_BUSY_RATIO - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
- FIELD_NAME_BYTES_READ - Static variable in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- FIELD_NAME_BYTES_WRITTEN - Static variable in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- FIELD_NAME_CHANGELOG_STORAGE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
- FIELD_NAME_CHECKPOINT_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
- FIELD_NAME_CHECKPOINT_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
- FIELD_NAME_CHECKPOINT_INTERVAL - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
- FIELD_NAME_CHECKPOINT_MAX_CONCURRENT - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
- FIELD_NAME_CHECKPOINT_MIN_PAUSE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
- FIELD_NAME_CHECKPOINT_STATUS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics
- FIELD_NAME_CHECKPOINT_STATUS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
- FIELD_NAME_CHECKPOINT_STORAGE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
- FIELD_NAME_CHECKPOINT_TIMEOUT - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
- FIELD_NAME_CHECKPOINT_TYPE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- FIELD_NAME_CHECKPOINTED_SIZE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
- FIELD_NAME_CHECKPOINTED_SIZE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- FIELD_NAME_CHECKPOINTED_SIZE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
- FIELD_NAME_CHECKPOINTED_SIZE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
- FIELD_NAME_CHECKPOINTED_SIZE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
- FIELD_NAME_CHECKPOINTS_AFTER_TASKS_FINISH - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
- FIELD_NAME_COMMIT - Static variable in class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
- FIELD_NAME_COMPATIBLE_START_TIME - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- FIELD_NAME_COMPLETED - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
- FIELD_NAME_COMPLETED_CHECKPOINTS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
- FIELD_NAME_CONCURRENT_EXCEPTIONS - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.RootExceptionInfo
- FIELD_NAME_CONFIG_KEY - Static variable in class org.apache.flink.runtime.rest.messages.ConfigurationInfoEntry
- FIELD_NAME_CONFIG_VALUE - Static variable in class org.apache.flink.runtime.rest.messages.ConfigurationInfoEntry
- FIELD_NAME_COUNT - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo.GarbageCollectorInfo
- FIELD_NAME_COUNTS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
- FIELD_NAME_CPU - Static variable in class org.apache.flink.runtime.rest.messages.ResourceProfileInfo
- FIELD_NAME_CPU_CORES - Static variable in class org.apache.flink.runtime.instance.HardwareDescription
- FIELD_NAME_DATA_PORT - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- FIELD_NAME_DELETE_ON_CANCELLATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ExternalizedCheckpointInfo
- FIELD_NAME_DIRECT_COUNT - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
- FIELD_NAME_DIRECT_MAX - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
- FIELD_NAME_DIRECT_USED - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
- FIELD_NAME_DISCARDED - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.CompletedCheckpointStatistics
- FIELD_NAME_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
- FIELD_NAME_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- FIELD_NAME_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
- FIELD_NAME_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
- FIELD_NAME_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
- FIELD_NAME_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
- FIELD_NAME_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- FIELD_NAME_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.ProfilingInfo
- FIELD_NAME_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
- FIELD_NAME_ENABLED - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ExternalizedCheckpointInfo
- FIELD_NAME_END_TIME - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_END_TIME - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- FIELD_NAME_END_TIMESTAMP - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
- FIELD_NAME_ENDPOINT - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- FIELD_NAME_ENDPOINT - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo
- FIELD_NAME_ENDPOINT - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.ExceptionInfo
- FIELD_NAME_ENDPOINT - Static variable in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
- FIELD_NAME_ENTRIES - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.JobExceptionHistory
- FIELD_NAME_EXCEPTION_HISTORY - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory
- FIELD_NAME_EXCEPTION_NAME - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.ExceptionInfo
- FIELD_NAME_EXCEPTION_STACKTRACE - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.ExceptionInfo
- FIELD_NAME_EXCEPTION_TIMESTAMP - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.ExceptionInfo
- FIELD_NAME_EXECUTION_CONFIG - Static variable in class org.apache.flink.runtime.rest.messages.JobConfigInfo
- FIELD_NAME_EXTENDED - Static variable in class org.apache.flink.runtime.rest.messages.ResourceProfileInfo
- FIELD_NAME_EXTERNAL_PATH - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
- FIELD_NAME_EXTERNAL_PATH - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.CompletedCheckpointStatistics
- FIELD_NAME_EXTERNALIZED_CHECKPOINT_CONFIG - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
- FIELD_NAME_FAILED - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
- FIELD_NAME_FAILED_CHECKPOINTS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
- FIELD_NAME_FAILURE_LABELS - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.ExceptionInfo
- FIELD_NAME_FAILURE_MESSAGE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.FailedCheckpointStatistics
- FIELD_NAME_FAILURE_TIMESTAMP - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.FailedCheckpointStatistics
- FIELD_NAME_FEATURE_WEB_CANCEL - Static variable in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
- FIELD_NAME_FEATURE_WEB_HISTORY - Static variable in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
- FIELD_NAME_FEATURE_WEB_RESCALE - Static variable in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
- FIELD_NAME_FEATURE_WEB_SUBMIT - Static variable in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
- FIELD_NAME_FINISHED_TIME - Static variable in class org.apache.flink.runtime.rest.messages.ProfilingInfo
- FIELD_NAME_FLAME_GRAPHS - Static variable in class org.apache.flink.runtime.rest.messages.ProfilingInfoList
- FIELD_NAME_FLINK_FEATURES - Static variable in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
- FIELD_NAME_FLINK_REVISION - Static variable in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
- FIELD_NAME_FLINK_VERSION - Static variable in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
- FIELD_NAME_FORMAT_TYPE - Static variable in class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointRequestBody
- FIELD_NAME_FRAMEWORK_HEAP - Static variable in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
- FIELD_NAME_FRAMEWORK_OFFHEAP - Static variable in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
- FIELD_NAME_GARBAGE_COLLECTORS - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
- FIELD_NAME_GLOBAL_JOB_PARAMETERS - Static variable in class org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
- FIELD_NAME_HARDWARE - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- FIELD_NAME_HEAP_COMMITTED - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
- FIELD_NAME_HEAP_MAX - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
- FIELD_NAME_HEAP_USED - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
- FIELD_NAME_HISTORY - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
- FIELD_NAME_ID - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
- FIELD_NAME_ID - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- FIELD_NAME_ID - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
- FIELD_NAME_ID - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsInfo
- FIELD_NAME_ID - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsInfo
- FIELD_NAME_ID - Static variable in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
- FIELD_NAME_IDLE_RATIO - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
- FIELD_NAME_IN_PROGRESS_CHECKPOINTS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
- FIELD_NAME_INDEX - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics
- FIELD_NAME_IS_SAVEPOINT - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
- FIELD_NAME_IS_SAVEPOINT - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- FIELD_NAME_IS_STOPPABLE - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_JMX_PORT - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- FIELD_NAME_JOB_ACCUMULATORS - Static variable in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
- FIELD_NAME_JOB_GRAPH - Static variable in class org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody
- FIELD_NAME_JOB_ID - Static variable in class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview.JobIdWithStatus
- FIELD_NAME_JOB_ID - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_JOB_ID - Static variable in class org.apache.flink.runtime.rest.messages.JobConfigInfo
- FIELD_NAME_JOB_ID - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.SlotInfo
- FIELD_NAME_JOB_NAME - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_JOB_NAME - Static variable in class org.apache.flink.runtime.rest.messages.JobConfigInfo
- FIELD_NAME_JOB_STATUS - Static variable in class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview.JobIdWithStatus
- FIELD_NAME_JOB_STATUS - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_JOB_TYPE - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_JOB_URL - Static variable in class org.apache.flink.runtime.rest.messages.job.JobSubmitResponseBody
- FIELD_NAME_JOB_VERTEX_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- FIELD_NAME_JOB_VERTEX_END_TIME - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- FIELD_NAME_JOB_VERTEX_ID - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- FIELD_NAME_JOB_VERTEX_ID - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo
- FIELD_NAME_JOB_VERTEX_INFOS - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_JOB_VERTEX_METRICS - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- FIELD_NAME_JOB_VERTEX_NAME - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- FIELD_NAME_JOB_VERTEX_START_TIME - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- FIELD_NAME_JOB_VERTEX_STATE - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- FIELD_NAME_JOB_VERTICES_PER_STATE - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_JOBS - Static variable in class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview
- FIELD_NAME_JOBS - Static variable in class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
- FIELD_NAME_JOBS_CANCELLED - Static variable in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
- FIELD_NAME_JOBS_FAILED - Static variable in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
- FIELD_NAME_JOBS_FINISHED - Static variable in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
- FIELD_NAME_JOBS_RUNNING - Static variable in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
- FIELD_NAME_JSON_PLAN - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_JVM_METASPACE - Static variable in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
- FIELD_NAME_JVM_OVERHEAD - Static variable in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
- FIELD_NAME_LAST_HEARTBEAT - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- FIELD_NAME_LATEST_ACK_TIMESTAMP - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- FIELD_NAME_LATEST_ACK_TIMESTAMP - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
- FIELD_NAME_LATEST_CHECKPOINTS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
- FIELD_NAME_LOG_URL - Static variable in class org.apache.flink.runtime.rest.messages.LogUrlResponse
- FIELD_NAME_LOGS - Static variable in class org.apache.flink.runtime.rest.messages.LogListInfo
- FIELD_NAME_MANAGED - Static variable in class org.apache.flink.runtime.rest.messages.ResourceProfileInfo
- FIELD_NAME_MANAGED_MEMORY - Static variable in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
- FIELD_NAME_MAPPED_COUNT - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
- FIELD_NAME_MAPPED_MAX - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
- FIELD_NAME_MAPPED_USED - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
- FIELD_NAME_MAX_PARALLELISM - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_MAX_PARALLELISM - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- FIELD_NAME_MAX_PARALLELISM - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
- FIELD_NAME_MAXIMUM - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.StatsSummaryDto
- FIELD_NAME_MEMORY - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- FIELD_NAME_MESSAGE - Static variable in class org.apache.flink.runtime.rest.messages.ProfilingInfo
- FIELD_NAME_METRICS - Static variable in class org.apache.flink.runtime.rest.messages.AggregatedTaskDetailsInfo
- FIELD_NAME_METRICS - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- FIELD_NAME_METRICS - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsInfo
- FIELD_NAME_MINIMUM - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.StatsSummaryDto
- FIELD_NAME_MODE - Static variable in class org.apache.flink.runtime.rest.messages.ProfilingInfo
- FIELD_NAME_NAME - Static variable in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
- FIELD_NAME_NAME - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo.GarbageCollectorInfo
- FIELD_NAME_NETWORK - Static variable in class org.apache.flink.runtime.rest.messages.ResourceProfileInfo
- FIELD_NAME_NETWORK_MEMORY - Static variable in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
- FIELD_NAME_NON_HEAP_COMMITTED - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
- FIELD_NAME_NON_HEAP_MAX - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
- FIELD_NAME_NON_HEAP_USED - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
- FIELD_NAME_NOW - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_NOW - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
- FIELD_NAME_NOW - Static variable in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
- FIELD_NAME_NUM_ACK_SUBTASKS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- FIELD_NAME_NUM_ACK_SUBTASKS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
- FIELD_NAME_NUM_SUBTASKS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- FIELD_NAME_NUM_SUBTASKS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
- FIELD_NAME_NUMBER_AVAILABLE_SLOTS - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- FIELD_NAME_NUMBER_SLOTS - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- FIELD_NAME_OBJECT_REUSE_MODE - Static variable in class org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
- FIELD_NAME_OPERATION - Static variable in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationResult
- FIELD_NAME_OTHER_CONCURRENT_ATTEMPTS - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- FIELD_NAME_OTHER_CONCURRENT_ATTEMPTS - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
- FIELD_NAME_OUTPUT_FILE - Static variable in class org.apache.flink.runtime.rest.messages.ProfilingInfo
- FIELD_NAME_P50 - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.StatsSummaryDto
- FIELD_NAME_P90 - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.StatsSummaryDto
- FIELD_NAME_P95 - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.StatsSummaryDto
- FIELD_NAME_P99 - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.StatsSummaryDto
- FIELD_NAME_P999 - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.StatsSummaryDto
- FIELD_NAME_PARALLELISM - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- FIELD_NAME_PARALLELISM - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo
- FIELD_NAME_PARALLELISM - Static variable in class org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
- FIELD_NAME_PARALLELISM - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
- FIELD_NAME_PERIODIC_MATERIALIZATION_INTERVAL - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
- FIELD_NAME_PERSISTED - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
- FIELD_NAME_PERSISTED_DATA - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
- FIELD_NAME_PERSISTED_DATA - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- FIELD_NAME_PERSISTED_DATA - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
- FIELD_NAME_PROCESSED - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
- FIELD_NAME_PROCESSED_DATA - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
- FIELD_NAME_PROCESSED_DATA - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- FIELD_NAME_PROCESSED_DATA - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
- FIELD_NAME_PROCESSING_MODE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
- FIELD_NAME_RECORDS_READ - Static variable in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- FIELD_NAME_RECORDS_WRITTEN - Static variable in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- FIELD_NAME_REFRESH_INTERVAL - Static variable in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
- FIELD_NAME_RESOURCE - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.SlotInfo
- FIELD_NAME_RESOURCE_ID - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- FIELD_NAME_RESTART_STRATEGY - Static variable in class org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
- FIELD_NAME_RESTORE_TIMESTAMP - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
- FIELD_NAME_RESTORED - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
- FIELD_NAME_RESTORED_CHECKPOINTS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
- FIELD_NAME_SAVEPOINT - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
- FIELD_NAME_SAVEPOINT_FORMAT - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- FIELD_NAME_SAVEPOINT_PATH - Static variable in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalRequest
- FIELD_NAME_SERIALIZED_COORDINATION_REQUEST - Static variable in class org.apache.flink.runtime.rest.messages.job.coordination.ClientCoordinationRequestBody
- FIELD_NAME_SERIALIZED_COORDINATION_RESULT - Static variable in class org.apache.flink.runtime.rest.messages.job.coordination.ClientCoordinationResponseBody
- FIELD_NAME_SERIALIZED_THROWABLE - Static variable in class org.apache.flink.runtime.rest.messages.json.SerializedThrowableSerializer
- FIELD_NAME_SERIALIZED_USER_TASK_ACCUMULATORS - Static variable in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
- FIELD_NAME_SHUFFLE_MEMORY_AVAILABLE - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
- FIELD_NAME_SHUFFLE_MEMORY_SEGMENTS_AVAILABLE - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
- FIELD_NAME_SHUFFLE_MEMORY_SEGMENTS_TOTAL - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
- FIELD_NAME_SHUFFLE_MEMORY_SEGMENTS_USED - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
- FIELD_NAME_SHUFFLE_MEMORY_TOTAL - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
- FIELD_NAME_SHUFFLE_MEMORY_USED - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
- FIELD_NAME_SIZE_JVM_HEAP - Static variable in class org.apache.flink.runtime.instance.HardwareDescription
- FIELD_NAME_SIZE_MANAGED_MEMORY - Static variable in class org.apache.flink.runtime.instance.HardwareDescription
- FIELD_NAME_SIZE_PHYSICAL_MEMORY - Static variable in class org.apache.flink.runtime.instance.HardwareDescription
- FIELD_NAME_SLOT_SHARING_GROUP_ID - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- FIELD_NAME_SLOTS_AVAILABLE - Static variable in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
- FIELD_NAME_SLOTS_FREE_AND_BLOCKED - Static variable in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
- FIELD_NAME_SLOTS_TOTAL - Static variable in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
- FIELD_NAME_START_DELAY - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
- FIELD_NAME_START_DELAY - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
- FIELD_NAME_START_TIME - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_START_TIME - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- FIELD_NAME_STATE_BACKEND - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
- FIELD_NAME_STATE_CHANGELOG - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
- FIELD_NAME_STATE_SIZE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
-
The accurate name of this field should be 'checkpointed_data_size', keep it as before to not break backwards compatibility for old web UI.
- FIELD_NAME_STATE_SIZE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
The accurate name of this field should be 'checkpointed_data_size', keep it as before to not break backwards compatibility for old web UI.
- FIELD_NAME_STATE_SIZE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
-
The accurate name of this field should be 'checkpointed_data_size', keep it as before to not break backwards compatibility for old web UI.
- FIELD_NAME_STATE_SIZE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
The accurate name of this field should be 'checkpointed_data_size', keep it as before to not break backwards compatibility for old web UI.
- FIELD_NAME_STATE_SIZE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
-
The accurate name of this field should be 'checkpointed_data_size', keep it as before to not break backwards compatibility for old web UI.
- FIELD_NAME_STATUS - Static variable in class org.apache.flink.runtime.messages.webmonitor.JobStatusInfo
- FIELD_NAME_STATUS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- FIELD_NAME_STATUS - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- FIELD_NAME_STATUS - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
- FIELD_NAME_STATUS - Static variable in class org.apache.flink.runtime.rest.messages.ProfilingInfo
- FIELD_NAME_STATUS_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.AggregatedTaskDetailsInfo
- FIELD_NAME_STATUS_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- FIELD_NAME_SUBTASK - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
- FIELD_NAME_SUBTASK - Static variable in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
- FIELD_NAME_SUBTASK_INDEX - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsInfo
- FIELD_NAME_SUBTASK_INDEX - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- FIELD_NAME_SUBTASK_INDEX - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo
- FIELD_NAME_SUBTASKS - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo
- FIELD_NAME_SUBTASKS - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
- FIELD_NAME_SUBTASKS - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
- FIELD_NAME_SUBTASKS - Static variable in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
- FIELD_NAME_SUBTASKS_CHECKPOINT_STATISTICS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails
- FIELD_NAME_SUMMARY - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
- FIELD_NAME_SUMMARY - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails
- FIELD_NAME_SYNC_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
- FIELD_NAME_SYNCHRONOUS_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
- FIELD_NAME_TARGET_DIRECTORY - Static variable in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerRequestBody
- FIELD_NAME_TARGET_DIRECTORY - Static variable in class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointRequestBody
- FIELD_NAME_TASK_HEAP - Static variable in class org.apache.flink.runtime.rest.messages.ResourceProfileInfo
- FIELD_NAME_TASK_HEAP - Static variable in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
- FIELD_NAME_TASK_MANAGER_ID - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.ExceptionInfo
- FIELD_NAME_TASK_MANAGERS - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersInfo
- FIELD_NAME_TASK_NAME - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.ExceptionInfo
- FIELD_NAME_TASK_OFFHEAP - Static variable in class org.apache.flink.runtime.rest.messages.ResourceProfileInfo
- FIELD_NAME_TASK_OFFHEAP - Static variable in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
- FIELD_NAME_TASKMANAGER_ID - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- FIELD_NAME_TASKMANAGERS - Static variable in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
- FIELD_NAME_TASKMANAGERS_BLOCKED - Static variable in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
- FIELD_NAME_TASKS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- FIELD_NAME_TASKS_PER_STATE - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- FIELD_NAME_THREAD_INFO - Static variable in class org.apache.flink.runtime.rest.messages.ThreadDumpInfo.ThreadInfo
- FIELD_NAME_THREAD_INFOS - Static variable in class org.apache.flink.runtime.rest.messages.ThreadDumpInfo
- FIELD_NAME_THREAD_NAME - Static variable in class org.apache.flink.runtime.rest.messages.ThreadDumpInfo.ThreadInfo
- FIELD_NAME_TIME - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo.GarbageCollectorInfo
- FIELD_NAME_TIMESTAMPS - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_TIMESTAMPS - Static variable in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
- FIELD_NAME_TIMEZONE_NAME - Static variable in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
- FIELD_NAME_TIMEZONE_OFFSET - Static variable in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
- FIELD_NAME_TOLERABLE_FAILED_CHECKPOINTS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
- FIELD_NAME_TOTAL_CHECKPOINTS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
- FIELD_NAME_TOTAL_FLINK_MEMORY - Static variable in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
- FIELD_NAME_TOTAL_PROCESS_MEMORY - Static variable in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
- FIELD_NAME_TOTAL_RESOURCE - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- FIELD_NAME_TRIGGER_TIME - Static variable in class org.apache.flink.runtime.rest.messages.ProfilingInfo
- FIELD_NAME_TRIGGER_TIMESTAMP - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- FIELD_NAME_TRUNCATED - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.JobExceptionHistory
- FIELD_NAME_UNALIGNED_CHECKPOINT - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
- FIELD_NAME_UNALIGNED_CHECKPOINTS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
- FIELD_NAME_USER_ACCUMULATORS - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsInfo
- FIELD_NAME_USER_ACCUMULATORS - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo
- FIELD_NAME_USER_ACCUMULATORS - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsInfo
- FIELD_NAME_USER_TASK_ACCUMULATORS - Static variable in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
- FIELD_NAME_VERSION - Static variable in class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
- FIELD_NAME_VERTEX_ID - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
- FIELD_NAME_VERTEX_NAME - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
- FieldAccessor<T,F> - Class in org.apache.flink.streaming.util.typeutils
-
These classes encapsulate the logic of accessing a field specified by the user as either an index or a field expression string.
- FieldAccessor() - Constructor for class org.apache.flink.streaming.util.typeutils.FieldAccessor
- FieldAccessorFactory - Class in org.apache.flink.streaming.util.typeutils
-
Static factories for the
FieldAccessorutilities. - FieldAccessorFactory() - Constructor for class org.apache.flink.streaming.util.typeutils.FieldAccessorFactory
- fieldType - Variable in class org.apache.flink.streaming.util.typeutils.FieldAccessor
- FILE - org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionType
-
A BoundedBlockingSubpartition type that simply stores the partition data in a file.
- FILE_MMAP - org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionType
-
Creates a BoundedBlockingSubpartition that stores the partition data in a file and memory maps that file for reading.
- FileBasedBufferIterator - Class in org.apache.flink.runtime.io.disk
-
CloseableIteratorofbuffersover file content. - FileBasedBufferIterator(RefCountedFile, int, int) - Constructor for class org.apache.flink.runtime.io.disk.FileBasedBufferIterator
- FileBasedStateOutputStream - Class in org.apache.flink.runtime.state.filesystem
-
A
CheckpointStateOutputStreamthat writes into a specified file and returns aFileStateHandleupon closing. - FileBasedStateOutputStream(FileSystem, Path) - Constructor for class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
- FileCache - Class in org.apache.flink.runtime.filecache
-
The FileCache is used to access registered cache files when a task is deployed.
- FileCache(String[], PermanentBlobService) - Constructor for class org.apache.flink.runtime.filecache.FileCache
- fileChannel - Variable in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
-
A file channel for NIO access to the file.
- FileChannelInputView - Class in org.apache.flink.runtime.io.disk
-
A
DataInputViewthat is backed by aBlockChannelReader, making it effectively a data input stream. - FileChannelInputView(BlockChannelReader<MemorySegment>, MemoryManager, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.FileChannelInputView
- FileChannelManager - Interface in org.apache.flink.runtime.io.disk
-
The manager used for creating/getting file IO channels based on config temp dirs.
- FileChannelManagerImpl - Class in org.apache.flink.runtime.io.disk
-
The manager used for creating/deleting file channels based on config temp dirs.
- FileChannelManagerImpl(String[], String) - Constructor for class org.apache.flink.runtime.io.disk.FileChannelManagerImpl
- FileChannelOutputView - Class in org.apache.flink.runtime.io.disk
-
A
DataOutputViewthat is backed by aBlockChannelWriter, making it effectively a data output stream. - FileChannelOutputView(BlockChannelWriter<MemorySegment>, MemoryManager, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.FileChannelOutputView
- FileDataIndexCache<T extends FileDataIndexRegionHelper.Region> - Class in org.apache.flink.runtime.io.network.partition.hybrid.index
-
A cache layer of hybrid data index.
- FileDataIndexCache(int, Path, long, FileDataIndexSpilledRegionManager.Factory<T>) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.index.FileDataIndexCache
- FileDataIndexRegionHelper<T extends FileDataIndexRegionHelper.Region> - Interface in org.apache.flink.runtime.io.network.partition.hybrid.index
-
FileDataIndexRegionHelperis responsible for writing aFileDataIndexRegionHelper.Regionto the file or reading aFileDataIndexRegionHelper.Regionfrom file. - FileDataIndexRegionHelper.Region - Interface in org.apache.flink.runtime.io.network.partition.hybrid.index
-
A
FileDataIndexRegionHelper.RegionRepresents a series of buffers that are: From the same subpartition Logically (i.e. buffer index) consecutive Physically (i.e. offset in the file) consecutive - FileDataIndexSpilledRegionManager<T extends FileDataIndexRegionHelper.Region> - Interface in org.apache.flink.runtime.io.network.partition.hybrid.index
-
This class is responsible for spilling region to disk and managing these spilled regions.
- FileDataIndexSpilledRegionManager.Factory<T extends FileDataIndexRegionHelper.Region> - Interface in org.apache.flink.runtime.io.network.partition.hybrid.index
-
Factory of
FileDataIndexSpilledRegionManager. - FileDataIndexSpilledRegionManagerImpl<T extends FileDataIndexRegionHelper.Region> - Class in org.apache.flink.runtime.io.network.partition.hybrid.index
-
Default implementation of
FileDataIndexSpilledRegionManager. - FileDataIndexSpilledRegionManagerImpl(int, Path, int, long, int, BiConsumer<Integer, T>, FileDataIndexRegionHelper<T>) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.index.FileDataIndexSpilledRegionManagerImpl
- FileDataIndexSpilledRegionManagerImpl.Factory<T extends FileDataIndexRegionHelper.Region> - Class in org.apache.flink.runtime.io.network.partition.hybrid.index
-
Factory of
FileDataIndexSpilledRegionManager. - FileExecutionGraphInfoStore - Class in org.apache.flink.runtime.dispatcher
-
Store for
ExecutionGraphInfoinstances. - FileExecutionGraphInfoStore(File, Duration, int, long, ScheduledExecutor, Ticker) - Constructor for class org.apache.flink.runtime.dispatcher.FileExecutionGraphInfoStore
- FileIOChannel - Interface in org.apache.flink.runtime.io.disk.iomanager
-
A Channel represents a collection of files that belong logically to the same resource.
- FileIOChannel.Enumerator - Class in org.apache.flink.runtime.io.disk.iomanager
-
An enumerator for channels that logically belong together.
- FileIOChannel.ID - Class in org.apache.flink.runtime.io.disk.iomanager
-
An ID identifying an underlying file channel.
- FileJobGraphRetriever - Class in org.apache.flink.runtime.entrypoint.component
-
JobGraphRetrieverimplementation which retrieves theJobGraphfrom a file on disk. - FileJobGraphRetriever(String, File) - Constructor for class org.apache.flink.runtime.entrypoint.component.FileJobGraphRetriever
- FileMergingCheckpointStateOutputStream - Class in org.apache.flink.runtime.state.filesystem
-
A
CheckpointStateOutputStreamthat writes into a segment of a file and returns aSegmentFileStateHandleupon closing. - FileMergingCheckpointStateOutputStream(int, FileMergingCheckpointStateOutputStream.FileMergingSnapshotManagerProxy) - Constructor for class org.apache.flink.runtime.state.filesystem.FileMergingCheckpointStateOutputStream
- FileMergingCheckpointStateOutputStream.FileMergingSnapshotManagerProxy - Interface in org.apache.flink.runtime.state.filesystem
-
A proxy of the
FileMergingSnapshotManagerthat owns thisFileMergingCheckpointStateOutputStream, with the interfaces for dealing with physical files. - FileMergingMetricGroup - Class in org.apache.flink.runtime.checkpoint.filemerging
-
Metrics related to the file merging snapshot manager.
- FileMergingMetricGroup(MetricGroup, FileMergingSnapshotManager.SpaceStat) - Constructor for class org.apache.flink.runtime.checkpoint.filemerging.FileMergingMetricGroup
- FileMergingOperatorStreamStateHandle - Class in org.apache.flink.runtime.state.filemerging
-
A
OperatorStreamStateHandlethat works for file merging checkpoints. - FileMergingOperatorStreamStateHandle(DirectoryStreamStateHandle, DirectoryStreamStateHandle, Map<String, OperatorStateHandle.StateMetaInfo>, StreamStateHandle) - Constructor for class org.apache.flink.runtime.state.filemerging.FileMergingOperatorStreamStateHandle
- FileMergingSnapshotManager - Interface in org.apache.flink.runtime.checkpoint.filemerging
-
FileMergingSnapshotManager provides an interface to manage files and meta information for checkpoint files with merging checkpoint files enabled.
- FileMergingSnapshotManager.SpaceStat - Class in org.apache.flink.runtime.checkpoint.filemerging
-
Space usage statistics of a managed directory.
- FileMergingSnapshotManager.SubtaskKey - Class in org.apache.flink.runtime.checkpoint.filemerging
-
A key identifies a subtask.
- FileMergingSnapshotManagerBase - Class in org.apache.flink.runtime.checkpoint.filemerging
-
Base implementation of
FileMergingSnapshotManager. - FileMergingSnapshotManagerBase(String, long, PhysicalFilePool.Type, float, Executor, MetricGroup) - Constructor for class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
- FileMergingSnapshotManagerBase.DirectoryHandleWithReferenceTrack - Class in org.apache.flink.runtime.checkpoint.filemerging
-
This class wrap DirectoryStreamStateHandle with reference count by ongoing checkpoint.
- FileMergingSnapshotManagerBuilder - Class in org.apache.flink.runtime.checkpoint.filemerging
-
A builder that builds the
FileMergingSnapshotManager. - FileMergingSnapshotManagerBuilder(JobID, ResourceID, FileMergingType) - Constructor for class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBuilder
-
Initialize the builder.
- FileMergingSnapshotManagerClosableWrapper - Class in org.apache.flink.runtime.state
-
A wrapper that wraps
FileMergingSnapshotManagerand aCloseable. - fileMergingSnapshotManagerForTask(JobID, ResourceID, ExecutionAttemptID, Configuration, Configuration, TaskManagerJobMetricGroup) - Method in class org.apache.flink.runtime.state.TaskExecutorFileMergingManager
-
Initialize file merging snapshot manager for each job according configurations when
TaskExecutor.submitTask(org.apache.flink.runtime.deployment.TaskDeploymentDescriptor, org.apache.flink.runtime.jobmaster.JobMasterId, java.time.Duration). - FileMergingType - Enum in org.apache.flink.runtime.checkpoint.filemerging
-
How the checkpoint files can be segmented.
- FileMessageParameters - Class in org.apache.flink.runtime.rest.messages.cluster
-
Parameters for
JobManagerCustomLogHandler. - FileMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.cluster.FileMessageParameters
- FileMonitoringFunction - Class in org.apache.flink.streaming.api.functions.source.legacy
-
Deprecated.Internal class deprecated in favour of
ContinuousFileMonitoringFunction. - FileMonitoringFunction(String, long, FileMonitoringFunction.WatchType) - Constructor for class org.apache.flink.streaming.api.functions.source.legacy.FileMonitoringFunction
-
Deprecated.
- FileMonitoringFunction.WatchType - Enum in org.apache.flink.streaming.api.functions.source.legacy
-
Deprecated.The watch type of the
FileMonitoringFunction. - fileName - Variable in class org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody.DistributedCacheFile
- filePoolType - Variable in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
-
Type of physical file pool.
- FileProcessingMode - Enum in org.apache.flink.streaming.api.functions.source
-
The mode in which the
ContinuousFileMonitoringFunctionoperates. - FileReadFunction - Class in org.apache.flink.streaming.api.functions.source.legacy
-
Deprecated.Internal class deprecated in favour of
ContinuousFileMonitoringFunction. - FileReadFunction() - Constructor for class org.apache.flink.streaming.api.functions.source.legacy.FileReadFunction
-
Deprecated.
- FileRegionBuffer - Class in org.apache.flink.runtime.io.network.buffer
-
This class represents a chunk of data in a file channel.
- FileRegionBuffer(FileChannel, long, int, Buffer.DataType, boolean) - Constructor for class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- FileRegionWriteReadUtils - Class in org.apache.flink.runtime.io.network.partition.hybrid.index
-
Utils for read and write
FileDataIndexRegionHelper.Region. - FileRegionWriteReadUtils() - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.index.FileRegionWriteReadUtils
- FileSegment - Class in org.apache.flink.runtime.io.disk.iomanager
- FileSegment(FileChannel, long, int, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.FileSegment
- fileSizeThreshold - Variable in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageAccess
- FileSlotAllocationSnapshotPersistenceService - Class in org.apache.flink.runtime.taskexecutor.slot
-
File based
SlotAllocationSnapshotPersistenceServicethat persists theSlotAllocationSnapshotas local files. - FileSlotAllocationSnapshotPersistenceService(File) - Constructor for class org.apache.flink.runtime.taskexecutor.slot.FileSlotAllocationSnapshotPersistenceService
- FileStateHandle - Class in org.apache.flink.runtime.state.filesystem
-
StreamStateHandlefor state that was written to a file stream. - FileStateHandle(Path, long) - Constructor for class org.apache.flink.runtime.state.filesystem.FileStateHandle
-
Creates a new file state for the given file path.
- fileSystem - Variable in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageAccess
- FileSystemBlobStore - Class in org.apache.flink.runtime.blob
-
Blob store backed by
FileSystem. - FileSystemBlobStore(FileSystem, String) - Constructor for class org.apache.flink.runtime.blob.FileSystemBlobStore
- FileSystemCheckpointStorage - Class in org.apache.flink.runtime.state.storage
-
FileSystemCheckpointStoragecheckpoints state as files to a file system. - FileSystemCheckpointStorage(String) - Constructor for class org.apache.flink.runtime.state.storage.FileSystemCheckpointStorage
-
Creates a new checkpoint storage that stores its checkpoint data in the file system and location defined by the given URI.
- FileSystemCheckpointStorage(URI) - Constructor for class org.apache.flink.runtime.state.storage.FileSystemCheckpointStorage
-
Creates a new checkpoint storage that stores its checkpoint data in the file system and location defined by the given URI.
- FileSystemCheckpointStorage(URI, int) - Constructor for class org.apache.flink.runtime.state.storage.FileSystemCheckpointStorage
-
Creates a new checkpoint storage that stores its checkpoint data in the file system and location defined by the given URI.
- FileSystemCheckpointStorage(Path) - Constructor for class org.apache.flink.runtime.state.storage.FileSystemCheckpointStorage
-
Creates a new checkpoint storage that stores its checkpoint data in the file system and location defined by the given URI.
- FileSystemCheckpointStorage(Path, int, int) - Constructor for class org.apache.flink.runtime.state.storage.FileSystemCheckpointStorage
-
Creates a new checkpoint storage that stores its checkpoint data in the file system and location defined by the given URI.
- FileSystemJobEventStore - Class in org.apache.flink.runtime.jobmaster.event
- FileSystemJobEventStore(JobID, Configuration) - Constructor for class org.apache.flink.runtime.jobmaster.event.FileSystemJobEventStore
- FileSystemJobEventStore(Path, Configuration) - Constructor for class org.apache.flink.runtime.jobmaster.event.FileSystemJobEventStore
- FileSystemJobResultStore - Class in org.apache.flink.runtime.highavailability
-
An implementation of the
JobResultStorewhich persists job result data to an underlying distributed filesystem. - FileSystemStateStorageHelper<T extends Serializable> - Class in org.apache.flink.runtime.persistence.filesystem
-
RetrievableStateStorageHelperimplementation which stores the state in the given filesystem path. - FileSystemStateStorageHelper(Path, String) - Constructor for class org.apache.flink.runtime.persistence.filesystem.FileSystemStateStorageHelper
- FileType - Enum in org.apache.flink.runtime.taskexecutor
-
Different file types to request from the
TaskExecutor. - FileUpload - Class in org.apache.flink.runtime.rest
-
Client uploading a file.
- FileUpload(Path, String) - Constructor for class org.apache.flink.runtime.rest.FileUpload
- FileUploadHandler - Class in org.apache.flink.runtime.rest
-
Writes multipart/form-data to disk.
- FileUploadHandler(Path, MultipartRoutes) - Constructor for class org.apache.flink.runtime.rest.FileUploadHandler
- FileUploads - Class in org.apache.flink.runtime.rest.handler
-
A container for uploaded files.
- FileUploads(Path) - Constructor for class org.apache.flink.runtime.rest.handler.FileUploads
- filter(FilterFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Applies a Filter transformation on a
DataStream. - filter(Metric, String, String) - Method in class org.apache.flink.runtime.metrics.filter.DefaultMetricFilter
- filter(Metric, String, String) - Method in interface org.apache.flink.runtime.metrics.filter.MetricFilter
-
Filters a given metric.
- filterOrTransform(List<T>) - Method in class org.apache.flink.runtime.state.StateSnapshotTransformers.ListStateSnapshotTransformer
- filterOrTransform(Map<K, V>) - Method in class org.apache.flink.runtime.state.StateSnapshotTransformers.MapStateSnapshotTransformer
- filterOrTransform(StateSnapshotTransformer<S>) - Method in interface org.apache.flink.runtime.state.StateEntry
- filterOrTransform(T) - Method in interface org.apache.flink.runtime.state.StateSnapshotTransformer
-
Transform or filter out state values which are included or skipped in the snapshot.
- finalize() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
The finalize method shuts down the timer.
- finalize() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
- FINALIZE_CHECKPOINT_FAILURE - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- finalizeBuildPhase(IOManager, FileIOChannel.Enumerator, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
- finalizeCheckpoint(CheckpointsCleaner, Runnable, Executor) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
- finalizeOnMaster(JobVertex.FinalizeOnMasterContext) - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatVertex
- finalizeOnMaster(JobVertex.FinalizeOnMasterContext) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
A hook that can be overwritten by sub classes to implement logic that is called by the master after the job completed.
- finalizeProbePhase(List<MemorySegment>, List<HashPartition<BT, PT>>, boolean) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
- finalizeProbePhase(List<MemorySegment>, List<HashPartition<BT, PT>>, boolean) - Method in class org.apache.flink.runtime.operators.hash.ReOpenableHashPartition
- finalizeReplay() - Method in interface org.apache.flink.runtime.jobmaster.event.JobEventReplayHandler
-
Called when finalizing replaying job event.
- finalizeReplay() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DefaultBatchJobRecoveryHandler
- find(Configuration) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils.LogFileLocation
-
Finds the Flink log directory using log.file Java property that is set during startup.
- findConnectingAddress(InetSocketAddress, long, long) - Static method in class org.apache.flink.runtime.net.ConnectionUtils
-
Finds the local network address from which this machine can connect to the target address.
- findConnectingAddress(Duration) - Method in class org.apache.flink.runtime.net.ConnectionUtils.LeaderConnectingAddressListener
- findConnectingAddress(Duration, Duration) - Method in class org.apache.flink.runtime.net.ConnectionUtils.LeaderConnectingAddressListener
- findConnectingAddress(LeaderRetrievalService, Duration, RpcSystemUtils) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
- findContextFactory(String) - Static method in class org.apache.flink.runtime.security.SecurityFactoryServiceLoader
-
Find a suitable
SecurityContextFactorybased on canonical name. - findEnabledTraceReportersInConfiguration(Configuration, String, Pattern, Pattern, String) - Static method in class org.apache.flink.runtime.metrics.ReporterSetup
- findExecution(ExecutionAttemptID) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- findExecution(ExecutionAttemptID) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- findLastAllocation() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- findLastLocation() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
Gets the location that an execution of this vertex was assigned to.
- findLowest(Deque<CompletedCheckpoint>) - Static method in class org.apache.flink.runtime.checkpoint.AbstractCompleteCheckpointStore
- findModuleFactory(String) - Static method in class org.apache.flink.runtime.security.SecurityFactoryServiceLoader
-
Find a suitable
SecurityModuleFactorybased on canonical name. - findRegion(int, int, boolean) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.index.FileDataIndexSpilledRegionManager
-
Find the region contains target bufferIndex and belong to target subpartition.
- findRegion(int, int, boolean) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.index.FileDataIndexSpilledRegionManagerImpl
- findThrowableOfThrowableType(Throwable, ThrowableType) - Static method in class org.apache.flink.runtime.throwable.ThrowableClassifier
-
Checks whether a throwable chain contains a specific throwable type and returns the corresponding throwable.
- findVertexByID(JobVertexID) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Searches for a vertex with a matching ID and returns it.
- findVertexWithAttempt(ExecutionAttemptID) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- findVertexWithAttempt(ExecutionAttemptID) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- FineGrainedSlotManager - Class in org.apache.flink.runtime.resourcemanager.slotmanager
-
Implementation of
SlotManagersupporting fine-grained resource management. - FineGrainedSlotManager(ScheduledExecutor, SlotManagerConfiguration, SlotManagerMetricGroup, ResourceTracker, TaskManagerTracker, SlotStatusSyncer, ResourceAllocationStrategy) - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedSlotManager
- FineGrainedTaskManagerRegistration - Class in org.apache.flink.runtime.resourcemanager.slotmanager
-
A FineGrainedTaskManagerRegistration represents a TaskManager.
- FineGrainedTaskManagerRegistration(TaskExecutorConnection, ResourceProfile, ResourceProfile) - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerRegistration
- FineGrainedTaskManagerSlot - Class in org.apache.flink.runtime.resourcemanager.slotmanager
-
A FineGrainedTaskManagerSlot represents a slot located in a TaskManager.
- FineGrainedTaskManagerSlot(AllocationID, JobID, ResourceProfile, TaskExecutorConnection, SlotState) - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerSlot
- FineGrainedTaskManagerTracker - Class in org.apache.flink.runtime.resourcemanager.slotmanager
-
Implementation of
TaskManagerTrackersupporting fine-grained resource management. - FineGrainedTaskManagerTracker() - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- finish() - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperator
- finish() - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperatorV2
- finish() - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateUdfStreamOperator
- finish() - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
Successfully finish the production of the partition.
- finish() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
Mark this
BufferBuilderand associatedBufferConsumeras finished - no new data writes will be allowed. - finish() - Method in class org.apache.flink.runtime.io.network.partition.BufferWritingResultPartition
- finish() - Method in interface org.apache.flink.runtime.io.network.partition.DataBuffer
-
Finishes this
DataBufferwhich means no record can be appended anymore. - finish() - Method in class org.apache.flink.runtime.io.network.partition.HashBasedDataBuffer
- finish() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartition
- finish() - Method in class org.apache.flink.runtime.io.network.partition.PartitionedFileWriter
-
Finishes writing the
PartitionedFilewhich closes the file channel and returns the correspondingPartitionedFile. - finish() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartition
- finish() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Finishes the result partition.
- finish() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
Writing of data is finished.
- finish() - Method in class org.apache.flink.runtime.io.network.partition.SortBuffer
- finish() - Method in class org.apache.flink.runtime.io.network.partition.SortMergeResultPartition
- finish() - Method in interface org.apache.flink.streaming.api.functions.sink.legacy.SinkFunction
-
Deprecated.This method is called at the end of data processing.
- finish() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
- finish() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- finish() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- finish() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
- finish() - Method in class org.apache.flink.streaming.api.operators.SourceOperator
- finish() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
This method is called at the end of data processing.
- finish() - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
- finish(StreamTaskActionExecutor, StopMode) - Method in class org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper
-
Finishes the wrapped operator and propagates the finish operation to the next wrapper that the
StreamOperatorWrapper.nextpoints to. - FINISHED - org.apache.flink.runtime.execution.ExecutionState
-
This state marks "successfully completed".
- FINISHED - org.apache.flink.runtime.rest.messages.ProfilingInfo.ProfilingStatus
- FINISHED_ON_RESTORE - Static variable in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
- FinishedDataOutput<IN> - Class in org.apache.flink.streaming.runtime.io
-
An empty
PushingAsyncDataInput.DataOutputwhich is used byStreamOneInputProcessoronce anDataInputStatus.END_OF_DATAis received. - FinishedDataOutput() - Constructor for class org.apache.flink.streaming.runtime.io.FinishedDataOutput
- finishedOnRestoreInput - Variable in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- FinishedOnRestoreInput<IN> - Class in org.apache.flink.streaming.runtime.tasks
-
A fake
Inputfor finished on restore tasks. - FinishedOnRestoreInput(RecordWriterOutput<?>[], int) - Constructor for class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreInput
- FinishedOnRestoreMainOperatorOutput<OUT> - Class in org.apache.flink.streaming.runtime.tasks
-
A fake main operator output that skips all the following operators for finished on restored tasks.
- FinishedOnRestoreMainOperatorOutput(RecordWriterOutput<?>[]) - Constructor for class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
- FinishedOperatorChain<OUT,OP extends StreamOperator<OUT>> - Class in org.apache.flink.streaming.runtime.tasks
-
The
OperatorChainthat is used for restoring tasks that areTaskStateManager.isTaskDeployedAsFinished(). - FinishedOperatorChain(StreamTask<OUT, OP>, RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>>) - Constructor for class org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
- FinishedOperatorSubtaskState - Class in org.apache.flink.runtime.checkpoint
-
A specialized
OperatorSubtaskStaterepresenting the subtask is finished. - FinishedTaskStateProvider - Interface in org.apache.flink.runtime.checkpoint
-
Collects and fulfills the finished state for the subtasks or operators.
- FinishedTaskStateProvider.PartialFinishingNotSupportedByStateException - Exception in org.apache.flink.runtime.checkpoint
-
Thrown when some subtasks of the operator have been finished but state doesn't support that (e.g.
- finishInput(long) - Method in interface org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter
-
Finalize write of channel state data for the given checkpoint id.
- finishInput(long) - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter.NoOpChannelStateWriter
- finishInput(long) - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriterImpl
- finishOperators(StreamTaskActionExecutor, StopMode) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
- finishOperators(StreamTaskActionExecutor, StopMode) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
Closes all operators in a chain effect way.
- finishOperators(StreamTaskActionExecutor, StopMode) - Method in class org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
- finishOutput(long) - Method in interface org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter
-
Finalize write of channel state data for the given checkpoint id.
- finishOutput(long) - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter.NoOpChannelStateWriter
- finishOutput(long) - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriterImpl
- finishPartitionsIfNeeded() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
Mark partition finished if needed.
- finishReading() - Method in interface org.apache.flink.runtime.operators.sort.PushSorter
-
Finalizes the sorting.
- finishReadRecoveredState() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
- finishReadRecoveredState() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RecoveredInputChannel
- finishReadRecoveredState() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- finishReadRecoveredState() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
- finishReadRecoveredState() - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
- finishReadRecoveredState(boolean) - Method in interface org.apache.flink.runtime.io.network.partition.CheckpointedResultPartition
- finishReadRecoveredState(boolean) - Method in class org.apache.flink.runtime.io.network.partition.PipelinedResultPartition
- finishRecovery() - Method in interface org.apache.flink.streaming.runtime.io.RecoverableStreamTaskInput
- finishRecovery() - Method in class org.apache.flink.streaming.runtime.io.recovery.RescalingStreamTaskNetworkInput
- finishResult(StreamStateHandle) - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStatePendingResult
- finishWriteAndSortKeys(List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.sort.LargeRecordHandler
- FIRE - org.apache.flink.streaming.api.windowing.triggers.TriggerResult
-
On
FIRE, the window is evaluated and results are emitted. - FIRE_AND_PURGE - org.apache.flink.streaming.api.windowing.triggers.TriggerResult
-
FIRE_AND_PURGEevaluates the window function and emits the window result. - FIRST - org.apache.flink.runtime.io.network.api.writer.SubtaskStateMapper
-
Restores extra subtasks to the first subtask.
- FIRST - Static variable in class org.apache.flink.streaming.api.operators.InputSelection
-
The
InputSelectioninstance which indicates to select the first input. - FIRST_BIT_IN_BYTE_MASK - Static variable in class org.apache.flink.runtime.state.FullSnapshotUtil
- FIRST_STATE_ORDER - org.apache.flink.streaming.runtime.operators.asyncprocessing.ElementOrder
-
The
processElementcall will be invoked on record arrival, but may be blocked at the first state accessing if there is a preceding same-key record under processing. - firstDam() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
- firstOperatorWrapper - Variable in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- FixedDelayRestartBackoffTimeStrategy - Class in org.apache.flink.runtime.executiongraph.failover
-
Restart strategy which tries to restart a fixed number of times with a fixed backoff time in between.
- FixedDelayRestartBackoffTimeStrategy.FixedDelayRestartBackoffTimeStrategyFactory - Class in org.apache.flink.runtime.executiongraph.failover
-
The factory for creating
FixedDelayRestartBackoffTimeStrategy. - FixedDelayRestartBackoffTimeStrategyFactory(int, long) - Constructor for class org.apache.flink.runtime.executiongraph.failover.FixedDelayRestartBackoffTimeStrategy.FixedDelayRestartBackoffTimeStrategyFactory
- FixedLengthByteKeyAndValueComparator<INPUT> - Class in org.apache.flink.streaming.api.operators.sortpartition
-
The
FixedLengthByteKeyAndValueComparatoris used byKeyedSortPartitionOperatorto compare records according to both the record key and record value. - FixedLengthRecordSorter<T> - Class in org.apache.flink.runtime.operators.sort
- FixedLengthRecordSorter(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
- FixedSizeRegion(int, long, long, int) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.ProducerMergedPartitionFileIndex.FixedSizeRegion
- FLAG_LAST_BLOCK - Static variable in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
The flag marking a block as the last block.
- flameGraphTypeQueryParameter - Variable in class org.apache.flink.runtime.rest.messages.JobVertexFlameGraphParameters
- FlameGraphTypeQueryParameter - Class in org.apache.flink.runtime.rest.messages
-
Flame Graph type query parameter.
- FlameGraphTypeQueryParameter() - Constructor for class org.apache.flink.runtime.rest.messages.FlameGraphTypeQueryParameter
- FlameGraphTypeQueryParameter.Type - Enum in org.apache.flink.runtime.rest.messages
-
Flame Graph type.
- FLAT_MAP - org.apache.flink.runtime.operators.DriverStrategy
- flatMap(FlatMapFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Applies a FlatMap transformation on a
DataStream. - flatMap(FlatMapFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Applies a FlatMap transformation on a
DataStream. - flatMap(Tuple3<String, Long, Long>, Collector<String>) - Method in class org.apache.flink.streaming.api.functions.source.legacy.FileReadFunction
-
Deprecated.
- flatMap(CoFlatMapFunction<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies a CoFlatMap transformation on a
ConnectedStreamsand maps the output to a common type. - flatMap(CoFlatMapFunction<IN1, IN2, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies a CoFlatMap transformation on a
ConnectedStreamsand maps the output to a common type. - flatMap1(IN1, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.co.CoFlatMapFunction
-
This method is called for each element in the first of the connected streams.
- flatMap2(IN2, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.co.CoFlatMapFunction
-
This method is called for each element in the second of the connected streams.
- FlatMapDriver<IT,OT> - Class in org.apache.flink.runtime.operators
-
Map task which is executed by a Task Manager.
- FlatMapDriver() - Constructor for class org.apache.flink.runtime.operators.FlatMapDriver
- FLATTEN_CONFIG_OPTION - Static variable in class org.apache.flink.runtime.entrypoint.parser.ConfigurationCommandLineOptions
- flattenConfig() - Method in class org.apache.flink.runtime.entrypoint.ModifiableClusterConfiguration
- flattenedChannelIndices - Variable in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
- flinkClientConfig - Variable in class org.apache.flink.runtime.resourcemanager.active.AbstractResourceManagerDriver
- flinkConfig - Variable in class org.apache.flink.runtime.resourcemanager.active.AbstractResourceManagerDriver
- flinkConfig - Variable in class org.apache.flink.runtime.resourcemanager.active.ActiveResourceManager
- FlinkConfigLoader - Class in org.apache.flink.runtime.util.bash
-
Util class for loading configuration from commandline arguments.
- FlinkHttpObjectAggregator - Class in org.apache.flink.runtime.rest
-
Same as
HttpObjectDecoderbut returns HTTP 413 to the client if the payload exceedsMessageAggregator.maxContentLength. - FlinkHttpObjectAggregator(int, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.FlinkHttpObjectAggregator
- FlinkJobNotFoundException - Exception in org.apache.flink.runtime.messages
-
Exception indicating that we could not find a Flink job with the given job ID.
- FlinkJobNotFoundException(JobID) - Constructor for exception org.apache.flink.runtime.messages.FlinkJobNotFoundException
- FlinkJobTerminatedWithoutCancellationException - Exception in org.apache.flink.runtime.messages
-
Exception indicating that the Flink job with the given job ID has terminated without cancellation.
- FlinkJobTerminatedWithoutCancellationException(JobID, JobStatus) - Constructor for exception org.apache.flink.runtime.messages.FlinkJobTerminatedWithoutCancellationException
- FlinkMemory - Interface in org.apache.flink.runtime.util.config.memory
-
Memory components which constitute the Total Flink Memory.
- FlinkMemoryUtils<FM extends FlinkMemory> - Interface in org.apache.flink.runtime.util.config.memory
-
Utility to derive the
FlinkMemorycomponents. - FlinkParseException - Exception in org.apache.flink.runtime.entrypoint
-
Exception which indicates that the parsing of command line arguments failed.
- FlinkParseException(String) - Constructor for exception org.apache.flink.runtime.entrypoint.FlinkParseException
- FlinkParseException(String, Throwable) - Constructor for exception org.apache.flink.runtime.entrypoint.FlinkParseException
- FlinkParseException(Throwable) - Constructor for exception org.apache.flink.runtime.entrypoint.FlinkParseException
- FlinkZooKeeperQuorumPeer - Class in org.apache.flink.runtime.zookeeper
-
Simple wrapper for ZooKeeper's
QuorumPeer, which reads a ZooKeeper config file and writes the required 'myid' file before starting the peer. - FlinkZooKeeperQuorumPeer() - Constructor for class org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
- flip() - Method in class org.apache.flink.runtime.io.disk.SpillingBuffer
- FloatingBuffersUsageGauge - Class in org.apache.flink.runtime.io.network.metrics
-
Gauge metric measuring the floating buffers usage gauge for
SingleInputGates. - FloatingBuffersUsageGauge(SingleInputGate[]) - Constructor for class org.apache.flink.runtime.io.network.metrics.FloatingBuffersUsageGauge
- floatingNetworkBuffersPerGate() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- flush() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartition
- flush() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
- flush() - Method in class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
- flush() - Method in class org.apache.flink.runtime.state.CompressibleFSDataOutputStream
- flush() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
- flush() - Method in class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
- flush() - Method in class org.apache.flink.runtime.state.filesystem.FileMergingCheckpointStateOutputStream
- flush() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
- flush() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
-
Flush buffers to file if their size is above
FsCheckpointStreamFactory.FsCheckpointStateOutputStream.localStateThreshold. - flush() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
- flush() - Method in class org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
- flush() - Method in class org.apache.flink.runtime.util.ForwardingOutputStream
- flush() - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
- flush(int) - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
Manually trigger the consumption of data from the given subpartitions.
- flush(int) - Method in class org.apache.flink.runtime.io.network.partition.BoundedBlockingResultPartition
- flush(int) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartition
- flush(int) - Method in class org.apache.flink.runtime.io.network.partition.PipelinedResultPartition
- flush(int) - Method in class org.apache.flink.runtime.io.network.partition.SortMergeResultPartition
- flush(ChannelHandlerContext, HttpRequest, HttpResponse) - Static method in class org.apache.flink.runtime.rest.handler.util.KeepAliveWrite
- flush(Channel, HttpRequest, HttpResponse) - Static method in class org.apache.flink.runtime.rest.handler.util.KeepAliveWrite
- flushAccumulatedBuffers(TieredStorageSubpartitionId, Buffer, int) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.HashBufferAccumulator
- flushAccumulatedBuffers(TieredStorageSubpartitionId, Buffer, int) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.HashSubpartitionBufferAccumulatorContext
-
Flush the accumulated
Buffers of the subpartition. - flushAll() - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
- flushAll() - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
Manually trigger the consumption of data from all subpartitions.
- flushAll() - Method in class org.apache.flink.runtime.io.network.partition.BoundedBlockingResultPartition
- flushAll() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartition
- flushAll() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedResultPartition
- flushAll() - Method in class org.apache.flink.runtime.io.network.partition.SortMergeResultPartition
- flushAllSubpartitions(boolean) - Method in class org.apache.flink.runtime.io.network.partition.BufferWritingResultPartition
- flushAlways - Variable in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
- flushOutputs() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
This method should be called before finishing the record emission, to make sure any data that is still buffered will be sent.
- flushSubpartition(int, boolean) - Method in class org.apache.flink.runtime.io.network.partition.BufferWritingResultPartition
- flushToFile() - Method in class org.apache.flink.runtime.state.filesystem.FileMergingCheckpointStateOutputStream
- flushToFile() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
- FOR_KEYED_OBJECTS - Static variable in interface org.apache.flink.runtime.state.KeyExtractorFunction
- FOR_PRIORITY_COMPARABLE_OBJECTS - Static variable in interface org.apache.flink.runtime.state.PriorityComparator
- FORCED_ALIGNED - org.apache.flink.runtime.checkpoint.CheckpointOptions.AlignmentType
- forceNonParallel() - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the parallelism and maximum parallelism of this operator to one.
- forCheckpoint(CheckpointRetentionPolicy) - Static method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
-
Creates the checkpoint properties for a checkpoint.
- forCheckpointWithDefaultLocation() - Static method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
- forComponentId(String) - Method in class org.apache.flink.runtime.leaderelection.LeaderInformationRegister
-
Returns the
LeaderInformationthat is stored or an emptyOptionalif no entry exists for the passedcomponentId. - forComponentIdOrEmpty(String) - Method in class org.apache.flink.runtime.leaderelection.LeaderInformationRegister
-
Returns a
LeaderInformationwhich is empty if noLeaderInformationis stored for the passedcomponentId. - forConfig(SnapshotType, CheckpointStorageLocationReference, boolean, boolean, long) - Static method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
- forEachEventTimeTimer(BiConsumerWithException<N, Long, Exception>) - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
-
Performs an action for each registered timer.
- forEachEventTimeTimer(BiConsumerWithException<N, Long, Exception>) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
- forEachEventTimeTimer(BiConsumerWithException<N, Long, Exception>) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
- forEachProcessingTimeTimer(BiConsumerWithException<N, Long, Exception>) - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
-
Performs an action for each registered timer.
- forEachProcessingTimeTimer(BiConsumerWithException<N, Long, Exception>) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
- forEachProcessingTimeTimer(BiConsumerWithException<N, Long, Exception>) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
- foreachTimer(BiConsumerWithException<N, Long, Exception>, KeyGroupedInternalPriorityQueue<TimerHeapInternalTimer<K, N>>) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceAsyncImpl
-
Iterator each timer in the queue, and invoke the consumer.
- foreachTimer(BiConsumerWithException<N, Long, Exception>, KeyGroupedInternalPriorityQueue<TimerHeapInternalTimer<K, N>>) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
- forGlobalFailure(JobInfo, MetricGroup, Executor, ClassLoader) - Static method in class org.apache.flink.runtime.failure.DefaultFailureEnricherContext
-
Factory method returning a Global failure Context for the given params.
- forGloballyCleanableResources(ComponentMainThreadExecutor, Executor, RetryStrategy) - Static method in class org.apache.flink.runtime.dispatcher.cleanup.DefaultResourceCleaner
- forInitializationFailure(ExecutionGraphInfo, Throwable) - Static method in class org.apache.flink.runtime.jobmaster.JobManagerRunnerResult
- forInputGate(InputGate) - Static method in interface org.apache.flink.streaming.runtime.io.checkpointing.UpstreamRecoveryTracker
- forKeyedObjects() - Static method in interface org.apache.flink.runtime.state.KeyExtractorFunction
- forLocallyCleanableResources(ComponentMainThreadExecutor, Executor, RetryStrategy) - Static method in class org.apache.flink.runtime.dispatcher.cleanup.DefaultResourceCleaner
- format() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
- formatLogString(String) - Method in class org.apache.flink.runtime.operators.BatchTask
- formatLogString(String) - Method in interface org.apache.flink.runtime.operators.TaskContext
- formatScope(String) - Method in class org.apache.flink.runtime.metrics.scope.JobManagerScopeFormat
- formatScope(String, String) - Method in class org.apache.flink.runtime.metrics.scope.TaskManagerScopeFormat
- formatScope(JobManagerJobMetricGroup, AbstractID, String, OperatorID, String) - Method in class org.apache.flink.runtime.metrics.scope.JobManagerOperatorScopeFormat
- formatScope(JobManagerMetricGroup, JobID, String) - Method in class org.apache.flink.runtime.metrics.scope.JobManagerJobScopeFormat
- formatScope(TaskManagerJobMetricGroup, AbstractID, ExecutionAttemptID, String, int, int) - Method in class org.apache.flink.runtime.metrics.scope.TaskScopeFormat
- formatScope(TaskManagerMetricGroup, JobID, String) - Method in class org.apache.flink.runtime.metrics.scope.TaskManagerJobScopeFormat
- formatScope(TaskMetricGroup, OperatorID, String) - Method in class org.apache.flink.runtime.metrics.scope.OperatorScopeFormat
- FormatUserCodeTable() - Constructor for class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer.FormatUserCodeTable
- forPath(String) - Static method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
- forPath(String, boolean) - Static method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
- forPath(String, boolean, RecoveryClaimMode) - Static method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
- forPathWithSize(Path) - Static method in class org.apache.flink.runtime.state.DirectoryStateHandle
- forPriorityComparableObjects() - Static method in interface org.apache.flink.runtime.state.PriorityComparator
- forReporter(String, MetricConfig, MetricReporter) - Static method in class org.apache.flink.runtime.metrics.ReporterSetup
- forReporter(String, MetricConfig, TraceReporter) - Static method in class org.apache.flink.runtime.metrics.TraceReporterSetup
- forReporter(String, MetricReporter) - Static method in class org.apache.flink.runtime.metrics.ReporterSetup
- forReporter(String, MetricFilter, MetricReporter) - Static method in class org.apache.flink.runtime.metrics.ReporterSetup
- forReporter(String, TraceReporter) - Static method in class org.apache.flink.runtime.metrics.TraceReporterSetup
- forSavepoint(boolean, SavepointFormatType) - Static method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
-
Creates the checkpoint properties for a (manually triggered) savepoint.
- forSink(DataStream<T>, Sink<T>, CustomSinkOperatorUidHashes) - Static method in class org.apache.flink.streaming.api.datastream.DataStreamSink
- FORST_STATE_BACKEND_NAME - Static variable in class org.apache.flink.runtime.state.StateBackendLoader
- forStreamStateHandle(StreamStateHandle) - Static method in class org.apache.flink.runtime.state.SharedStateRegistryKey
-
Create a unique key based on physical id.
- forSuccess(ExecutionGraphInfo) - Static method in class org.apache.flink.runtime.jobmaster.JobManagerRunnerResult
- forSyncSavepoint(boolean, boolean, SavepointFormatType) - Static method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
- forTaskFailure(JobInfo, MetricGroup, Executor, ClassLoader) - Static method in class org.apache.flink.runtime.failure.DefaultFailureEnricherContext
-
Factory method returning a Task failure Context for the given params.
- forTaskManagerFailure(JobInfo, MetricGroup, Executor, ClassLoader) - Static method in class org.apache.flink.runtime.failure.DefaultFailureEnricherContext
-
Factory method returning a TaskManager failure Context for the given params.
- forUnclaimedSnapshot() - Static method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
-
Creates the checkpoint properties for a snapshot restored in
RecoveryClaimMode.NO_CLAIM. - forUpdatedSerializer(TypeSerializer<T>) - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueSnapshotRestoreWrapper
-
Returns a deep copy of the snapshot, where the serializer is changed to the given serializer.
- forUpdatedSerializer(TypeSerializer<T>, boolean) - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueSnapshotRestoreWrapper
-
Returns a deep copy of the snapshot, where the serializer is re-registered by the serializer snapshot or changed to the given serializer.
- forUrl(Configuration, Executor, URL) - Static method in class org.apache.flink.runtime.rest.RestClient
-
Creates a new RestClient for the provided root URL.
- forward() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStreamso that the output elements are forwarded to the local subtask of the next operation. - FORWARD - org.apache.flink.runtime.checkpoint.SnapshotType.SharingFilesStrategy
- FORWARD - org.apache.flink.runtime.operators.shipping.ShipStrategyType
-
Forwarding the data locally in memory.
- FORWARD_BACKWARD - org.apache.flink.runtime.checkpoint.SnapshotType.SharingFilesStrategy
- FORWARD_EDGES_PIPELINED - org.apache.flink.streaming.api.graph.GlobalStreamExchangeMode
-
Set job edges with
ForwardPartitionerto beResultPartitionType.PIPELINED_BOUNDEDand other edges to beResultPartitionType.BLOCKING. - ForwardForConsecutiveHashPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
If there are multiple consecutive and the same hash shuffles, SQL planner will change them except the first one to use forward partitioner, so that these operators can be chained to reduce unnecessary shuffles.
- ForwardForConsecutiveHashPartitioner(StreamPartitioner<T>) - Constructor for class org.apache.flink.streaming.runtime.partitioner.ForwardForConsecutiveHashPartitioner
-
Create a new ForwardForConsecutiveHashPartitioner.
- ForwardForUnspecifiedPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
When the parallelism of both upstream and downstream is
ExecutionConfig.PARALLELISM_DEFAULTand the edge's partitioner is not specified (partitioner==null), the edge's partitioner will be set to FORWARD by default(SeeStreamGraph.createActualEdge(java.lang.Integer, java.lang.Integer, int, org.apache.flink.streaming.runtime.partitioner.StreamPartitioner<?>, org.apache.flink.util.OutputTag, org.apache.flink.streaming.api.transformations.StreamExchangeMode, org.apache.flink.runtime.jobgraph.IntermediateDataSetID)method for details). - ForwardForUnspecifiedPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.ForwardForUnspecifiedPartitioner
- ForwardGroup - Class in org.apache.flink.runtime.jobgraph.forwardgroup
-
A forward group is a set of job vertices connected via forward edges.
- ForwardGroup(Set<JobVertex>) - Constructor for class org.apache.flink.runtime.jobgraph.forwardgroup.ForwardGroup
- ForwardGroupComputeUtil - Class in org.apache.flink.runtime.jobgraph.forwardgroup
-
Common utils for computing forward groups.
- ForwardGroupComputeUtil() - Constructor for class org.apache.flink.runtime.jobgraph.forwardgroup.ForwardGroupComputeUtil
- ForwardingInputStream - Class in org.apache.flink.runtime.util
-
Input stream, that wraps another input stream and forwards all method calls to the wrapped stream.
- ForwardingInputStream(InputStream) - Constructor for class org.apache.flink.runtime.util.ForwardingInputStream
- ForwardingOutputStream - Class in org.apache.flink.runtime.util
-
OutputStream, that wraps anotherOutputStreamand forwards all method calls to the wrapped stream. - ForwardingOutputStream(OutputStream) - Constructor for class org.apache.flink.runtime.util.ForwardingOutputStream
- ForwardPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that forwards elements only to the locally running downstream operation.
- ForwardPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
- freeInactiveSlots(JobID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.DefaultSlotStatusSyncer
- freeInactiveSlots(JobID) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotStatusSyncer
-
Frees all currently inactive slot allocated for the given job.
- freeInactiveSlots(JobID, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- freeInactiveSlots(JobID, Duration) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Frees all currently inactive slot allocated for the given job.
- freeInactiveSlots(JobID, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- FreeingBufferRecycler - Class in org.apache.flink.runtime.io.network.buffer
-
A simple buffer recycler that frees the memory segments.
- freeReservedSlot(AllocationID, long) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotPool
-
Frees the reserved slot, adding it back into the set of free slots.
- freeReservedSlot(AllocationID, long) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultAllocatedSlotPool
- freeReservedSlot(AllocationID, Throwable, long) - Method in class org.apache.flink.runtime.jobmaster.slotpool.BlocklistDeclarativeSlotPool
- freeReservedSlot(AllocationID, Throwable, long) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPool
-
Frees the reserved slot identified by the given allocationId.
- freeReservedSlot(AllocationID, Throwable, long) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultDeclarativeSlotPool
- freeSegments - Variable in class org.apache.flink.runtime.io.network.partition.SortBuffer
-
A list of
MemorySegments used to store data in memory. - freeSlot(AllocationID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.DefaultSlotStatusSyncer
- freeSlot(AllocationID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerRegistration
- freeSlot(AllocationID) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotStatusSyncer
-
Free the given slot.
- freeSlot(AllocationID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.SlotActions
-
Free the task slot with the given allocation id.
- freeSlot(AllocationID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Try to free the slot.
- freeSlot(AllocationID, Throwable) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Tries to free the slot.
- freeSlot(AllocationID, Throwable) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- freeSlot(AllocationID, Throwable, long) - Method in interface org.apache.flink.runtime.scheduler.adaptive.allocator.FreeSlotFunction
-
Frees the slot identified by the given
AllocationID. - freeSlot(AllocationID, Throwable, Duration) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Frees the slot with the given allocation ID.
- freeSlot(AllocationID, Throwable, Duration) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
- freeSlot(AllocationID, Throwable, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- freeSlot(AllocationID, Throwable, Duration) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Frees the slot with the given allocation ID.
- freeSlot(AllocationID, Throwable, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- freeSlot(SlotID, AllocationID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedSlotManager
-
Free the given slot from the given allocation.
- freeSlot(SlotID, AllocationID) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Free the given slot from the given allocation.
- FreeSlotFunction - Interface in org.apache.flink.runtime.scheduler.adaptive.allocator
-
A function for freeing slots.
- FreeSlotTracker - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
Track all free slots.
- from() - Method in interface org.apache.flink.runtime.state.changelog.SequenceNumberRange
-
Inclusive.
- from() - Method in class org.apache.flink.runtime.state.changelog.SequenceNumberRange.GenericSequenceNumberRange
- from(int, Map<IntermediateDataSetID, Integer>, Map<IntermediateDataSetID, Integer>, Map<IntermediateDataSetID, Integer>, Map<IntermediateDataSetID, ResultPartitionType>, Map<IntermediateDataSetID, ResultPartitionType>) - Static method in class org.apache.flink.runtime.shuffle.TaskInputsOutputsDescriptor
- from(long, ZonedDateTime, boolean, boolean, boolean, boolean) - Static method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
- from(ThreadInfo) - Static method in class org.apache.flink.runtime.messages.ThreadInfoSample
-
Constructs a
ThreadInfoSamplefromThreadInfo. - from(Collection<ThreadInfo>) - Static method in class org.apache.flink.runtime.messages.ThreadInfoSample
-
Constructs a collection of
ThreadInfoSamples from a collection ofThreadInfosamples. - from(Map<IntermediateDataSetID, DataSetMetaInfo>) - Static method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetListResponseBody
- from(ArchivedExecutionConfig) - Static method in class org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
- from(Configuration) - Static method in class org.apache.flink.runtime.rest.messages.ConfigurationInfo
- from(ResultPartitionDeploymentDescriptor) - Static method in class org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionInfo
- from(Dispatcher) - Static method in class org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherGatewayService
- from(PartialDispatcherServices, JobGraphWriter, JobResultStore) - Static method in class org.apache.flink.runtime.dispatcher.PartialDispatcherServicesWithJobPersistenceComponents
- from(PartialDispatcherServicesWithJobPersistenceComponents, JobManagerRunnerFactory, CleanupRunnerFactory) - Static method in class org.apache.flink.runtime.dispatcher.DispatcherServices
- from(IntermediateResultPartition) - Static method in class org.apache.flink.runtime.shuffle.PartitionDescriptor
- from(InputSelection) - Static method in class org.apache.flink.streaming.api.operators.InputSelection.Builder
-
Returns a
Builderthat uses the input mask of the specifiedselectionas the initial mask. - from(StreamRecord<T>) - Static method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
-
Creates a TimestampedValue from given
StreamRecord. - fromApplicationOrConfigOrDefault(StateBackend, Configuration, Configuration, ClassLoader, Logger) - Static method in class org.apache.flink.runtime.state.StateBackendLoader
-
This is the state backend loader that loads a
DelegatingStateBackendwrapping the state backend loaded fromStateBackendLoader.loadFromApplicationOrConfigOrDefaultInternal(org.apache.flink.runtime.state.StateBackend, org.apache.flink.configuration.Configuration, org.apache.flink.configuration.Configuration, java.lang.ClassLoader, org.slf4j.Logger)when delegation is enabled. - fromBuffer(Buffer, ClassLoader) - Static method in class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
- fromBufferAndLookahead(Buffer, Buffer.DataType, int, int) - Static method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition.BufferAndBacklog
- fromByteBuf(ByteBuf) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionAttemptID
- fromByteBuf(ByteBuf) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionGraphID
- fromByteBuf(ByteBuf) - Static method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
- fromByteBuf(ByteBuf) - Static method in class org.apache.flink.runtime.io.network.partition.ResultSubpartitionIndexSet
- fromByteBuf(ByteBuf) - Static method in class org.apache.flink.runtime.jobgraph.IntermediateDataSetID
- fromByteBuf(ByteBuf) - Static method in class org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
- fromByteBuf(ByteBuf) - Static method in class org.apache.flink.runtime.jobgraph.JobVertexID
- fromByteBuf(ByteBuf) - Static method in class org.apache.flink.runtime.scheduler.strategy.ExecutionVertexID
- fromBytes(byte[]) - Static method in class org.apache.flink.runtime.operators.util.BloomFilter
-
Deserializing bytes array to BloomFilter.
- fromCollection(Collection<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Deprecated.This method will be removed a future release, possibly as early as version 2.0. Use
StreamExecutionEnvironment.fromData(Collection)instead. - fromCollection(Collection<OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Deprecated.This method will be removed a future release, possibly as early as version 2.0. Use
StreamExecutionEnvironment.fromData(Collection, TypeInformation)instead. - fromCollection(Iterator<OUT>, Class<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Deprecated.This method will be removed a future release, possibly as early as version 2.0. Use
StreamExecutionEnvironment.fromData(Collection, TypeInformation)instead. For rate-limited data generation, useDataGeneratorSourcewithRateLimiterStrategy. If you need to use a fixed set of elements in such scenario, combine it withFromElementsGeneratorFunction. - fromCollection(Iterator<OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Deprecated.This method will be removed a future release, possibly as early as version 2.0. Use
StreamExecutionEnvironment.fromData(Collection, TypeInformation)instead. For rate-limited data generation, useDataGeneratorSourcewithRateLimiterStrategy. If you need to use a fixed set of elements in such scenario, combine it withFromElementsGeneratorFunction. - fromConfig(Configuration) - Static method in enum org.apache.flink.runtime.jobmanager.HighAvailabilityMode
-
Return the configured
HighAvailabilityMode. - fromConfig(Configuration) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
-
Creates the scope formats as defined in the given configuration.
- fromConfig(Configuration) - Static method in enum org.apache.flink.runtime.util.ZooKeeperUtils.ZkClientACLMode
-
Return the configured
ZooKeeperUtils.ZkClientACLMode. - fromConfig(ReadableConfig, ClassLoader, Logger) - Static method in class org.apache.flink.runtime.state.CheckpointStorageLoader
-
Loads the checkpoint storage from the configuration, from the parameter 'execution.checkpointing.storage', as defined in
CheckpointingOptions.CHECKPOINT_STORAGE. - fromConfiguration(Configuration) - Static method in interface org.apache.flink.runtime.heartbeat.HeartbeatServices
-
Creates an HeartbeatServices instance from a
Configuration. - fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageConfiguration
- fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.jobmaster.JobMasterConfiguration
- fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.metrics.filter.DefaultMetricFilter
- fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.registration.RetryingRegistrationConfiguration
- fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
- fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.rest.RestClientConfiguration
-
Creates and returns a new
RestClientConfigurationfrom the givenConfiguration. - fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
-
Creates and returns a new
RestServerEndpointConfigurationfrom the givenConfiguration. - fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
-
Creates the
QueryableStateConfigurationfrom the given Configuration. - fromConfiguration(Configuration, long) - Static method in class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
-
Create a metric registry configuration object from the given
Configuration. - fromConfiguration(Configuration, Executor) - Static method in class org.apache.flink.runtime.highavailability.FileSystemJobResultStore
- fromConfiguration(Configuration, MemorySize, boolean, InetAddress) - Static method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
-
Utility method to extract network related parameters from the configuration and to sanity check them.
- fromConfiguration(Configuration, PluginManager) - Static method in class org.apache.flink.runtime.metrics.ReporterSetup
- fromConfiguration(Configuration, PluginManager) - Static method in class org.apache.flink.runtime.metrics.TraceReporterSetup
- fromConfiguration(Configuration, BlobServer, FatalErrorHandler) - Static method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
- fromConfiguration(Configuration, ResourceID, String, boolean, TaskExecutorResourceSpec, WorkingDirectory) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
Utility method to extract TaskManager config parameters from the configuration and to sanity check them.
- fromConfiguration(Configuration, JobType, boolean) - Static method in class org.apache.flink.runtime.jobmaster.DefaultSlotPoolServiceSchedulerFactory
- fromConfiguration(Configuration, WorkerResourceSpec) - Static method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
- fromConfiguration(Configuration, WorkerResourceSpecFactory) - Static method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
- fromConfiguration(Configuration, TaskExecutorResourceSpec, String, File) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
- fromConfiguration(Configuration, MetricQueryServiceRetriever, GatewayRetriever<T>, ExecutorService) - Static method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricFetcherImpl
- fromConfiguration(ReadableConfig) - Static method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
- fromConfiguration(ReadableConfig) - Static method in class org.apache.flink.runtime.throughput.BufferDebloatConfiguration
- fromConfiguration(ResourceManagerRuntimeServicesConfiguration, HighAvailabilityServices, ScheduledExecutor, SlotManagerMetricGroup) - Static method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
- fromConfiguration(TaskManagerServicesConfiguration) - Static method in class org.apache.flink.runtime.taskexecutor.KvStateService
-
Creates and returns the KvState service.
- fromConfiguration(TaskManagerServicesConfiguration, PermanentBlobService, MetricGroup, ExecutorService, ScheduledExecutor, FatalErrorHandler, WorkingDirectory) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
Creates and returns the task manager services.
- fromData(Class<OUT>, OUT...) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains the given elements.
- fromData(Collection<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains the given elements.The type of the data stream is that of the elements in the collection.
- fromData(Collection<OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains the given elements.
- fromData(TypeInformation<OUT>, OUT...) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains the given elements.
- fromData(OUT...) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains the given elements.
- fromElements(Class<OUT>, OUT...) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Deprecated.This method will be removed a future release, possibly as early as version 2.0. Use
#fromData(OUT...)instead. - fromElements(OUT...) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Deprecated.This method will be removed a future release, possibly as early as version 2.0. Use
#fromData(OUT...)instead. - FromElementsFunction<T> - Class in org.apache.flink.streaming.api.functions.source.legacy
-
Deprecated.This class is based on the
SourceFunctionAPI, which is due to be removed. Use the newSourceAPI instead. - FromElementsFunction(Iterable<T>) - Constructor for class org.apache.flink.streaming.api.functions.source.legacy.FromElementsFunction
-
Deprecated.
- FromElementsFunction(TypeSerializer<T>, Iterable<T>) - Constructor for class org.apache.flink.streaming.api.functions.source.legacy.FromElementsFunction
-
Deprecated.
- FromElementsFunction(TypeSerializer<T>, T...) - Constructor for class org.apache.flink.streaming.api.functions.source.legacy.FromElementsFunction
-
Deprecated.
- FromElementsFunction(T...) - Constructor for class org.apache.flink.streaming.api.functions.source.legacy.FromElementsFunction
-
Deprecated.
- fromExceptionHistoryEntry(ExceptionHistoryEntry, Collection<ExceptionHistoryEntry>) - Static method in class org.apache.flink.runtime.scheduler.exceptionhistory.RootExceptionHistoryEntry
- fromExecutionGraph(DefaultExecutionGraph) - Static method in class org.apache.flink.runtime.scheduler.adapter.DefaultExecutionTopology
- fromFailureHandlingResultSnapshot(FailureHandlingResultSnapshot) - Static method in class org.apache.flink.runtime.scheduler.exceptionhistory.RootExceptionHistoryEntry
-
Creates a
RootExceptionHistoryEntrybased on the passedFailureHandlingResultSnapshot. - fromGlobalFailure(Throwable, long, CompletableFuture<Map<String, String>>, Iterable<Execution>) - Static method in class org.apache.flink.runtime.scheduler.exceptionhistory.RootExceptionHistoryEntry
-
Creates a
RootExceptionHistoryEntryrepresenting a global failure from the passedThrowableand timestamp. - fromGlobalFailure(ErrorInfo) - Static method in class org.apache.flink.runtime.scheduler.exceptionhistory.RootExceptionHistoryEntry
-
Creates a
RootExceptionHistoryEntrybased on the passedErrorInfo. - fromGraph(ExecutionGraph) - Static method in class org.apache.flink.runtime.scheduler.adaptive.allocator.JobAllocationsInformation
- fromGraph(ExecutionGraph) - Static method in class org.apache.flink.runtime.scheduler.adaptive.allocator.StateSizeEstimates
- fromHexString(String) - Static method in class org.apache.flink.runtime.clusterframework.types.AllocationID
- fromHexString(String) - Static method in class org.apache.flink.runtime.instance.SlotSharingGroupId
- fromHexString(String) - Static method in class org.apache.flink.runtime.jobgraph.JobVertexID
- fromHexString(String) - Static method in class org.apache.flink.runtime.rest.messages.TriggerId
- FromIteratorFunction<T> - Class in org.apache.flink.streaming.api.functions.source.legacy
-
Deprecated.This class is based on the
SourceFunctionAPI, which is due to be removed. Use the newSourceAPI instead. - FromIteratorFunction(Iterator<T>) - Constructor for class org.apache.flink.streaming.api.functions.source.legacy.FromIteratorFunction
-
Deprecated.
- fromJobGraph(JobGraph) - Static method in class org.apache.flink.runtime.jobgraph.topology.DefaultLogicalTopology
- fromJobStatus(JobStatus) - Static method in enum org.apache.flink.runtime.clusterframework.ApplicationStatus
-
Derives the ApplicationStatus that should be used for a job that resulted in the given job status.
- fromJobType(JobType) - Static method in enum org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory.PartitionLocationConstraint
- fromJobVertexID(JobVertexID) - Static method in class org.apache.flink.runtime.jobgraph.OperatorID
- fromMetaInfoSnapshot(StateMetaInfoSnapshot) - Static method in class org.apache.flink.runtime.state.RegisteredStateMetaInfoBase
- fromMultiplePartitions(int, List<IntermediateResultPartitionID>, ResultPartitionType) - Static method in class org.apache.flink.runtime.scheduler.strategy.ConsumedPartitionGroup
- fromMultipleVertices(List<ExecutionVertexID>, ResultPartitionType) - Static method in class org.apache.flink.runtime.scheduler.strategy.ConsumerVertexGroup
- fromNewRegisteredSerializer(TypeSerializer<T>) - Static method in class org.apache.flink.runtime.state.StateSerializerProvider
-
Creates a
StateSerializerProviderfrom the registered state serializer. - fromParallelCollection(SplittableIterator<OUT>, Class<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains elements in the iterator.
- fromParallelCollection(SplittableIterator<OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains elements in the iterator.
- fromPreviousSerializerSnapshot(TypeSerializerSnapshot<T>) - Static method in class org.apache.flink.runtime.state.StateSerializerProvider
-
Creates a
StateSerializerProviderfor restored state from the previous serializer's snapshot. - fromRequestBodyOrQueryParameter(T, SupplierWithException<T, RestHandlerException>, T, Logger) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRequestUtils
-
Returns
requestValueif it is not null, otherwise returns the query parameter value if it is not null, otherwise returns the default value. - fromResources(double, int) - Static method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
- fromResourceSpec(ResourceSpec, MemorySize) - Static method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
- fromResrouceProfile(ResourceProfile) - Static method in class org.apache.flink.runtime.rest.messages.ResourceProfileInfo
- fromSequence(long, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains a sequence of numbers (longs) and is useful for testing and for cases that just need a stream of N events of any kind.
- fromSerializedEvent(ByteBuffer, ClassLoader) - Static method in class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
- fromSinglePartition(int, IntermediateResultPartitionID, ResultPartitionType) - Static method in class org.apache.flink.runtime.scheduler.strategy.ConsumedPartitionGroup
- fromSingleVertex(ExecutionVertexID, ResultPartitionType) - Static method in class org.apache.flink.runtime.scheduler.strategy.ConsumerVertexGroup
- fromSource(Source<OUT, ?, ?>, WatermarkStrategy<OUT>, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Adds a data
Sourceto the environment to get aDataStream. - fromSource(Source<OUT, ?, ?>, WatermarkStrategy<OUT>, String, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Adds a data
Sourceto the environment to get aDataStream. - FromSplittableIteratorFunction<T> - Class in org.apache.flink.streaming.api.functions.source.legacy
-
Deprecated.This class is based on the
SourceFunctionAPI, which is due to be removed. Use the newSourceAPI instead. - FromSplittableIteratorFunction(SplittableIterator<T>) - Constructor for class org.apache.flink.streaming.api.functions.source.legacy.FromSplittableIteratorFunction
-
Deprecated.
- fromStatusOverview(ClusterOverview, String, String) - Static method in class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
- fromTaskExecutorProcessSpec(TaskExecutorProcessSpec) - Static method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec
- fromTopologicallySortedJobVertices(List<JobVertex>) - Static method in class org.apache.flink.runtime.jobgraph.topology.DefaultLogicalTopology
- fromTotalResourceProfile(ResourceProfile, int) - Static method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec
- fromUnresolvedLocation(UnresolvedTaskManagerLocation, TaskManagerLocation.ResolutionMode) - Static method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
- fromUuid(UUID) - Static method in class org.apache.flink.runtime.dispatcher.DispatcherId
-
Creates a new DispatcherId that corresponds to the UUID.
- fromUuid(UUID) - Static method in class org.apache.flink.runtime.resourcemanager.ResourceManagerId
-
Creates a ResourceManagerId that corresponds to the given UUID.
- fromUuidOrNull(UUID) - Static method in class org.apache.flink.runtime.jobmaster.JobMasterId
-
If the given uuid is null, this returns null, otherwise a JobMasterId that corresponds to the UUID, via
JobMasterId(UUID). - fromUuidOrNull(UUID) - Static method in class org.apache.flink.runtime.resourcemanager.ResourceManagerId
-
If the given uuid is null, this returns null, otherwise a ResourceManagerId that corresponds to the UUID, via
ResourceManagerId(UUID). - FrontMetricGroup<P extends AbstractMetricGroup<?>> - Class in org.apache.flink.runtime.metrics.groups
-
Metric group which forwards all registration calls to a variable parent metric group that injects a variable reporter index into calls to
MetricGroup.getMetricIdentifier(String)orMetricGroup.getMetricIdentifier(String, CharacterFilter). - FrontMetricGroup(ReporterScopedSettings, P) - Constructor for class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
- fs - Variable in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
-
The
FileSystemthat this manager works on. - FsCheckpointMetadataOutputStream - Class in org.apache.flink.runtime.state.filesystem
-
A
CheckpointMetadataOutputStreamthat writes a specified file and directory, and returns aFsCompletedCheckpointStorageLocationupon closing. - FsCheckpointMetadataOutputStream(FileSystem, Path, Path) - Constructor for class org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
- FsCheckpointStateOutputStream(Path, FileSystem, int, int) - Constructor for class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
- FsCheckpointStateOutputStream(Path, FileSystem, int, int, boolean) - Constructor for class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
- FsCheckpointStateToolset - Class in org.apache.flink.runtime.state.filesystem
-
An implementation of
CheckpointStateToolsetthat does file based duplicating with asPathsCopyingFileSystem. - FsCheckpointStateToolset(Path, PathsCopyingFileSystem) - Constructor for class org.apache.flink.runtime.state.filesystem.FsCheckpointStateToolset
- FsCheckpointStorageAccess - Class in org.apache.flink.runtime.state.filesystem
-
An implementation of durable checkpoint storage to file systems.
- FsCheckpointStorageAccess(FileSystem, Path, Path, boolean, JobID, int, int) - Constructor for class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageAccess
- FsCheckpointStorageAccess(Path, Path, boolean, JobID, int, int) - Constructor for class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageAccess
- FsCheckpointStorageAccess(Path, Path, JobID, int, int) - Constructor for class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageAccess
- FsCheckpointStorageLocation - Class in org.apache.flink.runtime.state.filesystem
-
A storage location for checkpoints on a file system.
- FsCheckpointStorageLocation(FileSystem, Path, Path, Path, CheckpointStorageLocationReference, int, int) - Constructor for class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
- FsCheckpointStreamFactory - Class in org.apache.flink.runtime.state.filesystem
-
A
CheckpointStreamFactorythat produces streams that write to aFileSystem. - FsCheckpointStreamFactory(FileSystem, Path, Path, int, int) - Constructor for class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
-
Creates a new stream factory that stores its checkpoint data in the file system and location defined by the given Path.
- FsCheckpointStreamFactory.FsCheckpointStateOutputStream - Class in org.apache.flink.runtime.state.filesystem
-
A
CheckpointStateOutputStreamthat writes into a file and returns aStreamStateHandleupon closing. - FsCompletedCheckpointStorageLocation - Class in org.apache.flink.runtime.state.filesystem
-
A
CompletedCheckpointStorageLocationthat resides on a file system. - FsCompletedCheckpointStorageLocation(FileSystem, Path, FileStateHandle, String) - Constructor for class org.apache.flink.runtime.state.filesystem.FsCompletedCheckpointStorageLocation
- FSDataOutputStreamWrapper - Class in org.apache.flink.runtime.state.filesystem
-
Implementation of
MetadataOutputStreamWrapperencapsulates theFSDataOutputStreamforFsCheckpointMetadataOutputStream. - FSDataOutputStreamWrapper(FileSystem, Path) - Constructor for class org.apache.flink.runtime.state.filesystem.FSDataOutputStreamWrapper
- FsJobArchivist - Class in org.apache.flink.runtime.history
-
Utility class for writing an archive file to a
FileSystemand reading it back. - FsMergingCheckpointStorageAccess - Class in org.apache.flink.runtime.state.filesystem
-
An implementation of file merging checkpoint storage to file systems.
- FsMergingCheckpointStorageAccess(Path, Path, JobID, int, int, FileMergingSnapshotManager, Environment) - Constructor for class org.apache.flink.runtime.state.filesystem.FsMergingCheckpointStorageAccess
- FsMergingCheckpointStorageLocation - Class in org.apache.flink.runtime.state.filesystem
-
An implementation of checkpoint storage location for file merging checkpoints.
- FsMergingCheckpointStorageLocation(FileMergingSnapshotManager.SubtaskKey, FileSystem, Path, Path, Path, CheckpointStorageLocationReference, int, int, FileMergingSnapshotManager, long) - Constructor for class org.apache.flink.runtime.state.filesystem.FsMergingCheckpointStorageLocation
- FsSegmentDataInputStream - Class in org.apache.flink.runtime.state.filesystem
-
This class is a
WrappingProxyforFSDataInputStreamthat is used to read from a file segment. - FsSegmentDataInputStream(FSDataInputStream, long, long) - Constructor for class org.apache.flink.runtime.state.filesystem.FsSegmentDataInputStream
- fulfillFinishedTaskStatus(Map<OperatorID, OperatorState>) - Method in class org.apache.flink.runtime.checkpoint.DefaultCheckpointPlan
- fulfillFinishedTaskStatus(Map<OperatorID, OperatorState>) - Method in interface org.apache.flink.runtime.checkpoint.FinishedTaskStateProvider
-
Fulfills the state for the finished subtasks and operators to indicate they are finished.
- FULL - org.apache.flink.runtime.io.network.api.writer.SubtaskStateMapper
-
Replicates the state to all subtasks.
- FULL - org.apache.flink.runtime.rest.messages.FlameGraphTypeQueryParameter.Type
-
Type of the Flame Graph that includes threads in all possible states.
- FULL_CHECKPOINT - Static variable in class org.apache.flink.runtime.checkpoint.CheckpointType
- FULL_DAM - org.apache.flink.runtime.operators.DamBehavior
-
Constant indicating that the algorithm collects all records before returning any.
- FULL_OUTER_HYBRIDHASH_BUILD_FIRST - org.apache.flink.runtime.operators.DriverStrategy
- FULL_OUTER_HYBRIDHASH_BUILD_SECOND - org.apache.flink.runtime.operators.DriverStrategy
- FULL_OUTER_MERGE - org.apache.flink.runtime.operators.DriverStrategy
- FULL_RESTART_STRATEGY_NAME - Static variable in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategyFactoryLoader
-
Config name for the
RestartAllFailoverStrategy. - FullOuterJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
-
The full outer join driver implements the logic of an outer join operator at runtime.
- FullOuterJoinDriver() - Constructor for class org.apache.flink.runtime.operators.FullOuterJoinDriver
- FullSnapshotAsyncWriter<K> - Class in org.apache.flink.runtime.state
-
An asynchronous writer that can write a full snapshot/savepoint from a
FullSnapshotResources. - FullSnapshotAsyncWriter(SnapshotType, SupplierWithException<CheckpointStreamWithResultProvider, Exception>, FullSnapshotResources<K>) - Constructor for class org.apache.flink.runtime.state.FullSnapshotAsyncWriter
- FullSnapshotResources<K> - Interface in org.apache.flink.runtime.state
-
A
SnapshotResourcesto be used with the backend-independentFullSnapshotAsyncWriter. - FullSnapshotRestoreOperation<K> - Class in org.apache.flink.runtime.state.restore
-
The procedure of restoring state from a savepoint written with the unified binary format.
- FullSnapshotRestoreOperation(KeyGroupRange, ClassLoader, Collection<KeyedStateHandle>, StateSerializerProvider<K>) - Constructor for class org.apache.flink.runtime.state.restore.FullSnapshotRestoreOperation
- FullSnapshotUtil - Class in org.apache.flink.runtime.state
-
Utility methods and constants around creating and restoring full snapshots using
FullSnapshotAsyncWriter. - fullWindowPartition() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Collect records from each partition into a separate full window.
- fullWindowPartition() - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Collect records from each partition into a separate full window.
- FullyFinishedOperatorState - Class in org.apache.flink.runtime.checkpoint
-
A special operator state implementation representing the operators whose instances are all finished.
- FullyFinishedOperatorState(String, String, OperatorID, int, int) - Constructor for class org.apache.flink.runtime.checkpoint.FullyFinishedOperatorState
- fullyLoaded() - Method in interface org.apache.flink.runtime.asyncprocessing.StateExecutor
-
Check if this executor is fully loaded.
- FunctionInitializationContext - Interface in org.apache.flink.runtime.state
-
This interface provides a context in which user functions can initialize by registering to managed state (i.e. state that is managed by state backends).
- FunctionSnapshotContext - Interface in org.apache.flink.runtime.state
-
This interface provides a context in which user functions that use managed state (i.e. state that is managed by state backends) can participate in a snapshot.
- furtherPartitioning - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
- furtherPartitioning - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
G
- GarbageCollectorInfo(String, long, long) - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo.GarbageCollectorInfo
- garbageCollectorNames - Variable in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.TaskManagerMetricStore
- GATE_RESTORE_DURATION - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- GateBuffersSpec - Class in org.apache.flink.runtime.io.network.partition.consumer
-
The buffer specs of the
InputGateinclude exclusive buffers per channel, required/total floating buffers and the target of total buffers. - GatewayRetriever<T extends org.apache.flink.runtime.rpc.RpcGateway> - Interface in org.apache.flink.runtime.webmonitor.retriever
-
Generic retriever interface for
RpcGateway. - gauge(String, G) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
- gauge(String, G) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
- GaugeDump(QueryScopeInfo, String, String) - Constructor for class org.apache.flink.runtime.metrics.dump.MetricDump.GaugeDump
- GaugePeriodTimer - Class in org.apache.flink.streaming.runtime.tasks.mailbox
-
Implementation of
PeriodTimerbased onTimerGauge. - GaugePeriodTimer(TimerGauge) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.GaugePeriodTimer
- generate() - Static method in class org.apache.flink.runtime.clusterframework.types.ResourceID
-
Generate a random resource id.
- generate() - Static method in class org.apache.flink.runtime.dispatcher.DispatcherId
-
Generates a new random DispatcherId.
- generate() - Static method in class org.apache.flink.runtime.jobmaster.JobMasterId
-
Generates a new random JobMasterId.
- generate() - Static method in class org.apache.flink.runtime.resourcemanager.ResourceManagerId
-
Generates a new random ResourceManagerId.
- generate() - Static method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingTaskManagerId
- generate() - Method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
- generateBufferWithHeaders(List<Tuple2<Buffer, Integer>>) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageUtils
- generateCheckpointStatistics(AbstractCheckpointStats, boolean) - Static method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- generateConnectionInformationPath(String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
- generateDefaultSlotResourceProfile(ResourceProfile, int) - Static method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerUtils
- generateDefaultSlotResourceProfile(WorkerResourceSpec, int) - Static method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerUtils
- generateDefaultSlotResourceProfile(TaskExecutorResourceSpec, int) - Static method in class org.apache.flink.runtime.taskexecutor.TaskExecutorResourceUtils
- generatedIDOnly(OperatorID) - Static method in class org.apache.flink.runtime.OperatorIDPair
- GeneratedLogUrlHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Handler for retrieving the log url of a specified TaskManager or JobManager.
- GeneratedLogUrlHandler(CompletableFuture<String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.GeneratedLogUrlHandler
- generateDynamicConfigsStr(TaskExecutorProcessSpec) - Static method in class org.apache.flink.runtime.clusterframework.TaskExecutorProcessUtils
- generateDynamicConfigsStr(JobManagerProcessSpec) - Static method in class org.apache.flink.runtime.jobmanager.JobManagerProcessUtils
- generateExternalResourcesString(Collection<ExternalResource>) - Static method in class org.apache.flink.runtime.externalresource.ExternalResourceUtils
-
Generate the string expression of the given external resources.
- generateJobManagerWorkingDirectoryFile(Configuration, ResourceID) - Static method in class org.apache.flink.runtime.entrypoint.ClusterEntrypointUtils
-
Generates the working directory
Filefor the JobManager process. - generateJvmParametersStr(JobManagerProcessSpec, Configuration) - Static method in class org.apache.flink.runtime.jobmanager.JobManagerProcessUtils
- generateJvmParametersStr(ProcessMemorySpec) - Static method in class org.apache.flink.runtime.util.config.memory.ProcessMemoryUtils
- generateJvmParametersStr(ProcessMemorySpec, boolean) - Static method in class org.apache.flink.runtime.util.config.memory.ProcessMemoryUtils
- generateLeaderLatchPath(String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
- generateOperatorDescription(Function, Function) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
- generateOperatorID(String) - Static method in class org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator
-
Creates an instance of
OperatorIDbased on the provided operator unique identifier (UID). - generateOperatorName() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
- generatePhysicalFilePath(Path) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
-
Generate a file path for a physical file.
- generatePlan(JobID, String, JobType, Iterable<JobVertex>, VertexParallelism) - Static method in class org.apache.flink.runtime.jobgraph.jsonplan.JsonPlanGenerator
- generatePlan(JobGraph) - Static method in class org.apache.flink.runtime.jobgraph.jsonplan.JsonPlanGenerator
- generateRandomId() - Static method in class org.apache.flink.runtime.checkpoint.filemerging.LogicalFile.LogicalFileId
- generateRegistration() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
This method generate a specific Registration, for example TaskExecutor Registration at the ResourceManager.
- generateRegistration() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorToResourceManagerConnection
- generateSequence(long, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Deprecated.Use
StreamExecutionEnvironment.fromSequence(long, long)instead to create a new data stream that containsNumberSequenceSource. - generateSlotOffer() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
Generate the slot offer from this TaskSlot.
- generateStreamGraph(List<Transformation<?>>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Generates a
StreamGraphthat consists of the giventransformationsand is configured with the configuration of this environment. - generateTaskManagerTotalResourceProfile(WorkerResourceSpec) - Static method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerUtils
- generateTaskManagerWorkingDirectoryFile(Configuration, ResourceID) - Static method in class org.apache.flink.runtime.entrypoint.ClusterEntrypointUtils
-
Generates the working directory
Filefor the TaskManager process. - generateTotalAvailableResourceProfile(TaskExecutorResourceSpec) - Static method in class org.apache.flink.runtime.taskexecutor.TaskExecutorResourceUtils
- generateUserSpecifiedHash(String) - Static method in class org.apache.flink.streaming.api.graph.StreamGraphHasherV2
- generateWorkingDirectoryFile(Configuration, Optional<ConfigOption<String>>, String) - Static method in class org.apache.flink.runtime.entrypoint.ClusterEntrypointUtils
-
Generate the working directory from the given configuration.
- generateZookeeperPath(String...) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Creates a ZooKeeper path of the form "/a/b/...
- generic(SequenceNumber, SequenceNumber) - Static method in interface org.apache.flink.runtime.state.changelog.SequenceNumberRange
- GENERIC - org.apache.flink.runtime.metrics.groups.AbstractMetricGroup.ChildType
- GenericJobEventSerializer - Class in org.apache.flink.runtime.jobmaster.event
-
Serializer for
JobEventinstances that uses Flink'sInstantiationUtilfor serialization and deserialization. - GenericJobEventSerializer() - Constructor for class org.apache.flink.runtime.jobmaster.event.GenericJobEventSerializer
- GenericKeyMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
A
GenericMetricGroupfor representing the key part of a key-value metric group pair. - GenericMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
A simple named
MetricGroupthat is used to hold subgroups of metrics. - GenericMetricGroup(MetricRegistry, AbstractMetricGroup, String) - Constructor for class org.apache.flink.runtime.metrics.groups.GenericMetricGroup
- GenericSequenceNumberRange(SequenceNumber.GenericSequenceNumber, SequenceNumber.GenericSequenceNumber) - Constructor for class org.apache.flink.runtime.state.changelog.SequenceNumberRange.GenericSequenceNumberRange
- GenericValueMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
A
GenericMetricGroupfor representing the value part of a key-value metric group pair. - get() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
-
Atomically gets the current checkpoint ID.
- get() - Method in enum org.apache.flink.runtime.checkpoint.DeactivatedCheckpointIDCounter
- get() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
- get() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
- get() - Static method in enum org.apache.flink.runtime.executiongraph.NoOpExecutionDeploymentListener
- get() - Static method in class org.apache.flink.runtime.messages.Acknowledge
-
Gets the singleton instance.
- get() - Method in interface org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup.SizeSupplier
- get() - Method in class org.apache.flink.runtime.state.DoneFuture
- get() - Method in class org.apache.flink.runtime.state.FileMergingSnapshotManagerClosableWrapper
- get() - Method in class org.apache.flink.runtime.state.PartitionableListState
- get() - Method in class org.apache.flink.runtime.state.v2.AbstractAggregatingState
- get() - Method in class org.apache.flink.runtime.state.v2.AbstractListState
- get() - Method in class org.apache.flink.runtime.state.v2.AbstractReducingState
- get() - Method in class org.apache.flink.runtime.state.v2.adaptor.ListStateAdaptor
- get() - Method in class org.apache.flink.runtime.state.v2.adaptor.MergingStateAdaptor
- get() - Static method in class org.apache.flink.runtime.state.VoidNamespace
-
Getter for the singleton instance
- get() - Static method in class org.apache.flink.runtime.util.EmptyIterator
-
Gets a singleton instance of the empty iterator.
- get() - Static method in class org.apache.flink.runtime.util.EmptyMutableObjectIterator
-
Gets a singleton instance of the empty iterator.
- get() - Method in class org.apache.flink.streaming.api.operators.util.SimpleVersionedListState
- get() - Static method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow
- get(int) - Method in class org.apache.flink.runtime.operators.util.BitSet
-
Returns true if the bit is set in the specified index.
- get(int) - Method in class org.apache.flink.runtime.state.ChainedStateHandle
-
Get the state handle for a single operator in the operator chain by it's index.
- get(int, int) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.index.FileDataIndexCache
-
Get a region contains target bufferIndex and belong to target subpartition.
- get(long, TimeUnit) - Method in class org.apache.flink.runtime.state.DoneFuture
- get(G, K) - Method in class org.apache.flink.runtime.util.DefaultGroupCache
- get(G, K) - Method in interface org.apache.flink.runtime.util.GroupCache
-
Get value in cache.
- get(Object) - Method in interface org.apache.flink.runtime.operators.coordination.CoordinatorStore
- get(Object) - Method in class org.apache.flink.runtime.operators.coordination.CoordinatorStoreImpl
- get(String) - Method in class org.apache.flink.runtime.iterative.concurrent.Broker
-
Blocking retrieval and removal of the object to share.
- get(K) - Method in class org.apache.flink.runtime.rest.handler.async.CompletedOperationCache
-
Returns an optional containing the
OperationResultfor the specified key, or an empty optional if no operation is registered under the key. - get(K) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
- get(K, N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
- get(K, N) - Method in class org.apache.flink.runtime.state.heap.StateMap
-
Returns the state for the composite of active key and given namespace.
- get(K, N) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Returns the state for the composite of active key and given namespace.
- get(N) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Returns the state of the mapping for the composite of active key and given namespace.
- get(N, TypeSerializer<N>, StateDescriptor<S, ?>) - Method in interface org.apache.flink.runtime.state.AbstractKeyedStateBackend.PartitionStateFactory
- get(JobID) - Method in class org.apache.flink.runtime.dispatcher.DefaultJobManagerRunnerRegistry
- get(JobID) - Method in interface org.apache.flink.runtime.dispatcher.ExecutionGraphInfoStore
-
Get the
ExecutionGraphInfofor the given job id. - get(JobID) - Method in class org.apache.flink.runtime.dispatcher.FileExecutionGraphInfoStore
- get(JobID) - Method in interface org.apache.flink.runtime.dispatcher.JobManagerRunnerRegistry
-
Returns the
JobManagerRunnerfor the givenJobID. - get(JobID) - Method in class org.apache.flink.runtime.dispatcher.MemoryExecutionGraphInfoStore
- get(JobID) - Method in class org.apache.flink.runtime.dispatcher.OnMainThreadJobManagerRunnerRegistry
- get(JobID, BlobKey, File) - Method in interface org.apache.flink.runtime.blob.BlobView
-
Copies a blob to a local file.
- get(JobID, BlobKey, File) - Method in class org.apache.flink.runtime.blob.FileSystemBlobStore
- get(JobID, BlobKey, File) - Method in class org.apache.flink.runtime.blob.VoidBlobStore
- get(CloseableRegistry) - Method in class org.apache.flink.runtime.state.FullSnapshotAsyncWriter
- get(CloseableRegistry) - Method in interface org.apache.flink.runtime.state.SnapshotStrategy.SnapshotResultSupplier
-
Performs the asynchronous part of a checkpoint and returns the snapshot result.
- get(TaskExecutorClusterPartitionReleaser) - Method in interface org.apache.flink.runtime.io.network.partition.ResourceManagerPartitionTrackerFactory
- get(JobVertexID, IntermediateDataSetID) - Method in class org.apache.flink.runtime.executiongraph.VertexInputInfoStore
-
Get a
JobVertexInputInfo. - get(T) - Method in class org.apache.flink.streaming.util.typeutils.FieldAccessor
-
Gets the value of the field (specified in the constructor) of the given record.
- get(UK) - Method in class org.apache.flink.runtime.state.v2.AbstractMapState
- get(UK) - Method in class org.apache.flink.runtime.state.v2.adaptor.MapStateAdaptor
- GET - org.apache.flink.runtime.rest.HttpMethodWrapper
- GET_JM_RESOURCE_PARAMS - org.apache.flink.runtime.util.bash.BashJavaUtils.Command
-
Get JVM parameters and dynamic configs of job manager resources.
- GET_TM_RESOURCE_PARAMS - org.apache.flink.runtime.util.bash.BashJavaUtils.Command
-
Get JVM parameters and dynamic configs of task executor resources.
- getAccessor(TypeInformation<T>, int, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.typeutils.FieldAccessorFactory
-
Creates a
FieldAccessorfor the given field position, which can be used to get and set the specified field on instances of this type. - getAccessor(TypeInformation<T>, String, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.typeutils.FieldAccessorFactory
-
Creates a
FieldAccessorfor the field that is given by a field expression, which can be used to get and set the specified field on instances of this type. - getAccumulateBackPressuredTime() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
- getAccumulateBusyTime() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
- getAccumulatedBackpressured() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- getAccumulatedBackPressuredTimeMs() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- getAccumulatedBusy() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- getAccumulatedCount() - Method in class org.apache.flink.runtime.metrics.TimerGauge
- getAccumulatedIdle() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- getAccumulateIdleTime() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
- getAccumulatorExclusiveBuffers() - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageUtils
-
Get exclusive buffer number of accumulator.
- getAccumulatorRegistry() - Method in interface org.apache.flink.runtime.execution.Environment
-
Return the registry for accumulators which are periodically sent to the job manager.
- getAccumulatorRegistry() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getAccumulatorRegistry() - Method in class org.apache.flink.runtime.taskmanager.Task
- getAccumulatorReport() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorToJobManagerHeartbeatPayload
- getAccumulatorResults() - Method in class org.apache.flink.runtime.jobmaster.JobResult
- getAccumulatorResultsStringified() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the aggregated user-defined accumulators as strings.
- getAccumulatorResultsStringified() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
- getAccumulatorResultsStringified() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
-
Returns the a stringified version of the user-defined accumulators.
- getAccumulators() - Method in class org.apache.flink.runtime.executiongraph.TaskExecutionStateTransition
- getAccumulators() - Method in class org.apache.flink.runtime.minicluster.MiniClusterJobClient
- getAccumulators() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
Gets flink and user-defined accumulators in serialized form.
- getAccumulatorSnapshots() - Method in class org.apache.flink.runtime.taskexecutor.AccumulatorReport
- getAccumulatorsSerialized() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns a map containing the serialized values of user-defined accumulators.
- getAccumulatorsSerialized() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
- getAccumulatorsSerialized() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
-
Gets a serialized accumulator map.
- getAckTimestamp() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
-
Returns the timestamp when the acknowledgement of this subtask was received at the coordinator.
- getAckTimestamp() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
- getAckTimestampStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
- getAclForPath(String) - Method in class org.apache.flink.runtime.util.ZooKeeperUtils.SecureAclProvider
- getAcquiredResources(JobID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.DefaultResourceTracker
- getAcquiredResources(JobID) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ResourceTracker
-
Returns a collection of
ResourceRequirements that describe which resources have been assigned to a job. - getActiveSerializer(InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
- getActiveSerializer(InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.recovery.RescalingStreamTaskNetworkInput
- getActiveTaskSlotAllocationIds() - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Returns the
AllocationIDof any active task listed in thisTaskSlotTable. - getActiveTaskSlotAllocationIds() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- getActiveTaskSlotAllocationIdsPerJob(JobID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
- getActiveTaskSlotAllocationIdsPerJob(JobID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- getAdditionalDetailsForIncompatibleVersion(int) - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
- getAdditionalVariables() - Method in class org.apache.flink.runtime.metrics.groups.ReporterScopedSettings
- getAdditionalVariables() - Method in class org.apache.flink.runtime.metrics.ReporterSetup
- getAdditionalVariables() - Method in class org.apache.flink.runtime.metrics.TraceReporterSetup
- getAddress() - Method in class org.apache.flink.runtime.io.network.ConnectionID
- getAddress() - Method in exception org.apache.flink.runtime.io.network.netty.exception.TransportException
- getAddress() - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Return the address of the task manager with which the gateway is associated.
- getAddress() - Method in interface org.apache.flink.runtime.jobmaster.JobMasterService
-
Get the address of the JobMaster service under which it is reachable.
- getAddress() - Method in class org.apache.flink.runtime.jobmaster.ResourceManagerAddress
- getAddress() - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
- getAddress() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- getAddress() - Method in class org.apache.flink.runtime.scheduler.exceptionhistory.ExceptionHistoryEntry.ArchivedTaskManagerLocation
- getAddress() - Method in enum org.apache.flink.runtime.shuffle.NettyShuffleDescriptor.LocalExecutionPartitionConnectionInfo
- getAddress() - Method in class org.apache.flink.runtime.shuffle.NettyShuffleDescriptor.NetworkPartitionConnectionInfo
- getAddress() - Method in interface org.apache.flink.runtime.shuffle.NettyShuffleDescriptor.PartitionConnectionInfo
- getAddress() - Method in class org.apache.flink.runtime.shuffle.ProducerDescriptor
- getAddress() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- getAddress() - Method in class org.apache.flink.runtime.webmonitor.NonLeaderRetrievalRestfulGateway
- getAddress() - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkAddressEvent
- getAggregatedSubpartitionBytes() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.AllToAllBlockingResultInfo
- getAggregatedUserAccumulatorsStringified() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
Returns the aggregated user-defined accumulators as strings.
- getAggregatedUserAccumulatorsStringified() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
- getAggregatedUserAccumulatorsStringified() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- getAggregateFunction() - Method in class org.apache.flink.runtime.state.v2.AggregatingStateDescriptor
-
Returns the Aggregate function for this state.
- getAggregateJobVertexState(int[], int) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
A utility function that computes an "aggregated" state for the vertex.
- getAggregates() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
- getAggregates(ClassLoader) - Method in class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
- getAggregateState() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
Returns the aggregated
ExecutionStatefor this job vertex. - getAggregateState() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
- getAggregateState() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
- getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
- getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
- getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - Method in class org.apache.flink.runtime.state.v2.DefaultKeyedStateStoreV2
- getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - Method in interface org.apache.flink.runtime.state.v2.KeyedStateStoreV2
-
Gets a handle to the system's key/value aggregating state.
- getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
- getAggregator(String) - Method in class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
- getAggregatorNames() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
- getAggregatorNames() - Method in class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
- getAlignedCheckpointTimeout() - Method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
- getAlignedCheckpointTimeout() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
- getAlignedCheckpointTimeout() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
- getAlignedCheckpointTimeout() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getAlignment() - Method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
- getAlignment() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
- getAlignmentDuration() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
- getAlignmentDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
- getAlignmentDurationNanos() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
- getAlignmentDurationNanos() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetricsBuilder
- getAlignmentDurationNanos() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
- getAlignmentDurationNanosOrDefault() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetricsBuilder
- getAlignmentDurationStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
- getAllAggregators() - Method in class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
- getAllAndLock() - Method in interface org.apache.flink.runtime.persistence.StateHandleStore
-
Gets all available state handles from the storage.
- getAllAndLock() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Gets all available state handles from ZooKeeper and locks the respective state nodes.
- getAllAttemptsMetricStores() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.SubtaskMetricStore
- getAllBarriersReceivedFuture(long) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
- getAllBarriersReceivedFuture(long) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
- getAllBarriersReceivedFuture(long) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
- getAllBlockedNodeIds() - Method in interface org.apache.flink.runtime.blocklist.BlockedNodeRetriever
-
Get all blocked node ids.
- getAllBlockedNodeIds() - Method in interface org.apache.flink.runtime.blocklist.BlocklistHandler
-
Get all blocked node ids.
- getAllBlockedNodeIds() - Method in interface org.apache.flink.runtime.blocklist.BlocklistTracker
-
Get all blocked node ids.
- getAllBlockedNodeIds() - Method in class org.apache.flink.runtime.blocklist.DefaultBlocklistHandler
- getAllBlockedNodeIds() - Method in class org.apache.flink.runtime.blocklist.DefaultBlocklistTracker
- getAllBlockedNodeIds() - Method in class org.apache.flink.runtime.blocklist.NoOpBlocklistHandler
- getAllBlockedNodes() - Method in interface org.apache.flink.runtime.blocklist.BlocklistTracker
-
Get all blocked nodes.
- getAllBlockedNodes() - Method in class org.apache.flink.runtime.blocklist.DefaultBlocklistTracker
- getAllCheckpoints() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
Returns all
CompletedCheckpointinstances. - getAllCheckpoints() - Method in enum org.apache.flink.runtime.checkpoint.DeactivatedCheckpointCompletedCheckpointStore
- getAllCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.DefaultCompletedCheckpointStore
- getAllCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.EmbeddedCompletedCheckpointStore
- getAllCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
- getAllConsumedPartitionGroups() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getAllDataProcessedFuture() - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
Gets the future indicating whether all the records has been processed by the downstream tasks.
- getAllDataProcessedFuture() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartition
- getAllDataProcessedFuture() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedResultPartition
- getAllDataProcessedFuture() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- getAllExecutionVertices() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns an iterable containing all execution vertices for this execution graph.
- getAllExecutionVertices() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
- getAllExecutionVertices() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getAllExecutionVertices() - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- getAllFutures() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
- getAllHandles() - Method in interface org.apache.flink.runtime.persistence.StateHandleStore
-
Return a list of all valid name for state handles.
- getAllHandles() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
- getAllInputGates() - Method in interface org.apache.flink.runtime.execution.Environment
- getAllInputGates() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getAllIntermediateResults() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getAllIntermediateResults() - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- getAllNonPipelinedConsumedPartitionGroups() - Method in class org.apache.flink.runtime.scheduler.adapter.DefaultSchedulingPipelinedRegion
- getAllNonPipelinedConsumedPartitionGroups() - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingPipelinedRegion
-
Get all distinct blocking
ConsumedPartitionGroups. - getAllocatedOrPendingSlot(AllocationID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- getAllocatedSlotInfos() - Method in class org.apache.flink.runtime.jobmaster.AllocatedSlotReport
- getAllocatedSlots() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotPool.AllocatedSlotsAndReservationStatus
- getAllocatedSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerRegistration
- getAllocatedSlots() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerInfo
-
Get allocated slots information.
- getAllocatedSlots() - Method in class org.apache.flink.runtime.resourcemanager.TaskManagerInfoWithSlots
- getAllocatedSlots() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsInfo
- getAllocatedSlots(JobID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Return an iterator of allocated slots for the given job id.
- getAllocatedSlots(JobID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- getAllocatedSlotsInformation() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolBridge
- getAllocatedSlotsInformation() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Returns a list of
SlotInfoobjects about all slots that are currently allocated in the slot pool. - getAllocatedSlotsOf(InstanceID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedSlotManager
- getAllocatedSlotsOf(InstanceID) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
- getAllocationId() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
- getAllocationId() - Method in class org.apache.flink.runtime.jobmaster.AllocatedSlotInfo
- getAllocationId() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Gets the allocation id of this slot.
- getAllocationId() - Method in interface org.apache.flink.runtime.jobmaster.SlotInfo
-
Gets the id under which the slot has been allocated on the TaskManager.
- getAllocationId() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotPool.FreeSlotInfo
- getAllocationId() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
- getAllocationId() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerSlot
- getAllocationId() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerSlotInformation
- getAllocationId() - Method in exception org.apache.flink.runtime.taskexecutor.exceptions.SlotOccupiedException
- getAllocationId() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotAllocationSnapshot
- getAllocationId() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotOffer
- getAllocationId() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
- getAllocationId() - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotPayload
- getAllocationId() - Method in class org.apache.flink.runtime.taskmanager.Task
- getAllocationID() - Method in class org.apache.flink.runtime.scheduler.adaptive.allocator.JobAllocationsInformation.VertexAllocationInformation
- getAllocationID() - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
-
Get the allocation id of this slot.
- getAllocationIdsOfFulfilledRequests() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlotRequestBulk
-
Returns
AllocationIDs of fulfilled physical slot requests. - getAllocationIdsPerJob(JobID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Returns the all
AllocationIDfor the given job. - getAllocationIdsPerJob(JobID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- getAllocations(JobVertexID) - Method in class org.apache.flink.runtime.scheduler.adaptive.allocator.JobAllocationsInformation
- getAllocationsOnPendingResources() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceAllocationResult
- getAllocationsOnRegisteredResources() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceAllocationResult
- getAllOperators() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
Returns an
Iterablewhich traverses all operators in forward topological order. - getAllOperators(boolean) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
Returns an
Iterablewhich traverses all operators in forward or reverse topological order. - getAllowedLateness() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
- getAllPartitions() - Method in class org.apache.flink.runtime.io.network.partition.BufferWritingResultPartition
- getAllPipelinedRegions() - Method in class org.apache.flink.runtime.jobgraph.topology.DefaultLogicalTopology
- getAllPipelinedRegions() - Method in class org.apache.flink.runtime.scheduler.adapter.DefaultExecutionTopology
- getAllPipelinedRegions() - Method in interface org.apache.flink.runtime.topology.Topology
-
Returns all pipelined regions in this topology.
- getAllReleaseBySchedulerConsumedPartitionGroups() - Method in class org.apache.flink.runtime.scheduler.adapter.DefaultSchedulingPipelinedRegion
- getAllReleaseBySchedulerConsumedPartitionGroups() - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingPipelinedRegion
-
Get all distinct releaseByScheduler
ConsumedPartitionGroups. - getAllSerializedShuffleDescriptorGroups() - Method in class org.apache.flink.runtime.deployment.CachedShuffleDescriptors
- getAllSlotsInformation() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotPool
-
Returns information about all slots in this pool.
- getAllSlotsInformation() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPool
-
Returns the slot information for all slots (free and allocated slots).
- getAllSlotsInformation() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultAllocatedSlotPool
- getAllSlotsInformation() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultDeclarativeSlotPool
- getAllSubtaskMetricStores() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.TaskMetricStore
- getAllTaskStateStats() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns all task state stats instances.
- getAllTrackedClusterPartitions() - Method in interface org.apache.flink.runtime.io.network.partition.JobMasterPartitionTracker
-
Gets all the cluster partitions under tracking.
- getAllTrackedNonClusterPartitions() - Method in interface org.apache.flink.runtime.io.network.partition.JobMasterPartitionTracker
-
Gets all the non-cluster partitions under tracking.
- getAllTrackedPartitions() - Method in interface org.apache.flink.runtime.io.network.partition.JobMasterPartitionTracker
-
Gets all the partitions under tracking.
- getAllTrackedPartitions() - Method in class org.apache.flink.runtime.io.network.partition.JobMasterPartitionTrackerImpl
- getAllVariables() - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
- getAllVariables() - Method in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
- getAllVariables() - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
- getAllVariables(int, Set<String>) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
- getAllVertices() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns a map containing all job vertices for this execution graph.
- getAllVertices() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
- getAllVertices() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getAllVertices() - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- getAllWriters() - Method in interface org.apache.flink.runtime.execution.Environment
- getAllWriters() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getAlwaysParentFirstLoaderPatterns() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
- getAmbiguousTargets() - Method in class org.apache.flink.runtime.checkpoint.RescaleMappings
- getAndIncrement() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
-
Atomically increments the current checkpoint ID.
- getAndIncrement() - Method in enum org.apache.flink.runtime.checkpoint.DeactivatedCheckpointIDCounter
- getAndIncrement() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
- getAndIncrement() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
- getAndLock(String) - Method in interface org.apache.flink.runtime.persistence.StateHandleStore
-
Gets the
RetrievableStateHandlestored with the given name. - getAndLock(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Gets the
RetrievableStateHandlestored in the given ZooKeeper node and locks it. - getAndRemove(String) - Method in class org.apache.flink.runtime.iterative.concurrent.Broker
-
Blocking retrieval and removal of the object to share.
- getAndRemove(Predicate<T>) - Method in class org.apache.flink.runtime.io.network.partition.PrioritizedDeque
-
Find first element matching the
Predicate, remove it from thePrioritizedDequeand return it. - getAndRemoveUncheckpointedAssignment(int, long) - Method in class org.apache.flink.runtime.source.coordinator.SplitAssignmentTracker
-
This method is invoked when a source reader fails over.
- getAndRemoveWriteResult(long) - Method in interface org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter
-
Must be called after
ChannelStateWriter.start(long, CheckpointOptions)once. - getAndRemoveWriteResult(long) - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter.NoOpChannelStateWriter
- getAndRemoveWriteResult(long) - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriterImpl
- getAndResetUnannouncedCredit() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
Gets the unannounced credit and resets it to 0 atomically.
- getAndRetainPartitionWithMetrics(JobID) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- getAndRetainPartitionWithMetrics(JobID) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Get and retain all partitions and their metrics located on this task executor, the metrics mainly includes the meta information of partition(partition bytes, etc).
- getAnnouncedEvent() - Method in class org.apache.flink.runtime.io.network.api.EventAnnouncement
- getAppConfigurationEntries(SecurityConfiguration) - Static method in class org.apache.flink.runtime.security.modules.JaasModule
- getAppConfigurationEntry(String) - Method in class org.apache.flink.runtime.security.DynamicConfiguration
-
Retrieve the AppConfigurationEntries for the specified name from this Configuration.
- getApplicationStatus() - Method in class org.apache.flink.runtime.jobmaster.JobResult
- getArchivedExecutionConfig() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the
ArchivedExecutionConfigfor this execution graph. - getArchivedExecutionConfig() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
- getArchivedExecutionConfig() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
-
Returns the serializable
ArchivedExecutionConfig. - getArchivedExecutionGraph() - Method in class org.apache.flink.runtime.scheduler.ExecutionGraphInfo
- getArchivedExecutionGraph(JobID) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- getArchivedExecutionGraph(JobStatus, Throwable) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- getArchivedExecutionGraphStore() - Method in class org.apache.flink.runtime.dispatcher.DispatcherServices
- getArchivedExecutionGraphStore() - Method in class org.apache.flink.runtime.dispatcher.PartialDispatcherServices
- getArchivedJsons(Path) - Static method in class org.apache.flink.runtime.history.FsJobArchivist
-
Reads the given archive file and returns a
Collectionof containedArchivedJson. - getArgs() - Method in class org.apache.flink.runtime.entrypoint.ClusterConfiguration
- getArity() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
- getArity() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
- getAssignedAllocationID() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
- getAssignedAllocationID() - Method in class org.apache.flink.runtime.executiongraph.Execution
- getAssignedResource() - Method in class org.apache.flink.runtime.executiongraph.Execution
- getAssignedResourceLocation() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
Returns the
TaskManagerLocationfor this execution. - getAssignedResourceLocation() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
- getAssignedResourceLocation() - Method in class org.apache.flink.runtime.executiongraph.Execution
- getAssignmentMode() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
- getAssignmentMode() - Method in class org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
- getAsyncCheckpointDuration() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
- getAsyncCheckpointDurationStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
- getAsyncCheckpointStartDelayNanos() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- getAsyncDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
- getAsyncDurationMillis() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
- getAsyncDurationMillis() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetricsBuilder
- getAsyncExecutionController() - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperatorV2
- getAsynchronousDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
- getAsyncInternalTimerService(String, TypeSerializer<K>, TypeSerializer<N>, Triggerable<K, N>, AsyncExecutionController<K>) - Method in interface org.apache.flink.streaming.api.operators.InternalTimeServiceManager
-
Creates an
InternalTimerServiceAsyncImplfor handling a group of timers identified by the givenname. - getAsyncInternalTimerService(String, TypeSerializer<K>, TypeSerializer<N>, Triggerable<K, N>, AsyncExecutionController<K>) - Method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManagerImpl
- getAsyncInternalTimerService(String, TypeSerializer<K>, TypeSerializer<N>, Triggerable<K, N>, AsyncExecutionController<K>) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeServiceManager
- getAsyncKeyedStateBackend() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
- getAsyncOperationDescription() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationTriggerMessageHeaders
-
Returns the description for this async operation header.
- getAsyncOperationDescription() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
- getAsyncOperationDescription() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointTriggerHeaders
- getAsyncOperationDescription() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteTriggerHeaders
- getAsyncOperationDescription() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
- getAsyncOperationDescription() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
- getAsyncOperationDescription() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointTriggerHeaders
- getAsyncOperationsThreadPool() - Method in interface org.apache.flink.runtime.execution.Environment
- getAsyncOperationsThreadPool() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getAsyncOperationsThreadPool() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- getAttempt() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- getAttemptCount(int) - Method in class org.apache.flink.runtime.executiongraph.DefaultSubtaskAttemptNumberStore
- getAttemptCount(int) - Method in interface org.apache.flink.runtime.executiongraph.SubtaskAttemptNumberStore
-
Returns the attempt number for the given subtask.
- getAttemptCounts(JobVertexID) - Method in class org.apache.flink.runtime.executiongraph.DefaultVertexAttemptNumberStore
- getAttemptCounts(JobVertexID) - Method in interface org.apache.flink.runtime.executiongraph.VertexAttemptNumberStore
-
Returns the attempt numbers for the given vertex.
- getAttemptId() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
Returns the
ExecutionAttemptIDfor this Execution. - getAttemptId() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
- getAttemptId() - Method in class org.apache.flink.runtime.executiongraph.Execution
- getAttemptNumber() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Returns the attempt number of the subtask.
- getAttemptNumber() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
Returns the attempt number for this execution.
- getAttemptNumber() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
- getAttemptNumber() - Method in class org.apache.flink.runtime.executiongraph.Execution
- getAttemptNumber() - Method in class org.apache.flink.runtime.executiongraph.ExecutionAttemptID
- getAttemptNumber() - Method in class org.apache.flink.runtime.jobmaster.event.ExecutionVertexFinishedEvent
- getAttemptNumber() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
- getAttemptsMetricStore(int) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.SubtaskMetricStore
- getAttribute() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getAttribute(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getAvailabilityAndBacklog() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
Checks whether this reader is available or not and returns the backlog at the same time.
- getAvailabilityAndBacklog(boolean) - Method in class org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionDirectTransferReader
- getAvailabilityAndBacklog(boolean) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.TieredStorageResultSubpartitionView
- getAvailabilityAndBacklog(boolean) - Method in class org.apache.flink.runtime.io.network.partition.NoOpResultSubpartitionView
- getAvailabilityAndBacklog(boolean) - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartition
- getAvailabilityAndBacklog(boolean) - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartitionView
- getAvailabilityAndBacklog(boolean) - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
-
Get the availability and backlog of the view.
- getAvailabilityAndBacklog(boolean) - Method in class org.apache.flink.runtime.io.network.partition.UnionResultSubpartitionView
- getAvailabilityProvider() - Method in interface org.apache.flink.runtime.state.changelog.StateChangelogStorage
- getAvailableBudget() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceBudgetManager
- getAvailableBuffers() - Method in class org.apache.flink.runtime.io.disk.BatchShuffleReadBufferPool
- getAvailableFuture() - Method in class org.apache.flink.runtime.io.AvailabilityProvider.AvailabilityHelper
- getAvailableFuture() - Method in interface org.apache.flink.runtime.io.AvailabilityProvider
- getAvailableFuture() - Method in class org.apache.flink.runtime.io.network.api.writer.MultipleRecordWriters
- getAvailableFuture() - Method in class org.apache.flink.runtime.io.network.api.writer.NonRecordWriter
- getAvailableFuture() - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
- getAvailableFuture() - Method in class org.apache.flink.runtime.io.network.api.writer.SingleRecordWriter
- getAvailableFuture() - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
- getAvailableFuture() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
Returns a future that is completed when there are free segments in this pool.
- getAvailableFuture() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
- getAvailableFuture() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartition
- getAvailableFuture() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- getAvailableFuture() - Method in class org.apache.flink.runtime.io.network.partition.SortMergeResultPartition
- getAvailableFuture() - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
- getAvailableFuture() - Method in class org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput
- getAvailableFuture() - Method in class org.apache.flink.streaming.api.operators.sort.SortingDataInput
- getAvailableFuture() - Method in class org.apache.flink.streaming.api.operators.SourceOperator
- getAvailableFuture() - Method in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
- getAvailableFuture() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
- getAvailableFuture() - Method in class org.apache.flink.streaming.runtime.io.MultipleFuturesAvailabilityHelper
- getAvailableFuture() - Method in class org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessor
- getAvailableFuture() - Method in class org.apache.flink.streaming.runtime.io.StreamOneInputProcessor
- getAvailableFuture() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskExternallyInducedSourceInput
- getAvailableFuture() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
- getAvailableFuture() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskFinishedOnRestoreSourceInput
- getAvailableJobDetails() - Method in interface org.apache.flink.runtime.dispatcher.ExecutionGraphInfoStore
-
Return the collection of
JobDetailsof all currently stored jobs. - getAvailableJobDetails() - Method in class org.apache.flink.runtime.dispatcher.FileExecutionGraphInfoStore
- getAvailableJobDetails() - Method in class org.apache.flink.runtime.dispatcher.MemoryExecutionGraphInfoStore
- getAvailableJobDetails(JobID) - Method in interface org.apache.flink.runtime.dispatcher.ExecutionGraphInfoStore
-
Return the
JobDetails} for the given job. - getAvailableJobDetails(JobID) - Method in class org.apache.flink.runtime.dispatcher.FileExecutionGraphInfoStore
- getAvailableJobDetails(JobID) - Method in class org.apache.flink.runtime.dispatcher.MemoryExecutionGraphInfoStore
- getAvailableMemory() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
- getAvailableResource() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerRegistration
- getAvailableResource() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerInfo
-
Get the available resource.
- getAvailableSlots() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultFreeSlotTracker
- getAvailableSlots() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.FreeSlotTracker
-
Get allocation id of all available slots.
- getAvailableVertexParallelism() - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- getAverage() - Method in class org.apache.flink.runtime.checkpoint.StatsSummary
-
Calculates the average over all seen values.
- getAverage() - Method in class org.apache.flink.runtime.checkpoint.StatsSummarySnapshot
-
Calculates the average over all seen values.
- getAverage() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.StatsSummaryDto
- getAverageBuffersPerRequester() - Method in class org.apache.flink.runtime.io.disk.BatchShuffleReadBufferPool
- getAvg() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
- getBackendIdentifier() - Method in class org.apache.flink.runtime.state.AbstractIncrementalStateHandle
- getBackendIdentifier() - Method in interface org.apache.flink.runtime.state.IncrementalKeyedStateHandle
-
Returns the identifier of the state backend from which this handle was created.
- getBackendStateType() - Method in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
- getBacklog() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyPayloadManager
- getBacklog() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartitionView.AvailabilityWithBacklog
- getBackoffTime() - Method in class org.apache.flink.runtime.executiongraph.failover.ExponentialDelayRestartBackoffTimeStrategy
- getBackoffTime() - Method in class org.apache.flink.runtime.executiongraph.failover.FailureRateRestartBackoffTimeStrategy
- getBackoffTime() - Method in class org.apache.flink.runtime.executiongraph.failover.FixedDelayRestartBackoffTimeStrategy
- getBackoffTime() - Method in enum org.apache.flink.runtime.executiongraph.failover.NoRestartBackoffTimeStrategy
- getBackoffTime() - Method in interface org.apache.flink.runtime.executiongraph.failover.RestartBackoffTimeStrategy
-
Returns the delay to do the restarting.
- getBackPressuredRatio() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
- getBackPressuredTimeMsPerSecond() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- getBackpressureLevel() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
- getBackpressureLevel() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
- getBackPressureRatio() - Method in class org.apache.flink.runtime.messages.TaskBackPressureResponse
- getBatchShuffleReadBufferPool() - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
- getBatchShuffleReadIOExecutor() - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
- getBinary() - Method in class org.apache.flink.runtime.scheduler.metrics.DeploymentStateTimeMetrics
- getBinary() - Method in interface org.apache.flink.runtime.scheduler.metrics.StateTimeMetric
-
Returns 1 if we are in the targeted state, otherwise 0.
- getBlobServer() - Method in class org.apache.flink.runtime.dispatcher.DispatcherServices
- getBlobServer() - Method in class org.apache.flink.runtime.dispatcher.PartialDispatcherServices
- getBlobServerHostname() - Method in class org.apache.flink.runtime.entrypoint.ClusterInformation
- getBlobServerPort() - Method in class org.apache.flink.runtime.entrypoint.ClusterInformation
- getBlobServerPort(Duration) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- getBlobServerPort(Duration) - Method in interface org.apache.flink.runtime.dispatcher.DispatcherGateway
-
Returns the port of the blob server.
- getBlobStorageDirectory() - Method in class org.apache.flink.runtime.entrypoint.WorkingDirectory
- getBlobWriter() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getBlobWriter() - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
- getBlobWriter() - Method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
- getBlockCount() - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
-
Gets the number of blocks written by this output view.
- getBlockCount() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
-
Gets the number of blocks used by this view.
- getBlockCount() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
Gets the number of blocks used by this view.
- getBlockCount() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
- getBlocked() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- getBlockedNodeRetriever() - Method in class org.apache.flink.runtime.resourcemanager.active.AbstractResourceManagerDriver
- getBlockingSubpartitionType() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- getBoundedness() - Method in class org.apache.flink.streaming.api.operators.SourceOperatorFactory
- getBoundedness() - Method in class org.apache.flink.streaming.api.transformations.LegacySourceTransformation
- getBoundedness() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
- getBoundedness() - Method in interface org.apache.flink.streaming.api.transformations.WithBoundedness
-
Returns the
Boundednessof thisTransformation. - getBroadcastGroupSize(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getBroadcastInput() - Method in class org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
- getBroadcastInputName(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getBroadcastInputSerializer(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getBroadcastState(MapStateDescriptor<K, V>) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
- getBroadcastState(MapStateDescriptor<K, V>) - Method in class org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction.Context
-
Fetches the
BroadcastStatewith the specified name. - getBroadcastState(MapStateDescriptor<K, V>) - Method in class org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction.ReadOnlyContext
-
Fetches a read-only view of the broadcast state with the specified name.
- getBroadcastStateDescriptors() - Method in class org.apache.flink.streaming.api.datastream.BroadcastStream
- getBroadcastStateDescriptors() - Method in class org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
- getBroadcastStateMetaInfoSnapshots() - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
- getBroadcastVariable(String) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
- getBroadcastVariable(String) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
- getBroadcastVariableManager() - Method in interface org.apache.flink.runtime.execution.Environment
- getBroadcastVariableManager() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
- getBroadcastVariableManager() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getBroadcastVariableWithInitializer(String, BroadcastVariableInitializer<T, C>) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
- getBroadcastVariableWithInitializer(String, BroadcastVariableInitializer<T, C>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
- getBrokerID(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getBuffer() - Method in class org.apache.flink.runtime.io.network.partition.BufferWithSubpartition
- getBuffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
- getBuffer() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyPayload
- getBufferAndIndexes() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.PartitionFileWriter.SegmentBufferContext
- getBufferConsumer() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumerWithPartialRecordLength
- getBufferDebloatThresholdPercentages() - Method in class org.apache.flink.runtime.throughput.BufferDebloatConfiguration
- getBufferedData() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
- getBufferIndex() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyPayload
- getBufferPool() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- getBufferPool() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemoryManager
-
Expose and get the internal
BufferPool. - getBufferPool() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemoryManagerImpl
- getBufferPool() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- getBufferProvider() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- getBuffersInBacklogUnsafe() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartition
-
Gets the number of non-event buffers in this subpartition.
- getBufferSize() - Method in class org.apache.flink.runtime.io.disk.BatchShuffleReadBufferPool
- getBufferTimeout() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the maximum time frequency (milliseconds) for the flushing of the output buffers.
- getBufferTimeout() - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
- getBufferTimeout() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
- getBufferTimeout() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getBuildSideBlockCount() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
- getBuildSideChannel() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
- getBuildSideComparator() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
- getBuildSideIterator() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
- getBuildSideRecordCount() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
- getBuildSideSerializer() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
- getBuildTime() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
- getBuildTimeString() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
- getBusyRatio() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
- getByteBufLength() - Static method in class org.apache.flink.runtime.executiongraph.ExecutionAttemptID
- getByteBufLength() - Static method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
- getByteBufLength() - Static method in class org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
- getByteBufLength(ResultSubpartitionIndexSet) - Static method in class org.apache.flink.runtime.io.network.partition.ResultSubpartitionIndexSet
- getBytes() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageBytesBasedDataIdentifier
- getBytes() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionID
- getBytes(int, byte[], int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- getBytes(int, OutputStream, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- getBytes(int, ByteBuffer) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- getBytes(int, FileChannel, long, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- getBytes(int, GatheringByteChannel, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- getBytes(int, ByteBuf, int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- getBytesInLatestSegment() - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
-
Gets the number of bytes written in the latest memory segment.
- getBytesMemoryUsed() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
Gets the number of bytes used by this output view, including written bytes and header bytes.
- getBytesPersistedDuringAlignment() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
- getBytesPersistedOfThisCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
- getBytesPersistedOfThisCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetricsBuilder
- getBytesProcessedDuringAlignment() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
- getBytesProcessedDuringAlignment() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetricsBuilder
- getBytesRead() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- getBytesWritten() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
Gets the number of pay-load bytes already written.
- getBytesWritten() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- getCachedFiles() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Get the list of cached files that were registered for distribution among the task managers.
- getCachedShuffleDescriptors(ConsumedPartitionGroup) - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
- getCacheSize() - Method in class org.apache.flink.runtime.query.KvStateEntry
- getCancelables() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- getCancelStreamRegistry() - Method in class org.apache.flink.runtime.state.KeyedStateBackendParametersImpl
- getCancelStreamRegistry() - Method in class org.apache.flink.runtime.state.OperatorStateBackendParametersImpl
- getCancelStreamRegistry() - Method in interface org.apache.flink.runtime.state.StateBackend.KeyedStateBackendParameters
- getCancelStreamRegistry() - Method in interface org.apache.flink.runtime.state.StateBackend.OperatorStateBackendParameters
- getCancelTask() - Method in class org.apache.flink.runtime.executiongraph.TaskExecutionStateTransition
- getCanEmitBatchOfRecords() - Method in class org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
- getCanEmitBatchOfRecords() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- getCanEmitBatchOfRecords() - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
- getCapacity() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
Gets the total capacity of this hash table, in bytes.
- getCapacity() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
- getCapacity() - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Gets the total capacity of this sorter, in bytes.
- getCapacity() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.MetricDump.CounterDump
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.MetricDump.GaugeDump
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.MetricDump
-
Returns the category for this MetricDump.
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.MetricDump.MeterDump
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
-
Returns the category for this QueryScopeInfo.
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobManagerOperatorQueryScopeInfo
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobManagerQueryScopeInfo
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobQueryScopeInfo
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskManagerQueryScopeInfo
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
- getCause() - Method in class org.apache.flink.runtime.blocklist.BlockedNode
- getCause() - Method in class org.apache.flink.runtime.io.network.netty.ConnectionErrorMessage
- getChainedOutputs(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getChainedSource(StreamConfig.SourceInputConfig) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- getChainedSourceOutputs() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- getChainedStubConfig(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getChainedTask(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getChainedTaskName(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getChainIndex() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getChainingStrategy() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
- getChainingStrategy() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
-
Get the chaining strategy of operator factory.
- getChainingStrategy() - Method in class org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
- getChainingStrategy() - Method in class org.apache.flink.streaming.api.transformations.ReduceTransformation
- getChainingStrategy() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
- getChainingStrategy() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
- getChainingStrategy() - Method in class org.apache.flink.streaming.api.transformations.TimestampsAndWatermarksTransformation
- getChainLength() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getChange() - Method in class org.apache.flink.runtime.state.changelog.StateChange
- getChangelogBusyTimeMsPerSecond() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- getChangelogStateBackendHandle(KeyedStateHandle) - Static method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl
- getChangelogStorageName() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the changelog storage name for this ExecutionGraph.
- getChangelogStorageName() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
- getChangelogStorageName() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getChangelogStoragesByJobId(JobID) - Method in class org.apache.flink.runtime.state.TaskExecutorStateChangelogStoragesManager
- getChanges() - Method in class org.apache.flink.runtime.state.changelog.inmemory.InMemoryChangelogStateHandle
- getChanges(Handle) - Method in interface org.apache.flink.runtime.state.changelog.StateChangelogHandleReader
- getChanges(ChangelogStateHandleStreamImpl) - Method in class org.apache.flink.runtime.state.changelog.StateChangelogHandleStreamHandleReader
- getChannel() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractChannelReaderInputView
-
Get the underlying channel.
- getChannel() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
-
Get the underlying channel.
- getChannel() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
- getChannel(int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
Returns the channel of this gate.
- getChannel(int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- getChannel(int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
- getChannel(int) - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
- getChannel(int) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
- getChannelID() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
- getChannelID() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
-
Gets the channel ID of this I/O channel.
- getChannelIndex() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Returns the index of this channel within its
SingleInputGate. - getChannelInfo() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
- getChannelInfo() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Returns the info of this channel, which uniquely identifies the channel in respect to its operator instance.
- getChannelInfos() - Method in interface org.apache.flink.runtime.io.network.partition.consumer.CheckpointableInput
- getChannelInfos() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
Returns the channel infos of this gate.
- getChannelInfos() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
- getChannelInfos() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
- getChannelMapping(int) - Method in class org.apache.flink.runtime.checkpoint.InflightDataRescalingDescriptor
- getChannelSelector() - Method in class org.apache.flink.runtime.io.network.api.writer.ChannelSelectorRecordWriter
- getChannelStateCheckpointId() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartition
- getChannelStateExecutorFactory() - Method in interface org.apache.flink.runtime.execution.Environment
- getChannelStateExecutorFactory() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getChannelStateWriter() - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
- getCheckpointAlignment() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
- getCheckpointBarrierHandler() - Method in class org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
- getCheckpointBarrierHandler() - Method in class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
- getCheckpointBarrierHandler() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Acquires the optional
CheckpointBarrierHandlerassociated with this stream task. - getCheckpointBarrierHandler() - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
- getCheckpointById(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
- getCheckpointCacheExpireAfterWrite() - Method in class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
- getCheckpointCacheSize() - Method in class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
- getCheckpointCommittablesUpTo(long) - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
-
Returns all
CheckpointCommittableManageruntil the requested checkpoint id. - getCheckpointConfig() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the checkpoint config, which defines values like checkpoint interval, delay between checkpoints, etc.
- getCheckpointConfig() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getCheckpointCoordinator() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getCheckpointCoordinator() - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- getCheckpointCoordinator() - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator.Context
-
Gets the checkpoint coordinator of this job.
- getCheckpointCoordinatorConfiguration() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the
CheckpointCoordinatorConfigurationornullif checkpointing is disabled. - getCheckpointCoordinatorConfiguration() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
- getCheckpointCoordinatorConfiguration() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getCheckpointCoordinatorConfiguration() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
- getCheckpointDirectory() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
- getCheckpointDirectory(long) - Method in class org.apache.flink.runtime.state.ChangelogTaskLocalStateStore
- getCheckpointDirectory(long) - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
- getCheckpointDirectoryForJob(Path, JobID) - Static method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorageAccess
-
Builds directory into which a specific job checkpoints, meaning the directory inside which it creates the checkpoint-specific subdirectories.
- getCheckpointDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
- getCheckpointDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
- getCheckpointedSize() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the checkpointed size during that checkpoint.
- getCheckpointedSize() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
- getCheckpointedSize() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummarySnapshot
- getCheckpointedSize() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- getCheckpointedSize() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
- getCheckpointedSize() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
- getCheckpointedSize() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- getCheckpointedSize() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
Deprecated.
- getCheckpointedSize() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
-
Returns the incremental state size.
- getCheckpointedSize() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getCheckpointedSize() - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
- getCheckpointedSize() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
- getCheckpointedSize() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
- getCheckpointedSize() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- getCheckpointedSize() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
- getCheckpointedSize() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
- getCheckpointedSize() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
- getCheckpointedSize() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl
- getCheckpointedSize() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendLocalHandle
- getCheckpointedSize() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateHandleStreamImpl
- getCheckpointedSize() - Method in class org.apache.flink.runtime.state.changelog.inmemory.InMemoryChangelogStateHandle
- getCheckpointedSize() - Method in interface org.apache.flink.runtime.state.CompositeStateHandle
-
Returns the persisted data size during checkpoint execution in bytes.
- getCheckpointedSize() - Method in class org.apache.flink.runtime.state.filemerging.FileMergingOperatorStreamStateHandle
- getCheckpointedSize() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
- getCheckpointedSize() - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
- getCheckpointedSize() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
- getCheckpointedSubpartitionInfo(int) - Method in interface org.apache.flink.runtime.io.network.partition.CheckpointedResultPartition
-
Gets the checkpointed subpartition info with the given subpartitionIndex.
- getCheckpointedSubpartitionInfo(int) - Method in class org.apache.flink.runtime.io.network.partition.PipelinedResultPartition
- getCheckpointFailureReason() - Method in exception org.apache.flink.runtime.checkpoint.CheckpointException
- getCheckpointFailureReason() - Method in class org.apache.flink.runtime.messages.checkpoint.SerializedCheckpointException
- getCheckpointHistorySize() - Method in class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
- getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the ID of this checkpoint.
- getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetaData
- getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.metadata.CheckpointMetadata
- getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
-
Returns the ID of this checkpoint.
- getCheckpointId() - Method in class org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
- getCheckpointId() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
- getCheckpointId() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointInfo
- getCheckpointId() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
- getCheckpointId() - Method in class org.apache.flink.runtime.state.AbstractIncrementalStateHandle
- getCheckpointId() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl
- getCheckpointId() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendLocalHandle
- getCheckpointId() - Method in interface org.apache.flink.runtime.state.CheckpointBoundKeyedStateHandle
-
Returns the ID of the checkpoint for which the handle was created or used.
- getCheckpointId() - Method in interface org.apache.flink.runtime.state.ManagedSnapshotContext
-
Returns the ID of the checkpoint for which the snapshot is taken.
- getCheckpointId() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
- getCheckpointId() - Method in interface org.apache.flink.streaming.runtime.operators.sink.committables.CheckpointCommittableManager
-
Returns the checkpoint id in which the committables were created.
- getCheckpointID() - Method in interface org.apache.flink.runtime.checkpoint.Checkpoint
- getCheckpointID() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
- getCheckpointID() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
- getCheckpointIdCounterPath() - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
- getCheckpointIdOfIgnoredInFlightData() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
- getCheckpointIdOfIgnoredInFlightData() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
- getCheckpointIdOrEOI() - Method in interface org.apache.flink.streaming.api.connector.sink2.CommittableMessage
-
Returns the checkpoint id or EOI if this message belong to the final checkpoint or the batch commit.
- getCheckpointIdOrEOI() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableSummary
- getCheckpointIdOrEOI() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableWithLineage
- getCheckpointingConsistencyMode() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the checkpointing consistency mode (exactly-once vs. at-least-once).
- getCheckpointingConsistencyMode() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns the checkpointing consistency mode (exactly-once vs. at-least-once).
- getCheckpointingMode() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Deprecated.Use
CheckpointConfig.getCheckpointingConsistencyMode()instead. - getCheckpointingMode() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Deprecated.
- getCheckpointingSettings() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Gets the settings for asynchronous snapshots.
- getCheckpointingSettings() - Method in class org.apache.flink.runtime.scheduler.adaptive.JobGraphJobInformation
- getCheckpointInterval() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
- getCheckpointInterval() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the interval in which checkpoints are periodically scheduled.
- getCheckpointInterval() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns the checkpointing interval or -1 if checkpointing is disabled.
- getCheckpointIntervalDuringBacklog() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
- getCheckpointIntervalDuringBacklog() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the interval in which checkpoints are periodically scheduled during backlog.
- getCheckpointLock() - Method in interface org.apache.flink.streaming.api.functions.source.legacy.SourceFunction.SourceContext
-
Deprecated.Returns the checkpoint lock.
- getCheckpointMetrics() - Method in class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
- getCheckpointMode() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getCheckpointOptions() - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
- getCheckpointOutputStream() - Method in interface org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
-
Returns the encapsulated output stream.
- getCheckpointOutputStream() - Method in class org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryAndSecondaryStream
- getCheckpointOutputStream() - Method in class org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryStreamOnly
- getCheckpointPath() - Method in class org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
-
Deprecated.Gets the checkpoint base directory.
- getCheckpointPath() - Method in class org.apache.flink.runtime.state.storage.FileSystemCheckpointStorage
-
Gets the base directory where all the checkpoints are stored.
- getCheckpointPath() - Method in class org.apache.flink.runtime.state.storage.JobManagerCheckpointStorage
- getCheckpointPlan() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
- getCheckpointProperties() - Method in class org.apache.flink.runtime.checkpoint.metadata.CheckpointMetadata
- getCheckpointRecoveryFactory() - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
- getCheckpointRecoveryFactory() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the checkpoint recovery factory for the job manager.
- getCheckpointRecoveryFactory() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
- getCheckpointRecoveryFactory() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServicesWithLeadershipControl
- getCheckpointResponder() - Method in interface org.apache.flink.runtime.taskexecutor.JobTable.Connection
- getCheckpointRetentionPolicy() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
- getCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
- getCheckpointStartDelay() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
- getCheckpointStartDelay() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
- getCheckpointStartDelayNanos() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
- getCheckpointStartDelayNanos() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetricsBuilder
- getCheckpointStartDelayNanos() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
- getCheckpointStartDelayStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
- getCheckpointStatisticsPerTask() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- getCheckpointStatsSnapshot() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns a snapshot of the checkpoint statistics or
nullif checkpointing is disabled. - getCheckpointStatsSnapshot() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
- getCheckpointStatsSnapshot() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getCheckpointStatus() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics
- getCheckpointStatus() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
- getCheckpointStatus(AsynchronousJobOperationKey) - Method in class org.apache.flink.runtime.dispatcher.DispatcherCachedOperationsHandler
- getCheckpointStorage() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
- getCheckpointStorage() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getCheckpointStorage() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- getCheckpointStorage() - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
- getCheckpointStorage(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getCheckpointStorageAccess() - Method in interface org.apache.flink.runtime.execution.Environment
- getCheckpointStorageAccess() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getCheckpointStorageLocation() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
- getCheckpointStorageName() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the checkpoint storage name for this ExecutionGraph.
- getCheckpointStorageName() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
- getCheckpointStorageName() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getCheckpointStore() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
- getCheckpointTimeout() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
- getCheckpointTimeout() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
- getCheckpointTimeout() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the maximum time that a checkpoint may take before being discarded.
- getCheckpointTimestamp() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
- getCheckpointTimestamp() - Method in interface org.apache.flink.runtime.state.ManagedSnapshotContext
-
Returns timestamp (wall clock time) when the master node triggered the checkpoint for which the state snapshot is taken.
- getCheckpointTimestamp() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
- getCheckpointTriggerCache() - Method in class org.apache.flink.runtime.dispatcher.DispatcherOperationCaches
- getCheckpointType() - Method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
-
Returns the type of checkpoint to perform.
- getCheckpointType() - Method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
-
Gets the type of the checkpoint (checkpoint / savepoint).
- getCheckpointType() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- getCheckpointType() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointTriggerRequestBody
- getChildren() - Method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexFlameGraph.Node
- getClassLoader() - Method in class org.apache.flink.runtime.executiongraph.SimpleInitializeOnMasterContext
- getClassLoader() - Method in interface org.apache.flink.runtime.jobgraph.JobVertex.FinalizeOnMasterContext
-
The class loader for user defined code.
- getClassLoader() - Method in interface org.apache.flink.runtime.jobgraph.JobVertex.InitializeOnMasterContext
-
The class loader for user defined code.
- getClassLoaderHandle() - Method in interface org.apache.flink.runtime.taskexecutor.JobTable.Connection
- getClassLoaderHandle() - Method in interface org.apache.flink.runtime.taskexecutor.JobTable.JobServices
-
Gets the
LibraryCacheManager.ClassLoaderHandlefor the associated job. - getClassLoaderResolveOrder() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
- getClasspaths() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
- getClientChannelHandlers() - Method in class org.apache.flink.runtime.io.network.netty.NettyProtocol
-
Returns the client channel handlers.
- getClientConnectTimeoutSeconds() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
- getClientNumThreads() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
- getClock() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
- getClock() - Method in interface org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
-
Returns
Clockassociated with this timer service. - getClock() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
- getCloseFuture() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- getClusterHighAvailableStoragePath(Configuration) - Static method in class org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
-
Gets the cluster high available storage path from the provided configuration.
- getClusterInformation() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- getClusterInformation() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerProcessContext
- getClusterInformation() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
-
Gets the cluster information.
- getClusterPartitionReport() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorHeartbeatPayload
- getClusterPartitionShuffleDescriptors(IntermediateDataSetID) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getClusterPartitionShuffleDescriptors(IntermediateDataSetID) - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
-
Get the shuffle descriptors of the cluster partitions ordered by partition number.
- getClusterPartitionShuffleDescriptors(IntermediateDataSetID) - Method in interface org.apache.flink.runtime.io.network.partition.JobMasterPartitionTracker
-
Get the shuffle descriptors of the cluster partitions ordered by partition number.
- getClusterPartitionShuffleDescriptors(IntermediateDataSetID) - Method in class org.apache.flink.runtime.io.network.partition.JobMasterPartitionTrackerImpl
- getClusterPartitionShuffleDescriptors(IntermediateDataSetID) - Method in interface org.apache.flink.runtime.io.network.partition.ResourceManagerPartitionTracker
-
Returns all the shuffle descriptors of cluster partitions for the intermediate dataset.
- getClusterPartitionShuffleDescriptors(IntermediateDataSetID) - Method in class org.apache.flink.runtime.io.network.partition.ResourceManagerPartitionTrackerImpl
- getClusterPartitionsShuffleDescriptors(IntermediateDataSetID) - Method in interface org.apache.flink.runtime.io.network.partition.ClusterPartitionManager
-
Get the shuffle descriptors of the cluster partitions ordered by partition number.
- getClusterPartitionsShuffleDescriptors(IntermediateDataSetID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- getClusterRestEndpointLeaderElection() - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
- getClusterRestEndpointLeaderElection() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the
LeaderElectionfor the cluster's rest endpoint. - getClusterRestEndpointLeaderElection() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
- getClusterRestEndpointLeaderElection() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
- getClusterRestEndpointLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
- getClusterRestEndpointLeaderRetriever() - Method in interface org.apache.flink.runtime.highavailability.ClientHighAvailabilityServices
-
Get the leader retriever for the cluster's rest endpoint.
- getClusterRestEndpointLeaderRetriever() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
- getClusterRestEndpointLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
- getClusterRestEndpointLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneClientHAServices
- getClusterRestEndpointLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
- getClusterRestEndpointLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperClientHAServices
- getCode() - Method in enum org.apache.flink.runtime.rest.messages.ProfilingInfo.ProfilingMode
- getCode() - Method in enum org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.BackendStateType
- getCollector() - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
- getCollector() - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
- getCollector() - Method in class org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
-
Deprecated.
- getCoLocationGroup() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- getCoLocationGroup() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- getCoLocationGroup() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getCoLocationGroups() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns all
CoLocationGroupinstances associated with thisJobGraph. - getCommitId() - Method in class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
- getCommittable() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableWithLineage
- getCommittable() - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
- getCommittedBytes() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
- getCommitterUidHash() - Method in class org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes
- getComparatorWithCurrentReference() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator
- getComparatorWithCurrentReference() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator
- getCompatibleVersions() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
- getCompatibleVersions() - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
- getCompatibleVersions() - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
- getCompletedCheckpointStatistics() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
- getCompletionFuture() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
Returns the completion future.
- getCompletionFuture() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
Deprecated.
- getCompletionFuture() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- getCompletionTimestamp() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
- getComponentMetricStore(HandlerRequest<EmptyRequestBody>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.AbstractMetricsHandler
-
Returns the
MetricStore.ComponentMetricStorethat should be queried for metrics. - getComponentMetricStore(HandlerRequest<EmptyRequestBody>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.JobManagerMetricsHandler
- getComponentMetricStore(HandlerRequest<EmptyRequestBody>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.JobManagerOperatorMetricsHandler
- getComponentMetricStore(HandlerRequest<EmptyRequestBody>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.JobMetricsHandler
- getComponentMetricStore(HandlerRequest<EmptyRequestBody>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.JobVertexMetricsHandler
-
Deprecated.
- getComponentMetricStore(HandlerRequest<EmptyRequestBody>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.SubtaskMetricsHandler
- getComponentMetricStore(HandlerRequest<EmptyRequestBody>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.TaskManagerMetricsHandler
- getCompressionCodec() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- getCompressionDecorator(ExecutionConfig) - Static method in class org.apache.flink.runtime.state.AbstractStateBackend
- getCompressor() - Method in class org.apache.flink.runtime.io.compression.AirCompressorFactory
- getCompressor() - Method in interface org.apache.flink.runtime.io.compression.BlockCompressionFactory
- getCompressor() - Method in class org.apache.flink.runtime.io.compression.Lz4BlockCompressionFactory
- getConcurrentExceptions() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.RootExceptionInfo
- getConcurrentExceptions() - Method in class org.apache.flink.runtime.scheduler.exceptionhistory.RootExceptionHistoryEntry
- getConcurrentlyFailedExecution() - Method in class org.apache.flink.runtime.scheduler.exceptionhistory.FailureHandlingResultSnapshot
-
All
Executionsthat failed and are planned to be restarted as part of this failure handling. - getConfig() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
- getConfig() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the config object.
- getConfigDir() - Method in class org.apache.flink.runtime.entrypoint.ClusterConfiguration
- getConfigDir() - Method in class org.apache.flink.runtime.entrypoint.ModifiableClusterConfiguration
- getConfiguration() - Method in class org.apache.flink.runtime.dispatcher.DispatcherServices
- getConfiguration() - Method in class org.apache.flink.runtime.dispatcher.PartialDispatcherServices
- getConfiguration() - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
- getConfiguration() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns the vertex's configuration object which can be used to pass custom settings to the task at runtime.
- getConfiguration() - Method in class org.apache.flink.runtime.jobmaster.JobMasterConfiguration
- getConfiguration() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- getConfiguration() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
- getConfiguration() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
Gets the configuration that holds the actual values encoded.
- getConfiguration() - Method in class org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
- getConfiguration() - Method in interface org.apache.flink.runtime.shuffle.ShuffleMasterContext
- getConfiguration() - Method in class org.apache.flink.runtime.shuffle.ShuffleMasterContextImpl
- getConfiguration() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
- getConfiguration() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
- getConfiguration() - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
-
Gets the configuration that the TaskManager was started with.
- getConfiguration() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gives read-only access to the underlying configuration of this environment.
- getConfiguration() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getConfiguration() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- getConfigurationWithoutResourceLimitationIfSet(Configuration) - Static method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManagerFactory
-
Get the configuration for standalone ResourceManager, overwrite invalid configs.
- getConnection(JobID) - Method in class org.apache.flink.runtime.taskexecutor.DefaultJobTable
- getConnection(JobID) - Method in interface org.apache.flink.runtime.taskexecutor.JobTable
-
Gets the connection registered under jobId.
- getConnection(ResourceID) - Method in class org.apache.flink.runtime.taskexecutor.DefaultJobTable
- getConnection(ResourceID) - Method in interface org.apache.flink.runtime.taskexecutor.JobTable
-
Gets the connection registered under resourceId.
- getConnectionId() - Method in class org.apache.flink.runtime.shuffle.NettyShuffleDescriptor
- getConnectionIndex() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
- getConnectionIndex() - Method in class org.apache.flink.runtime.io.network.ConnectionID
- getConnectionIndex() - Method in enum org.apache.flink.runtime.shuffle.NettyShuffleDescriptor.LocalExecutionPartitionConnectionInfo
- getConnectionIndex() - Method in class org.apache.flink.runtime.shuffle.NettyShuffleDescriptor.NetworkPartitionConnectionInfo
- getConnectionIndex() - Method in interface org.apache.flink.runtime.shuffle.NettyShuffleDescriptor.PartitionConnectionInfo
- getConnectionInformationPath() - Method in class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalDriver
- getConnectionManager() - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
- getConnectionTimeout() - Method in class org.apache.flink.runtime.rest.RestClientConfiguration
-
{@see RestOptions#CONNECTION_TIMEOUT}.
- getConsumeClusterDatasetId() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getConsumedPartitionGroup() - Method in class org.apache.flink.runtime.scheduler.strategy.ConsumerVertexGroup
- getConsumedPartitionGroup(int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getConsumedPartitionGroups() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
- getConsumedPartitionGroups() - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingExecutionVertex
-
Gets the
ConsumedPartitionGroups. - getConsumedPartitionGroups() - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingResultPartition
-
Gets the
ConsumedPartitionGroups this partition belongs to. - getConsumedPartitionGroups(ExecutionVertexID) - Method in class org.apache.flink.runtime.scheduler.ExecutionGraphToInputsLocationsRetrieverAdapter
- getConsumedPartitionGroups(ExecutionVertexID) - Method in interface org.apache.flink.runtime.scheduler.InputsLocationsRetriever
-
Get the consumed result partition groups of an execution vertex.
- getConsumedPartitionGroupsById(IntermediateResultPartitionID) - Method in class org.apache.flink.runtime.executiongraph.EdgeManager
- getConsumedPartitionGroupsForVertex(ExecutionVertexID) - Method in class org.apache.flink.runtime.executiongraph.EdgeManager
- getConsumedPartitionShuffleDescriptor(IntermediateResultPartition, TaskDeploymentDescriptorFactory.PartitionLocationConstraint, boolean) - Static method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory
- getConsumedPartitionType() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
-
Returns the type of this input channel's consumed result partition.
- getConsumedPartitionType() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
Returns the type of this input channel's consumed result partition.
- getConsumedResultId() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
- getConsumedResultID() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGateID
- getConsumedResults() - Method in class org.apache.flink.runtime.jobgraph.topology.DefaultLogicalVertex
- getConsumedResults() - Method in interface org.apache.flink.runtime.topology.Vertex
- getConsumedSubpartitionIndex() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
- getConsumedSubpartitionIndexRange() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
-
Return the index range of the consumed subpartitions.
- getConsumedSubpartitionIndexSet() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
- getConsumerAgentMemorySpec() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskTierFactory
- getConsumerAgentMemorySpec() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory.MemoryTierFactory
- getConsumerAgentMemorySpec() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierFactory
- getConsumerAgentMemorySpec() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierFactory
-
Get the
TieredStorageMemorySpecof the consumer-side agent. - getConsumerExecutionState() - Method in interface org.apache.flink.runtime.io.network.partition.PartitionProducerStateProvider.ResponseHandle
- getConsumerID() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGateID
- getConsumerMaxParallelism() - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
- getConsumerParallelism() - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
- getConsumers() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
- getConsumerVertexGroup() - Method in class org.apache.flink.runtime.scheduler.strategy.ConsumedPartitionGroup
- getConsumerVertexGroups() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
- getConsumerVertexGroups() - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingResultPartition
-
Gets the
ConsumerVertexGroups. - getConsumerVertexGroupsForPartition(IntermediateResultPartitionID) - Method in class org.apache.flink.runtime.executiongraph.EdgeManager
- getConsumerVertices() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
- getConsumingDistributionPattern() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
- getContainedTypeSerializer() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
- getContainingTask() - Method in class org.apache.flink.runtime.operators.BatchTask
- getContainingTask() - Method in interface org.apache.flink.runtime.operators.TaskContext
- getContainingTask() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- getContainingTask() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorParameters
- getContentType() - Method in class org.apache.flink.runtime.rest.FileUpload
- getConvergenceCriterion(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getConvergenceCriterionAggregatorName() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getCoordinator(OperatorCoordinator.Context) - Method in class org.apache.flink.runtime.operators.coordination.RecreateOnResetOperatorCoordinator.Provider
- getCoordinator(OperatorCoordinator.Context) - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinatorProvider
- getCoordinatorExecutor() - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinator
- getCoordinatorListeningID() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
- getCoordinatorProvider(String, OperatorID) - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getCoordinatorProvider(String, OperatorID) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorFactory
- getCoordinatorProvider(String, OperatorID) - Method in interface org.apache.flink.streaming.api.operators.CoordinatedOperatorFactory
-
Get the operator coordinator provider for this operator.
- getCoordinatorProvider(String, OperatorID) - Method in class org.apache.flink.streaming.api.operators.SourceOperatorFactory
- getCoordinatorState() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- getCoordinatorStore() - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator.Context
-
Gets the
CoordinatorStoreinstance for sharing information betweenOperatorCoordinators. - getCorruptedClusterDatasetIds() - Method in exception org.apache.flink.runtime.scheduler.ClusterDatasetCorruptedException
- getCount() - Method in class org.apache.flink.runtime.checkpoint.StatsSummary
-
Returns the count of all seen values.
- getCount() - Method in class org.apache.flink.runtime.checkpoint.StatsSummarySnapshot
-
Returns the count of all seen values.
- getCount() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogram
- getCount() - Method in class org.apache.flink.runtime.metrics.ThresholdMeter
- getCount() - Method in class org.apache.flink.runtime.metrics.TimerGauge
- getCounts() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
-
Returns the snapshotted checkpoint counts.
- getCounts() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
- getCpu() - Method in class org.apache.flink.runtime.rest.messages.ResourceProfileInfo
- getCpuCores() - Method in class org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
- getCpuCores() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the cpu cores needed.
- getCpuCores() - Method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec
- getCpuCores() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorResourceSpec
- getCpuCoresWithFallback(Configuration, double) - Static method in class org.apache.flink.runtime.clusterframework.TaskExecutorProcessUtils
- getCpuCoresWithFallbackConfigOption(Configuration, ConfigOption<Double>) - Static method in class org.apache.flink.runtime.clusterframework.TaskExecutorProcessUtils
- getCpuIdle() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
- getCpuIrq() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
- getCpuLoad1() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
- getCpuLoad15() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
- getCpuLoad5() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
- getCpuNice() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
- getCpuSoftIrq() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
- getCpuSteal() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
- getCpuSys() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
- getCpuUsage() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
- getCpuUsagePerProcessor(int) - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
- getCpuUser() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
- getCreateTimestamp() - Method in class org.apache.flink.runtime.io.network.netty.NettyPartitionRequestListener
- getCreateTimestamp() - Method in interface org.apache.flink.runtime.io.network.partition.PartitionRequestListener
-
The creation timestamp of this notifier, it's used to check whether the notifier is timeout.
- getCurrent() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.ProbeIterator
- getCurrent() - Method in interface org.apache.flink.runtime.util.KeyGroupedIterator
- getCurrent() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator
- getCurrent() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator
- getCurrentAllocation(int) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Get the current allocation for the task slot with the given index.
- getCurrentAllocation(int) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- getCurrentAssignedResource() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getCurrentAssignedResourceLocation() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
Returns the
TaskManagerLocationfor this execution vertex. - getCurrentAssignedResourceLocation() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
- getCurrentAssignedResourceLocation() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getCurrentAttempts() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails.CurrentAttempts
- getCurrentBackoff() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Returns the current backoff in ms.
- getCurrentBufferOffset() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.ProducerMergedPartitionFileReader.ProducerMergedReadProgress
- getCurrentConfiguration() - Method in class org.apache.flink.runtime.security.modules.JaasModule
- getCurrentExecution(int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getCurrentExecution(int) - Method in class org.apache.flink.runtime.executiongraph.SpeculativeExecutionVertex
- getCurrentExecutionAttempt() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
Returns the current execution for this execution vertex.
- getCurrentExecutionAttempt() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
- getCurrentExecutionAttempt() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getCurrentExecutionAttempt() - Method in class org.apache.flink.runtime.executiongraph.SpeculativeExecutionVertex
- getCurrentExecutionAttempts() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
- getCurrentExecutions() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
Returns the current executions for this execution vertex.
- getCurrentExecutions() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
- getCurrentExecutions() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getCurrentExecutions() - Method in class org.apache.flink.runtime.executiongraph.SpeculativeExecutionVertex
- getCurrentIncompleteAndReset() - Method in class org.apache.flink.runtime.operators.coordination.util.IncompleteFuturesTracker
- getCurrentKey() - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperator
- getCurrentKey() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- getCurrentKey() - Method in interface org.apache.flink.runtime.state.InternalKeyContext
-
Used by states to access the current key.
- getCurrentKey() - Method in class org.apache.flink.runtime.state.InternalKeyContextImpl
- getCurrentKey() - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
- getCurrentKey() - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.OnTimerContext
-
Get the key of the firing timer.
- getCurrentKey() - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.ReadOnlyContext
-
Get key of the element being processed.
- getCurrentKey() - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.Context
-
Get key of the element being processed.
- getCurrentKey() - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.OnTimerContext
-
Get key of the firing timer.
- getCurrentKey() - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
-
Get key of the element being processed.
- getCurrentKey() - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction.OnTimerContext
-
Get key of the firing timer.
- getCurrentKey() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- getCurrentKey() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- getCurrentKey() - Method in interface org.apache.flink.streaming.api.operators.KeyContext
- getCurrentKey() - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
- getCurrentKey() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
- getCurrentKeyGroup() - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
-
Returns the key group that is currently being written.
- getCurrentKeyGroupIndex() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- getCurrentKeyGroupIndex() - Method in interface org.apache.flink.runtime.state.InternalKeyContext
-
Returns the key-group to which the current key belongs.
- getCurrentKeyGroupIndex() - Method in class org.apache.flink.runtime.state.InternalKeyContextImpl
- getCurrentNumberOfRetries() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.SocketClientSink
-
Deprecated.
- getCurrentNumberOfSubtasks() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the current number of subtasks the respective task is split into.
- getCurrentOffset() - Method in class org.apache.flink.runtime.io.disk.SimpleCollectingOutputView
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.runtime.state.ArrayListSerializerSnapshot
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializerSnapshot
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerSnapshot
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializerSnapshot
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.streaming.api.operators.TimerSerializerSnapshot
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerSnapshot
- getCurrentPositionInSegment() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Gets the position from which the next byte will be read.
- getCurrentPositionInSegment() - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
Gets the current write position (the position where the next bytes will be written) in the current memory segment.
- getCurrentProbeRecord() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
- getCurrentProcessingContext() - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperatorV2
- getCurrentProcessingTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner.WindowAssignerContext
-
Returns the current processing time.
- getCurrentProcessingTime() - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor.EvictorContext
-
Returns the current processing time.
- getCurrentProcessingTime() - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Returns the current processing time.
- getCurrentProcessingTime() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
- getCurrentProcessingTime() - Method in interface org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
- getCurrentSegment() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Gets the memory segment that will be used to read the next bytes from.
- getCurrentSegment() - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
Gets the segment that the view currently writes to.
- getCurrentSegmentLimit() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Gets the current limit in the memory segment.
- getCurrentTaskManagerLocationFuture() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getCurrentTime() - Method in class org.apache.flink.runtime.scheduler.metrics.DeploymentStateTimeMetrics
- getCurrentTime() - Method in interface org.apache.flink.runtime.scheduler.metrics.StateTimeMetric
-
Returns the time, in milliseconds, that have elapsed since we transitioned to the targeted state.
- getCurrentTimeMetricName(String) - Static method in interface org.apache.flink.runtime.scheduler.metrics.StateTimeMetric
- getCurrentWatermark() - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor.EvictorContext
-
Returns the current watermark time.
- getCurrentWatermark() - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Returns the current watermark time.
- getCurrentWatermark() - Method in interface org.apache.flink.streaming.runtime.operators.util.WatermarkStrategyWithPeriodicWatermarks
-
Returns the current watermark.
- getCurrentWatermark() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
- getCustomHeaders() - Method in class org.apache.flink.runtime.rest.messages.CustomHeadersDecorator
-
Returns the custom headers added to the message.
- getCustomHeaders() - Method in interface org.apache.flink.runtime.rest.messages.MessageHeaders
-
Returns a collection of custom HTTP headers.
- getCustomInitializationMetrics() - Method in class org.apache.flink.runtime.state.KeyedStateBackendParametersImpl
- getCustomInitializationMetrics() - Method in class org.apache.flink.runtime.state.OperatorStateBackendParametersImpl
- getCustomInitializationMetrics() - Method in interface org.apache.flink.runtime.state.StateBackend.KeyedStateBackendParameters
- getCustomInitializationMetrics() - Method in interface org.apache.flink.runtime.state.StateBackend.OperatorStateBackendParameters
- getData() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
- getDataFilePath() - Method in class org.apache.flink.runtime.io.network.partition.PartitionedFile
- getDataPort() - Method in class org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
- getDataPort() - Method in class org.apache.flink.runtime.resourcemanager.TaskExecutorRegistration
- getDataPort() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- getDataPort() - Method in class org.apache.flink.runtime.shuffle.ProducerDescriptor
- getDataPort() - Method in class org.apache.flink.runtime.taskmanager.UnresolvedTaskManagerLocation
- getDatasetId() - Method in class org.apache.flink.streaming.api.transformations.CacheTransformation
- getDataSetId() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetEntry
- getDataSetId() - Method in class org.apache.flink.runtime.taskexecutor.partition.ClusterPartitionReport.ClusterPartitionReportEntry
- getDataSetId() - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
- getDataSets() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetListResponseBody
- getDataType() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Gets the type of data this buffer represents.
- getDataType() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
Gets the data type of the internal buffer.
- getDataType() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
- getDataType() - Method in class org.apache.flink.runtime.io.network.buffer.BufferHeader
- getDataType() - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- getDataType() - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- getDataType() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- getDataType() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- getDataType(AbstractEvent, boolean) - Static method in enum org.apache.flink.runtime.io.network.buffer.Buffer.DataType
- getDataVolumePerTask() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DefaultVertexParallelismAndInputInfosDecider
- getDataVolumePerTask() - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.VertexParallelismAndInputInfosDecider
-
Get the average size of data volume to expect each task instance to process.
- getDebloatConfiguration() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- getDeclarativeSlotPool() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolService
- getDeclareNeededResourceDelay() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
- getDecompressor() - Method in class org.apache.flink.runtime.io.compression.AirCompressorFactory
- getDecompressor() - Method in interface org.apache.flink.runtime.io.compression.BlockCompressionFactory
- getDecompressor() - Method in class org.apache.flink.runtime.io.compression.Lz4BlockCompressionFactory
- getDecorated() - Method in class org.apache.flink.runtime.rest.messages.CustomHeadersDecorator
- getDefault() - Static method in class org.apache.flink.runtime.state.CheckpointStorageLocationReference
- getDefaultAcl() - Method in class org.apache.flink.runtime.util.ZooKeeperUtils.SecureAclProvider
- getDefaultBufferTimeout() - Method in interface org.apache.flink.streaming.api.graph.TransformationTranslator.Context
-
Returns the default buffer timeout to be used.
- getDefaultCheckpointStorage() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
- getDefaultKerberosInitAppEntryName() - Static method in class org.apache.flink.runtime.security.KerberosUtils
- getDefaultLocalParallelism() - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the default parallelism that will be used for the local execution environment created by
StreamExecutionEnvironment.createLocalEnvironment(). - getDefaultMaxParallelism(JobVertex) - Static method in class org.apache.flink.runtime.scheduler.SchedulerBase
-
Get a default value to use for a given vertex's max parallelism if none was specified.
- getDefaultMimeType() - Static method in class org.apache.flink.runtime.rest.handler.util.MimeTypes
-
Gets the default MIME type, which is
"application/octet-stream". - getDefaultNumSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerRegistration
- getDefaultNumSlots() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerInfo
-
Get the default number of slots.
- getDefaultSavepointDirectory() - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorageAccess
-
Gets the default directory for savepoints.
- getDefaultSavepointDirectory() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the default savepoint directory for this Job.
- getDefaultSlotResourceProfile() - Method in class org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
- getDefaultSlotResourceProfile() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerRegistration
- getDefaultSlotResourceProfile() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingTaskManager
- getDefaultSlotResourceProfile() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerInfo
-
Get the default slot resource profile.
- getDefaultSlotResourceProfile() - Method in class org.apache.flink.runtime.resourcemanager.TaskExecutorRegistration
- getDefaultSlotResourceProfile() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
- getDefaultStateBackend() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
- getDefaultTrigger() - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
- getDefaultTrigger() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
- getDefaultTrigger() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
- getDefaultTrigger() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
- getDefaultTrigger() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
- getDefaultTrigger() - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
-
Returns the default trigger associated with this
WindowAssigner. - getDefaultValue() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
- getDefaultWorkerResourceSpec() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
- getDelayBetweenSamples() - Method in class org.apache.flink.runtime.webmonitor.threadinfo.ThreadInfoSamplesRequest
-
Returns the configured delay between the individual samples.
- getDelegate() - Method in class org.apache.flink.runtime.state.AbstractChannelStateHandle
- getDelegatedKeyedStateBackend(boolean) - Method in interface org.apache.flink.runtime.state.TestableKeyedStateBackend
- getDelegatedStateBackend() - Method in interface org.apache.flink.runtime.state.delegate.DelegatingStateBackend
- getDelegateStateHandle() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
- getDelegateStateHandle() - Method in interface org.apache.flink.runtime.state.OperatorStateHandle
-
Returns the underlying stream state handle that points to the state data.
- getDelegateStateHandle() - Method in class org.apache.flink.runtime.state.OperatorStreamStateHandle
- getDelegationTokenManager() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerProcessContext
- getDelimiter() - Method in class org.apache.flink.runtime.metrics.groups.ReporterScopedSettings
- getDelimiter() - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
-
Returns the global delimiter.
- getDelimiter() - Method in class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
- getDelimiter() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
- getDelimiter() - Method in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
- getDelimiter() - Method in class org.apache.flink.runtime.metrics.ReporterSetup
- getDescription() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationTriggerMessageHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.AccumulatorsIncludeSerializedValueQueryParameter
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointIdPathParameter
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatusHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerLogListHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerProfilingHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerProfilingListHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerThreadDumpHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.CustomHeadersDecorator
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteStatusHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetIdPathParameter
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetListHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.FlameGraphTypeQueryParameter
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.coordination.ClientCoordinationHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.FailureLabelFilterParameter
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.JobManagerJobConfigurationHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.JobManagerJobEnvironmentHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.JobResourceRequirementsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.JobResourcesRequirementsUpdateHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.JobStatusInfoHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedJobMetricsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedSubtaskMetricsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedTaskManagerMetricsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerOperatorMetricsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobsFilterQueryParameter
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexMetricsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexWatermarksHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricsFilterParameter
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtasksFilterQueryParameter
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagersFilterQueryParameter
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskAttemptPathParameter
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.UpperLimitExceptionParameter
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobCancellationHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobClientHeartbeatHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobIDPathParameter
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobManagerEnvironmentHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobManagerLogUrlHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobVertexFlameGraphHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobVertexIdPathParameter
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.LogFileNamePathParameter
- getDescription() - Method in interface org.apache.flink.runtime.rest.messages.MessageHeaders
-
Returns the description for this header.
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Returns a description for REST API HTML documentation.
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.OperatorUidPathParameter
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.ProfilingFileNamePathParameter
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.RescalingParallelismQueryParameter
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.SubtaskIndexPathParameter
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.SubtaskIndexQueryParameter
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerIdPathParameter
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogsHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingListHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerThreadDumpHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.TaskManagerLogUrlHeaders
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.TriggerIdPathParameter
- getDirectMemoryStatsAsString(BufferPoolMXBean) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
-
Returns a String with the direct memory footprint.
- getDirectory() - Method in class org.apache.flink.runtime.state.DirectoryStateHandle
- getDirectory() - Method in class org.apache.flink.runtime.state.filemerging.DirectoryStreamStateHandle
- getDirectory() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
- getDirectoryStateHandle() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
- getDirtyResults() - Method in class org.apache.flink.runtime.highavailability.AbstractThreadsafeJobResultStore
- getDirtyResults() - Method in interface org.apache.flink.runtime.highavailability.JobResultStore
-
Get the persisted
JobResultinstances that are marked asdirty. - getDirtyResultsInternal() - Method in class org.apache.flink.runtime.highavailability.AbstractThreadsafeJobResultStore
- getDirtyResultsInternal() - Method in class org.apache.flink.runtime.highavailability.FileSystemJobResultStore
- getDirtyResultsInternal() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedJobResultStore
- getDiscardables() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- getDiscardables() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
- getDiskTierName() - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageUtils
- getDispatcherGateway() - Method in class org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess
- getDispatcherGateway() - Method in enum org.apache.flink.runtime.dispatcher.runner.StoppedDispatcherLeaderProcess
- getDispatcherGatewayFuture() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- getDispatcherLeaderElection() - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
- getDispatcherLeaderElection() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the
LeaderElectionfor the cluster's dispatcher. - getDispatcherLeaderElection() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
- getDispatcherLeaderElection() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
- getDispatcherLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
- getDispatcherLeaderRetriever() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the leader retriever for the dispatcher.
- getDispatcherLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
- getDispatcherLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
- getDispatcherNode() - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
- getDispatcherService() - Method in class org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess
- getDistributedCacheEntries() - Method in interface org.apache.flink.runtime.execution.Environment
- getDistributedCacheEntries() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getDistributionMode() - Method in class org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
- getDistributionPattern() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
- getDistributionPattern() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Returns the distribution pattern used for this edge.
- getDistributionPattern() - Method in class org.apache.flink.runtime.jobgraph.topology.DefaultLogicalEdge
- getDistributionPattern() - Method in interface org.apache.flink.runtime.jobgraph.topology.LogicalEdge
-
Returns the distribution pattern used for this edge.
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Gets the channel state rescaler used for rescaling persisted data on downstream side of this JobEdge.
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardForConsecutiveHashPartitioner
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardForUnspecifiedPartitioner
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
-
Defines the behavior of this partitioner, when downstream rescaled during recovery of in-flight data.
- getDriver() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getDriverClass() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
- getDriverComparator(int) - Method in class org.apache.flink.runtime.operators.BatchTask
- getDriverComparator(int) - Method in interface org.apache.flink.runtime.operators.TaskContext
- getDriverComparator(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getDriverStrategy() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getDuration() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.cluster.ProfilingRequestBody
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.ProfilingInfo
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
- getDurationMetrics() - Method in class org.apache.flink.runtime.checkpoint.SubTaskInitializationMetrics
- getDynamicProperties() - Method in class org.apache.flink.runtime.entrypoint.ClusterConfiguration
- getDynamicProperties() - Method in class org.apache.flink.runtime.entrypoint.ModifiableClusterConfiguration
- getDynamicPropertiesAsString(Configuration, Configuration) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Get dynamic properties based on two Flink configurations.
- getDynamicSlotID(ResourceID) - Static method in class org.apache.flink.runtime.clusterframework.types.SlotID
-
Get a SlotID without actual slot index for dynamic slot allocation.
- getEdgeManager() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getEdgeManager() - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
- getEdgeManager() - Method in class org.apache.flink.runtime.scheduler.adapter.DefaultExecutionTopology
- getEffectiveConfigurationForResourceManager(Configuration) - Method in class org.apache.flink.runtime.resourcemanager.active.ActiveResourceManagerFactory
- getEffectiveConfigurationForResourceManager(Configuration) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerFactory
-
Configuration changes in this method will be visible to only
ResourceManager. - getEffectiveResourceProfile(ResourceProfile, ResourceProfile) - Static method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerUtils
- getElement() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntry
- getElementOrder() - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperator
- getElementOrder() - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperatorV2
- getElementOrder() - Method in interface org.apache.flink.streaming.runtime.operators.asyncprocessing.AsyncStateProcessingOperator
-
Get the
ElementOrderof this operator. - getElementsCollectedAndReset() - Method in class org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
- getElementSerializer() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
- getElementSerializer() - Method in class org.apache.flink.runtime.state.RegisteredPriorityQueueStateBackendMetaInfo
- getEnd() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
Gets the end timestamp of this window.
- getEndIndex() - Method in class org.apache.flink.runtime.executiongraph.IndexRange
- getEndKeyGroup() - Method in class org.apache.flink.runtime.state.KeyGroupRange
- getEndOffsetExclusive() - Method in class org.apache.flink.runtime.state.BoundedInputStream
- getEndOfInputCommittable() - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
-
Returns
CheckpointCommittableManagerbelonging to the last input. - getEndOfRegionOffset() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.ProducerMergedPartitionFileReader.ProducerMergedReadProgress
- getEndpoint() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- getEndpoint() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.ExceptionInfo
- getEndpoint() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
- getEndpoint() - Method in class org.apache.flink.runtime.scheduler.exceptionhistory.ExceptionHistoryEntry.ArchivedTaskManagerLocation
- getEndpoint() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
Gets the endpoint of the TaskManager in the format of "$HOST:$PORT".
- getEndTime() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
- getEndTime() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getEndTime() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- getEndTime() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- getEndTime() - Method in interface org.apache.flink.runtime.webmonitor.stats.Statistics
-
Returns the timestamp when the last sample of this
Statisticswas collected. - getEndTime() - Method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexFlameGraph
- getEndTime() - Method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexThreadInfoStats
-
Returns the timestamp, when all samples where collected.
- getEndTimestamp() - Method in class org.apache.flink.runtime.blocklist.BlockedNode
- getEndTimestamp() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
- getEndToEndDuration() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the duration of this checkpoint calculated as the time since triggering until the latest acknowledged subtask or
-1if no subtask was acknowledged yet. - getEndToEndDuration() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
-
Returns the end to end duration until the checkpoint failure.
- getEndToEndDuration(long) - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
-
Computes the duration since the given trigger timestamp.
- getEndToEndDuration(long) - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
-
Returns the duration of this checkpoint at the task/operator calculated as the time since triggering until the latest acknowledged subtask or
-1if no subtask was acknowledged yet. - getEndToEndDurationStats() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummary
-
Returns the summary stats for the duration of completed checkpoints.
- getEndToEndDurationStats() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummarySnapshot
- getEndTs() - Method in class org.apache.flink.runtime.checkpoint.SubTaskInitializationMetrics
- getEntries() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.JobExceptionHistory
- getEntries() - Method in class org.apache.flink.runtime.taskexecutor.partition.ClusterPartitionReport
- getEntryIterator() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
- getEntryIterator() - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
- getEntryIterator() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
Returns an iterator that can be used to iterate over all the elements in the table.
- getEnumerator() - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinator
- getEnv() - Method in class org.apache.flink.runtime.state.KeyedStateBackendParametersImpl
- getEnv() - Method in class org.apache.flink.runtime.state.OperatorStateBackendParametersImpl
- getEnv() - Method in interface org.apache.flink.runtime.state.StateBackend.KeyedStateBackendParameters
- getEnv() - Method in interface org.apache.flink.runtime.state.StateBackend.OperatorStateBackendParameters
- getEnvironment() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the environment of this task.
- getEnvironment() - Method in class org.apache.flink.streaming.api.datastream.BroadcastStream
- getEnvironment() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- getEpoch() - Method in class org.apache.flink.runtime.asyncprocessing.RecordContext
- getError() - Method in class org.apache.flink.runtime.executiongraph.failover.FailureHandlingResult
-
Returns reason why the restarting cannot be conducted.
- getError() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyPayload
- getError(ClassLoader) - Method in class org.apache.flink.runtime.executiongraph.TaskExecutionStateTransition
- getError(ClassLoader) - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
Gets the attached exception, which is in serialized form.
- getErrorDelayMillis() - Method in class org.apache.flink.runtime.registration.RetryingRegistrationConfiguration
- getEstimatedNumberOfRequestedMemorySegments() - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
-
Estimates the number of requested buffers.
- getEstimatedNumberOfRequestedMemorySegments() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
- getEstimatedRequestedMemory() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
- getEstimatedRequestedSegmentsUsage() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
- getEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
- getEventPublisher() - Method in class org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
- getEventTimeTimers() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
- getEvictor() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
- getEvictor() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorFactory
- getException() - Method in class org.apache.flink.runtime.executiongraph.ErrorInfo
-
Returns the serialized form of the original exception.
- getExceptionAsString() - Method in class org.apache.flink.runtime.executiongraph.ErrorInfo
-
Returns the contained exception as a string.
- getExceptionHistory() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory
- getExceptionHistory() - Method in class org.apache.flink.runtime.scheduler.ExecutionGraphInfo
- getExceptionHistory() - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- getExceptionName() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.ExceptionInfo
- getExchangeMode() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
- getExchangeMode() - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
Returns the
StreamExchangeModeof thisPartitionTransformation. - getExcludedVariables() - Method in class org.apache.flink.runtime.metrics.groups.ReporterScopedSettings
- getExcludedVariables() - Method in class org.apache.flink.runtime.metrics.ReporterSetup
- getExclusiveCheckpointDir() - Method in class org.apache.flink.runtime.state.filesystem.FsCompletedCheckpointStorageLocation
- getExclusiveStateHandle() - Method in class org.apache.flink.runtime.state.filesystem.FsMergingCheckpointStorageLocation
- getExecutingCooldownTimeout() - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler.Settings
- getExecutingResourceStabilizationTimeout() - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler.Settings
- getExecutingThread() - Method in class org.apache.flink.runtime.taskmanager.Task
- getExecution() - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator.SubtaskGateway
-
Gets the execution attempt for the subtask execution attempt that this gateway communicates with.
- getExecutionAttemptId() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
- getExecutionAttemptId() - Method in class org.apache.flink.runtime.jobmaster.event.ExecutionVertexFinishedEvent
- getExecutionAttemptID() - Method in class org.apache.flink.runtime.accumulators.AccumulatorSnapshot
- getExecutionAttemptID() - Method in class org.apache.flink.runtime.messages.TaskBackPressureResponse
- getExecutionAttemptID() - Method in class org.apache.flink.runtime.shuffle.ShuffleIOOwnerContext
- getExecutionConfig() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the job specific
ExecutionConfig. - getExecutionConfig() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the global ExecutionConfig.
- getExecutionConfig() - Method in interface org.apache.flink.runtime.operators.TaskContext
- getExecutionConfig() - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
- getExecutionConfig() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getExecutionConfig() - Method in class org.apache.flink.streaming.api.datastream.DataStream
- getExecutionConfig() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getExecutionConfig() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Gets the execution config defined on the execution environment of the job to which this operator belongs.
- getExecutionConfig() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
Gets the execution config defined on the execution environment of the job to which this operator belongs.
- getExecutionConfig() - Method in interface org.apache.flink.streaming.runtime.tasks.ContainingTaskDetails
- getExecutionConfigInfo() - Method in class org.apache.flink.runtime.rest.messages.JobConfigInfo
- getExecutionDeploymentListener() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getExecutionDeploymentListener() - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
- getExecutionDeploymentReport() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorToJobManagerHeartbeatPayload
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
- getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Returns the
StreamExecutionEnvironmentthat was used to create thisDataStream. - getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
- getExecutionEnvironment() - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates an execution environment that represents the context in which the program is currently executed.
- getExecutionEnvironment(Configuration) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates an execution environment that represents the context in which the program is currently executed.
- getExecutionGraph() - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.BatchJobRecoveryContext
-
Provides the
ExecutionGraphassociated with the job. - getExecutionGraph() - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
-
ExecutionGraph is exposed to make it easier to rework tests to be based on the new scheduler.
- getExecutionGraph(JobID) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- getExecutionGraphAccessor() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getExecutionGraphID() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getExecutionGraphID() - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
- getExecutionGraphInfo() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunnerResult
- getExecutionGraphInfo(JobID, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.legacy.DefaultExecutionGraphCache
- getExecutionGraphInfo(JobID, RestfulGateway) - Method in interface org.apache.flink.runtime.rest.handler.legacy.ExecutionGraphCache
-
Gets the
ExecutionGraphInfofor the givenJobIDand caches it. - getExecutionHistory() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
Returns the execution history.
- getExecutionHistory() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
- getExecutionHistory() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getExecutionId() - Method in interface org.apache.flink.runtime.execution.Environment
-
Gets the ID of the task execution attempt.
- getExecutionId() - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotPayload
- getExecutionId() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getExecutionId() - Method in class org.apache.flink.runtime.taskmanager.Task
- getExecutionJobVertex(JobVertexID) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- getExecutionMode() - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler.Settings
- getExecutionParallelism() - Method in class org.apache.flink.runtime.executiongraph.SimpleInitializeOnMasterContext
- getExecutionParallelism() - Method in interface org.apache.flink.runtime.jobgraph.JobVertex.FinalizeOnMasterContext
-
The actual parallelism this vertex will be run with.
- getExecutionParallelism() - Method in interface org.apache.flink.runtime.jobgraph.JobVertex.InitializeOnMasterContext
-
The actual parallelism this vertex will be run with.
- getExecutionPlan() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates the plan with which the system will execute the program, and returns it as a String using a JSON representation of the execution data flow graph.
- getExecutions() - Method in class org.apache.flink.runtime.taskexecutor.ExecutionDeploymentReport
- getExecutionsOn(ResourceID) - Method in class org.apache.flink.runtime.jobmaster.DefaultExecutionDeploymentTracker
- getExecutionsOn(ResourceID) - Method in interface org.apache.flink.runtime.jobmaster.ExecutionDeploymentTracker
-
Returns all tracked executions for the given host.
- getExecutionState() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
Returns the current
ExecutionStatefor this execution vertex. - getExecutionState() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
- getExecutionState() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getExecutionState() - Method in class org.apache.flink.runtime.executiongraph.TaskExecutionStateTransition
- getExecutionState() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- getExecutionState() - Method in class org.apache.flink.runtime.taskmanager.Task
-
Returns the current execution state of the task.
- getExecutionState() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
Returns the new execution state of the task.
- getExecutionStateDuration(AccessExecution) - Static method in class org.apache.flink.runtime.rest.messages.job.StatusDurationUtils
- getExecutionVertex(ExecutionVertexID) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- getExecutionVertexId() - Method in class org.apache.flink.runtime.executiongraph.ExecutionAttemptID
- getExecutionVertexId() - Method in class org.apache.flink.runtime.jobmaster.event.ExecutionVertexFinishedEvent
- getExecutionVertexId() - Method in class org.apache.flink.runtime.scheduler.ExecutionVertexVersion
- getExecutionVertexIds() - Method in class org.apache.flink.runtime.jobmaster.event.ExecutionVertexResetEvent
- getExecutionVertexInputInfo(IntermediateDataSetID) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getExecutionVertexInputInfos() - Method in class org.apache.flink.runtime.executiongraph.JobVertexInputInfo
-
The input information of subtasks of this job vertex.
- getExecutionVertexOrThrow(ExecutionVertexID) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getExecutionVertexOrThrow(ExecutionVertexID) - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
- getExecutionVertexStats(JobID, AccessExecutionJobVertex, int) - Method in interface org.apache.flink.runtime.webmonitor.stats.VertexStatsTracker
-
Returns statistics for a execution vertex.
- getExecutionVertexStats(JobID, AccessExecutionJobVertex, int) - Method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexThreadInfoTracker
- getExecutionVertexVersion(ExecutionVertexID) - Method in class org.apache.flink.runtime.scheduler.ExecutionVertexVersioner
- getExecutionVertexVersions(Collection<ExecutionVertexID>) - Method in class org.apache.flink.runtime.scheduler.ExecutionVertexVersioner
- getExecutorService() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
- getExitCode() - Method in enum org.apache.flink.runtime.taskexecutor.TaskManagerRunner.Result
- getExpiredTimestamp() - Method in class org.apache.flink.runtime.rest.messages.JobClientHeartbeatRequestBody
- getExtendedResources() - Method in class org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
- getExtendedResources() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the extended resources.
- getExtendedResources() - Method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec
- getExtendedResources() - Method in class org.apache.flink.runtime.rest.messages.ResourceProfileInfo
- getExtendedResources() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorResourceSpec
- getExternalAddress() - Method in class org.apache.flink.runtime.taskmanager.UnresolvedTaskManagerLocation
- getExternalizedCheckpointRetention() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Returns the cleanup behaviour for externalized checkpoints.
- getExternalPath() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
-
Returns the external pointer of this checkpoint.
- getExternalPath() - Method in class org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
-
Returns the external path if this checkpoint was persisted externally.
- getExternalPath() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
- getExternalPath() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.CompletedCheckpointStatistics
- getExternalPointer() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
- getExternalPointer() - Method in interface org.apache.flink.runtime.state.CompletedCheckpointStorageLocation
-
Gets the external pointer to the checkpoint.
- getExternalPointer() - Method in class org.apache.flink.runtime.state.filesystem.FsCompletedCheckpointStorageLocation
- getExternalResourceConfigurationKeys(Configuration, String) - Static method in class org.apache.flink.runtime.externalresource.ExternalResourceUtils
-
Get the external resource configuration keys map, indexed by the resource name.
- getExternalResourceInfoProvider() - Method in interface org.apache.flink.runtime.execution.Environment
-
Get the
ExternalResourceInfoProviderwhich contains infos of available external resources. - getExternalResourceInfoProvider() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getExternalResourceInfos(String) - Method in interface org.apache.flink.runtime.externalresource.ExternalResourceInfoProvider
-
Get the specific external resource information by the resourceName.
- getExternalResourceInfos(String) - Method in class org.apache.flink.runtime.externalresource.StaticExternalResourceInfoProvider
- getExternalResourceInfos(String) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
- getExternalResourceInfos(String) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
- getExternalResourcesCollection(Configuration) - Static method in class org.apache.flink.runtime.externalresource.ExternalResourceUtils
-
Get the collection of all enabled external resources.
- getExternalSharedMemoryResource(String, LongFunctionWithException<T, Exception>, long) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Acquires a shared resource, identified by a type string.
- getExtra() - Method in class org.apache.flink.runtime.asyncprocessing.RecordContext
- getFactoryByJobId(JobID) - Method in class org.apache.flink.runtime.state.TaskExecutorChannelStateExecutorFactoryManager
- getFailedCheckpointStatistics() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
- getFailedExecution() - Method in class org.apache.flink.runtime.executiongraph.failover.FailureHandlingResult
-
Returns an
Optionalwith theExecutioncausing this failure or an emptyOptionalif it's a global failure. - getFailingTaskName() - Method in class org.apache.flink.runtime.scheduler.exceptionhistory.ExceptionHistoryEntry
- getFailoverRegion(ExecutionVertexID) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionFailoverStrategy
-
Returns the failover region that contains the given execution vertex.
- getFailureCause() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
- getFailureCause() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getFailureCause() - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- getFailureCause() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
- getFailureCause() - Method in class org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionDirectTransferReader
- getFailureCause() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.TieredStorageResultSubpartitionView
- getFailureCause() - Method in class org.apache.flink.runtime.io.network.partition.NoOpResultSubpartitionView
- getFailureCause() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartitionView
- getFailureCause() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- getFailureCause() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
-
ResultSubpartitionViewcan decide whether the failure cause should be reported to consumer as failure (primary failure) orProducerFailedException(secondary failure). - getFailureCause() - Method in class org.apache.flink.runtime.io.network.partition.UnionResultSubpartitionView
- getFailureCause() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationInfo
- getFailureCause() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointInfo
- getFailureCause() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointInfo
- getFailureCause() - Method in class org.apache.flink.runtime.taskmanager.Task
-
If the task has failed, this method gets the exception that caused this task to fail.
- getFailureEnrichers() - Method in class org.apache.flink.runtime.dispatcher.DispatcherServices
- getFailureEnrichers() - Method in class org.apache.flink.runtime.dispatcher.PartialDispatcherServices
- getFailureEnrichers(Configuration) - Static method in class org.apache.flink.runtime.failure.FailureEnricherUtils
-
Returns a set of validated FailureEnrichers for a given configuration.
- getFailureHandlingResult(Execution, Throwable, long) - Method in class org.apache.flink.runtime.executiongraph.failover.ExecutionFailureHandler
-
Return result of failure handling.
- getFailureInfo() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
Returns the exception that caused the job to fail.
- getFailureInfo() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the exception that caused the job to fail.
- getFailureInfo() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
Returns the exception that caused the job to fail.
- getFailureInfo() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
- getFailureInfo() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
- getFailureInfo() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
- getFailureInfo() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getFailureInfo() - Method in class org.apache.flink.runtime.executiongraph.Execution
- getFailureInfo() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getFailureLabels() - Method in class org.apache.flink.runtime.executiongraph.failover.FailureHandlingResult
-
Returns the labels future associated with the failure.
- getFailureLabels() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.ExceptionInfo
- getFailureLabels() - Method in class org.apache.flink.runtime.scheduler.exceptionhistory.ExceptionHistoryEntry
-
Returns the labels associated with the failure that is set as soon as failureLabelsFuture is completed.
- getFailureLabels() - Method in class org.apache.flink.runtime.scheduler.exceptionhistory.FailureHandlingResultSnapshot
-
Returns the labels future associated with the failure.
- getFailureLabelsFuture() - Method in class org.apache.flink.runtime.scheduler.exceptionhistory.ExceptionHistoryEntry
-
Returns the labels future associated with the failure.
- getFailureMessage() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
-
Returns the failure message or
nullif no cause was provided. - getFailureMessage() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.FailedCheckpointStatistics
- getFailureTimestamp() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
-
Returns the timestamp when this checkpoint failed.
- getFailureTimestamp() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.FailedCheckpointStatistics
- getFailureType() - Method in class org.apache.flink.runtime.failure.DefaultFailureEnricherContext
- getFatalErrorHandler() - Method in class org.apache.flink.runtime.dispatcher.DispatcherServices
- getFatalErrorHandler() - Method in class org.apache.flink.runtime.dispatcher.PartialDispatcherServices
- getFatalErrorHandler() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerProcessContext
- getFeatures() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
- getFeedbackEdges() - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
Returns the list of feedback
Transformations. - getFeedbackEdges() - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
Returns the list of feedback
Transformations. - getField(TtlValue<T>, int) - Method in class org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
- getFieldType() - Method in class org.apache.flink.streaming.util.typeutils.FieldAccessor
-
Gets the TypeInformation for the type of the field.
- getFile() - Method in class org.apache.flink.runtime.rest.FileUpload
- getFile(JobID, PermanentBlobKey) - Method in class org.apache.flink.runtime.blob.BlobServer
-
Returns the path to a local copy of the file associated with the provided job ID and blob key.
- getFile(JobID, PermanentBlobKey) - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
-
Returns the path to a local copy of the file associated with the provided job ID and blob key.
- getFile(JobID, PermanentBlobKey) - Method in interface org.apache.flink.runtime.blob.PermanentBlobService
-
Returns the path to a local copy of the file associated with the provided job ID and blob key.
- getFile(JobID, TransientBlobKey) - Method in class org.apache.flink.runtime.blob.BlobServer
-
Retrieves the local path of a file associated with a job and a blob key.
- getFile(JobID, TransientBlobKey) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
- getFile(JobID, TransientBlobKey) - Method in interface org.apache.flink.runtime.blob.TransientBlobService
-
Returns the path to a local copy of the file associated with the provided job ID and blob key.
- getFile(TransientBlobKey) - Method in class org.apache.flink.runtime.blob.BlobServer
-
Retrieves the local path of a (job-unrelated) file associated with a job and a blob key.
- getFile(TransientBlobKey) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
- getFile(TransientBlobKey) - Method in interface org.apache.flink.runtime.blob.TransientBlobService
-
Returns the path to a local copy of the (job-unrelated) file associated with the provided blob key.
- getFile(HandlerRequest<EmptyRequestBody>) - Method in class org.apache.flink.runtime.rest.handler.cluster.AbstractJobManagerFileHandler
- getFile(HandlerRequest<EmptyRequestBody>) - Method in class org.apache.flink.runtime.rest.handler.cluster.JobManagerCustomLogHandler
- getFile(HandlerRequest<EmptyRequestBody>) - Method in class org.apache.flink.runtime.rest.handler.cluster.JobManagerLogFileHandler
- getFile(HandlerRequest<EmptyRequestBody>) - Method in class org.apache.flink.runtime.rest.handler.cluster.JobManagerProfilingFileHandler
- getFileChannel() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileSegment
- getFilehandlesDriver() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getFilehandlesInput(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getFileId() - Method in class org.apache.flink.runtime.checkpoint.filemerging.LogicalFile
- getFileInternal(JobID, BlobKey) - Method in class org.apache.flink.runtime.blob.AbstractBlobCache
-
Returns local copy of the file for the BLOB with the given key.
- getFileInternal(JobID, BlobKey) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
- getFileMergingSnapshotManager() - Method in interface org.apache.flink.runtime.state.TaskStateManager
- getFileMergingSnapshotManager() - Method in class org.apache.flink.runtime.state.TaskStateManagerImpl
- getFileName(HandlerRequest<EmptyRequestBody>) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.AbstractTaskManagerFileHandler
- getFileName(HandlerRequest<EmptyRequestBody>) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerCustomLogHandler
- getFileName(HandlerRequest<EmptyRequestBody>) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerProfilingFileHandler
- getFilePath() - Method in class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFile
- getFilePath() - Method in class org.apache.flink.runtime.state.filemerging.SegmentFileStateHandle
-
Gets the path where this handle's state is stored.
- getFilePath() - Method in class org.apache.flink.runtime.state.filesystem.FileMergingCheckpointStateOutputStream
- getFilePath() - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
-
Gets the path where this handle's state is stored.
- getFileQueue(FileMergingSnapshotManager.SubtaskKey, CheckpointedStateScope) - Method in class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFilePool
-
Get or create a file queue for specific subtaskKey and checkpoint scope.
- getFilter() - Method in class org.apache.flink.runtime.metrics.groups.ReporterScopedSettings
- getFilter() - Method in class org.apache.flink.runtime.metrics.ReporterSetup
- getFilterStrategy() - Method in interface org.apache.flink.runtime.state.StateSnapshotTransformer.CollectionStateSnapshotTransformer
- getFinalBufferSubpartitionId() - Method in class org.apache.flink.runtime.io.network.api.RecoveryMetadata
- getFinishedAttempt(int) - Method in interface org.apache.flink.runtime.jobgraph.JobVertex.FinalizeOnMasterContext
-
Get the finished attempt number of subtask.
- getFinishedOnRestoreInputOrDefault(Input) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- getFinishedTasks() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointPlan
-
Returns tasks that have already been finished when taking the checkpoint.
- getFinishedTasks() - Method in class org.apache.flink.runtime.checkpoint.DefaultCheckpointPlan
- getFinishedTime() - Method in class org.apache.flink.runtime.rest.messages.ProfilingInfo
- getFirst() - Method in class org.apache.flink.runtime.scheduler.strategy.ConsumedPartitionGroup
- getFirst() - Method in class org.apache.flink.runtime.scheduler.strategy.ConsumerVertexGroup
- getFirstBufferIndex() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.index.FileDataIndexRegionHelper.Region
-
Get the first buffer index of this region.
- getFirstBufferIndex() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.ProducerMergedPartitionFileIndex.FixedSizeRegion
- getFirstInput() - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
Returns the non-broadcast
DataStream. - getFirstInput() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Returns the first
DataStream. - getFlatComparators() - Method in class org.apache.flink.streaming.api.operators.sortpartition.FixedLengthByteKeyAndValueComparator
- getFlatComparators() - Method in class org.apache.flink.streaming.api.operators.sortpartition.VariableLengthByteKeyAndValueComparator
- getFlexibleObjectMapper() - Static method in class org.apache.flink.runtime.rest.util.RestMapperUtils
-
Returns a preconfigured flexible
ObjectMapper. - getFlinkConfig() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
- getFlinkMemory() - Method in class org.apache.flink.runtime.util.config.memory.CommonProcessMemorySpec
- getFlinkRevision() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
- getFlinkVersion() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
- getForAggregation(AggregationFunction.AggregationType) - Static method in class org.apache.flink.streaming.api.functions.aggregation.Comparator
- getForClass(Class<?>) - Static method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction
- getFormat() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.OutputFormatSinkFunction
-
Deprecated.
- getFormat() - Method in class org.apache.flink.streaming.api.functions.source.legacy.InputFormatSourceFunction
-
Deprecated.Returns the
InputFormat. - getFormatDescription(OperatorID) - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatVertex
- getFormatType() - Method in class org.apache.flink.runtime.checkpoint.SavepointType
- getFormatType() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerRequestBody
- getFormatType() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointRequestBody
- getFqdnHostName() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation.DefaultHostNameSupplier
-
Returns the fully-qualified domain name the TaskManager.
- getFqdnHostName() - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerLocation.HostNameSupplier
- getFqdnHostName() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation.IpOnlyHostNameSupplier
-
Returns the textual representation of the TaskManager's IP address as FQDN host name.
- getFQDNHostname() - Method in class org.apache.flink.runtime.scheduler.exceptionhistory.ExceptionHistoryEntry.ArchivedTaskManagerLocation
- getFQDNHostname() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
Returns the fully-qualified domain name of the TaskManager provided by
TaskManagerLocation.hostNameSupplier. - getFraction() - Method in class org.apache.flink.runtime.util.config.memory.RangeFraction
- getFractionRoundedDown(long, long) - Static method in enum org.apache.flink.runtime.util.config.memory.ManagedMemoryUtils
- getFrameworkHeap() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
-
Returns the configured heap size used by the framework.
- getFrameworkHeap() - Method in class org.apache.flink.runtime.util.config.memory.taskmanager.TaskExecutorFlinkMemory
- getFrameworkHeapMemorySize(Configuration) - Static method in class org.apache.flink.runtime.util.config.memory.taskmanager.TaskExecutorFlinkMemoryUtils
- getFrameworkOffHeap() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
-
Returns the configured off-heap size used by the framework.
- getFrameworkOffHeap() - Method in class org.apache.flink.runtime.util.config.memory.taskmanager.TaskExecutorFlinkMemory
- getFrameworkOffHeapMemorySize(Configuration) - Static method in class org.apache.flink.runtime.util.config.memory.taskmanager.TaskExecutorFlinkMemoryUtils
- getFreedMemory() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
- getFreeMemory() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
- getFreeMemory() - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
- getFreeMemory() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
- getFreeResource() - Method in class org.apache.flink.runtime.resourcemanager.ResourceOverview
- getFreeResource() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ClusterResourceStatisticsProvider
-
Get profile of total free resources.
- getFreeResource() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedSlotManager
- getFreeResource() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- getFreeResource() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
- getFreeResource() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- getFreeResourceOf(InstanceID) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ClusterResourceStatisticsProvider
-
Get profile of free resources from the TaskManager with the given instance id.
- getFreeResourceOf(InstanceID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedSlotManager
- getFreeResourceOf(InstanceID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- getFreeResourceOf(InstanceID) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
- getFreeSince() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotPool.FreeSlotInfo
-
Returns since when this slot is free.
- getFreeSlotsInformation() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultFreeSlotTracker
- getFreeSlotsInformation() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.FreeSlotTracker
-
Returns a list of
PhysicalSlotobjects about all slots that are currently available in the slot pool. - getFreeSlotsWithIdleSinceInformation() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultFreeSlotTracker
- getFreeSlotsWithIdleSinceInformation() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.FreeSlotTracker
-
Returns a list of
AllocatedSlotPool.FreeSlotInfoobjects about all slots with slot idle since that are currently available in the slot pool. - getFreeSlotTracker() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotPool
-
Returns information about all currently free slots.
- getFreeSlotTracker() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPool
-
Returns the free slot tracker.
- getFreeSlotTracker() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolBridge
- getFreeSlotTracker() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultAllocatedSlotPool
- getFreeSlotTracker() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultDeclarativeSlotPool
- getFreeSlotTracker() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Returns all free slot tracker.
- getFrom() - Method in class org.apache.flink.runtime.state.changelog.inmemory.InMemoryChangelogStateHandle
- getFullBufferData(MemorySegment) - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
-
Returns the full buffer data in one piece of
MemorySegment. - getFullSegments() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBulkBlockReader
- getFullSegments() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BulkBlockChannelReader
- getFullyFinishedJobVertex() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointPlan
-
Returns the job vertices whose tasks are all finished when taking the checkpoint.
- getFullyFinishedJobVertex() - Method in class org.apache.flink.runtime.checkpoint.DefaultCheckpointPlan
- getFuture() - Method in class org.apache.flink.runtime.asyncprocessing.StateRequest
- getFuture() - Method in class org.apache.flink.runtime.registration.RetryingRegistration
- getFuture() - Method in interface org.apache.flink.runtime.webmonitor.retriever.GatewayRetriever
-
Get future of object to retrieve.
- getFuture() - Method in class org.apache.flink.runtime.webmonitor.retriever.LeaderGatewayRetriever
- getFutureExecutor() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getFutureExecutor() - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
-
Returns the ExecutionContext associated with this ExecutionGraph.
- getFutureExecutor() - Method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
- getGarbageCollectorStatsAsString(List<GarbageCollectorMXBean>) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
-
Gets the garbage collection statistics from the JVM.
- getGateIdx() - Method in class org.apache.flink.runtime.checkpoint.channel.InputChannelInfo
- getGateIndex() - Method in class org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate
-
Returns the index of this input gate.
- getGateIndex() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- getGateIndex() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageConsumerSpec
- getGateIndex() - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
- getGateway() - Method in interface org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess.DispatcherGatewayService
- getGateway() - Method in class org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherGatewayService
- getGateway() - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- getGateway() - Method in interface org.apache.flink.runtime.jobmaster.JobMasterService
-
Get the
JobMasterGatewaybelonging to this service. - getGeneratedOperatorID() - Method in class org.apache.flink.runtime.OperatorIDPair
- getGitCommitId() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
- getGitCommitIdAbbrev() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
- getGitCommitTime() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
- getGitCommitTimeString() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
- getGlobalAggregateManager() - Method in interface org.apache.flink.runtime.execution.Environment
- getGlobalAggregateManager() - Method in interface org.apache.flink.runtime.taskexecutor.JobTable.Connection
- getGlobalAggregateManager() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getGlobalAggregateManager() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Returns the global aggregate manager for the current job.
- getGlobalCommitterUidHash() - Method in class org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes
- getGlobalFailureHandlingResult(Throwable, long) - Method in class org.apache.flink.runtime.executiongraph.failover.ExecutionFailureHandler
-
Return result of failure handling on a global failure.
- getGlobalJobParameters() - Method in class org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
- getGlobalModificationTime() - Method in class org.apache.flink.streaming.api.functions.source.legacy.ContinuousFileMonitoringFunction
-
Deprecated.
- getGlobalStreamExchangeMode() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getGraph() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- getGraphGeneratorConfig() - Method in interface org.apache.flink.streaming.api.graph.TransformationTranslator.Context
-
Retrieves additional configuration for the graph generation process.
- getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Returns the name for this group, meaning what kind of entity it represents, for example "taskmanager".
- getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.GenericMetricGroup
- getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.InternalOperatorMetricGroup
- getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
- getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerOperatorMetricGroup
- getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.JobMetricGroup
- getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
- getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
- getGroupRangeOffsets() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
- getGroupSize(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getHadoopUser() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Gets the name of the user that is running the JVM.
- getHadoopVersionString() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
- getHaLeadershipControl() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
Returns
HaLeadershipControlif enabled. - getHandle() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle.HandleAndLocalPath
- getHandleName() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
- getHandlers() - Method in enum org.apache.flink.runtime.webmonitor.WebMonitorExtension.EmptyWebMonitorExtension
- getHandlers() - Method in interface org.apache.flink.runtime.webmonitor.WebMonitorExtension
-
Gets the collection of extension handlers to register at the
WebMonitorEndpoint. - getHandlesAndOffsets() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateHandleStreamImpl
- getHardBackPressuredTimeMsPerSecond() - Method in class org.apache.flink.runtime.io.network.partition.BufferWritingResultPartition
- getHardBackPressuredTimePerSecond() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- getHardwareDescription() - Method in class org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
- getHardwareDescription() - Method in class org.apache.flink.runtime.resourcemanager.TaskExecutorRegistration
- getHardwareDescription() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- getHaServices() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- getHaServices() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
- getHash() - Method in class org.apache.flink.runtime.blob.BlobKey
-
Returns the hash component of this key.
- getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - Method in class org.apache.flink.runtime.operators.hash.HashJoinIteratorBase
- getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstReOpenableHashJoinIterator
- getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondReOpenableHashJoinIterator
- getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstReOpenableHashJoinIterator
- getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondReOpenableHashJoinIterator
- getHashPartitioner() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardForConsecutiveHashPartitioner
- getHeadElementIndex() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
-
Returns the start index of the queue elements in the array.
- getHeadElementIndex() - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueue
- getHeaderLength() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
- getHeaderLength() - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
- getHeartbeatServices() - Method in class org.apache.flink.runtime.dispatcher.DispatcherServices
- getHeartbeatServices() - Method in class org.apache.flink.runtime.dispatcher.PartialDispatcherServices
- getHeartbeatServices() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerProcessContext
- getHeartbeatTarget() - Method in class org.apache.flink.runtime.heartbeat.DefaultHeartbeatMonitor
- getHeartbeatTarget() - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatMonitor
-
Gets heartbeat target.
- getHeartbeatTargetId() - Method in class org.apache.flink.runtime.heartbeat.DefaultHeartbeatMonitor
- getHeartbeatTargetId() - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatMonitor
-
Gets heartbeat target id.
- getHighAvailabilityServices() - Method in class org.apache.flink.runtime.dispatcher.DispatcherServices
- getHighAvailabilityServices() - Method in class org.apache.flink.runtime.dispatcher.PartialDispatcherServices
- getHighAvailabilityServices() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerProcessContext
- getHistoricalExecution(int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionHistory
- getHistoricalExecutions() - Method in class org.apache.flink.runtime.executiongraph.ExecutionHistory
- getHistory() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
-
Returns the snapshotted checkpoint history.
- getHistory() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
- getHistoryServerArchivist() - Method in class org.apache.flink.runtime.dispatcher.DispatcherServices
- getHistoryServerArchivist() - Method in class org.apache.flink.runtime.dispatcher.PartialDispatcherServices
- getHistoryServerURL(Configuration) - Static method in enum org.apache.flink.runtime.webmonitor.history.HistoryServerUtils
- getHistorySize() - Method in class org.apache.flink.runtime.state.metrics.LatencyTrackingStateConfig
- getHitCount() - Method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexFlameGraph.Node
- getHost() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
Gets the hostname of the master (JobManager), where the program will be executed.
- getHostAddress() - Method in class org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
- getHostedPartitions() - Method in class org.apache.flink.runtime.taskexecutor.partition.ClusterPartitionReport.ClusterPartitionReportEntry
- getHostname() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerProcessContext
- getHostname() - Method in class org.apache.flink.runtime.scheduler.exceptionhistory.ExceptionHistoryEntry.ArchivedTaskManagerLocation
- getHostname() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- getHostname() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
Gets the hostname of the TaskManager from
TaskManagerLocation.hostNameSupplier. - getHostname() - Method in class org.apache.flink.runtime.webmonitor.NonLeaderRetrievalRestfulGateway
- getHostName() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation.DefaultHostNameSupplier
-
Gets the hostname of the TaskManager.
- getHostName() - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerLocation.HostNameSupplier
- getHostName() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation.IpOnlyHostNameSupplier
-
Returns the textual representation of the TaskManager's IP address as host name.
- getHostName(InetAddress) - Static method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
Gets the hostname of the TaskManager based on the network address.
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.handler.legacy.files.WebContentHandlerSpecification
- getHttpMethod() - Method in interface org.apache.flink.runtime.rest.handler.RestHandlerSpecification
-
Returns the
HttpMethodWrapperto be used for the request. - getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatusHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointTriggerHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerCustomLogHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerLogFileHeader
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerLogListHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerProfilingFileHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerProfilingHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerProfilingListHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerStdoutFileHeader
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerThreadDumpHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.CustomHeadersDecorator
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteStatusHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteTriggerHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetListHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.coordination.ClientCoordinationHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.JobManagerJobConfigurationHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.JobManagerJobEnvironmentHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.JobResourceRequirementsHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.JobResourcesRequirementsUpdateHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.JobStatusInfoHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexWatermarksHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointTriggerHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobCancellationHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobClientHeartbeatHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobManagerEnvironmentHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobManagerLogUrlHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobVertexFlameGraphHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerCustomLogHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogsHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingFileHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingListHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerStdoutFileHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerThreadDumpHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.TaskManagerLogUrlHeaders
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.YarnCancelJobTerminationHeaders
-
Deprecated.
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.YarnStopJobTerminationHeaders
-
Deprecated.
- getHttpResponseStatus() - Method in exception org.apache.flink.runtime.rest.handler.RestHandlerException
- getHttpResponseStatus() - Method in exception org.apache.flink.runtime.rest.util.RestClientException
- getId() - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
- getId() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
- getId() - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
- getId() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
- getId() - Method in class org.apache.flink.runtime.jobgraph.topology.DefaultLogicalResult
- getId() - Method in class org.apache.flink.runtime.jobgraph.topology.DefaultLogicalVertex
- getId() - Method in interface org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
-
Returns the unique identifier describing this co-location constraint as a group.
- getId() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroupImpl
- getId() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
- getId() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- getId() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
- getId() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.Metric
- getId() - Method in class org.apache.flink.runtime.rest.messages.queue.QueueStatus
- getId() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
- getId() - Method in interface org.apache.flink.runtime.topology.Result
- getId() - Method in interface org.apache.flink.runtime.topology.Vertex
- getId() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Returns the ID of the
DataStreamin the currentStreamExecutionEnvironment. - getId() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getID() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getID() - Method in class org.apache.flink.runtime.executiongraph.TaskExecutionStateTransition
- getID() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns the ID of this job vertex.
- getID() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
Returns the ID of the task this result belongs to
- getIdentifier() - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
-
Gets the identifier of this hook.
- getIdentifier() - Method in class org.apache.flink.runtime.state.changelog.inmemory.InMemoryStateChangelogStorageFactory
- getIdentifier() - Method in interface org.apache.flink.runtime.state.changelog.StateChangelogStorageFactory
-
Get the identifier for user to use this changelog storage factory.
- getIdlenessTimeout() - Method in class org.apache.flink.runtime.rest.RestClientConfiguration
-
{@see RestOptions#IDLENESS_TIMEOUT}.
- getIdleRatio() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
- getIdleSince() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerRegistration
- getIdleSince() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerInfo
-
Get the timestamp when the last time becoming idle.
- getIdleTimeMsPerSecond() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- getIds(Collection<? extends OperatorInfo>) - Static method in interface org.apache.flink.runtime.operators.coordination.OperatorInfo
- getImplicitConvergenceCriterion(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getImplicitConvergenceCriterionAggregatorName() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getIndex() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory.ShuffleDescriptorAndIndex
- getIndex() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics
- getIndex() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
- getIndexFilePath() - Method in class org.apache.flink.runtime.io.network.partition.PartitionedFile
- getIndexInSubtaskGroup() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the index of this subtask in the subtask group.
- getIndexInSubtaskGroup() - Method in interface org.apache.flink.streaming.runtime.tasks.ContainingTaskDetails
- getInEdgeIndices() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getInEdges() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getInFlightRecordNum() - Method in class org.apache.flink.runtime.asyncprocessing.AsyncExecutionController
- getInfo() - Method in class org.apache.flink.runtime.state.AbstractChannelStateHandle
- getInfoForCurrentThread() - Method in class org.apache.flink.runtime.query.KvStateEntry
- getInitialClientHeartbeatTimeout() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
- getInitialCredit() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- getInitializationFailure() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunnerResult
-
This method returns the initialization failure.
- getInitializationStartTs() - Method in class org.apache.flink.runtime.checkpoint.SubTaskInitializationMetricsBuilder
- getInitializingOrRunningFuture() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Gets a future that completes once the task execution reaches one of the states
ExecutionState.INITIALIZINGorExecutionState.RUNNING. - getInitialRegistrationTimeoutMillis() - Method in class org.apache.flink.runtime.registration.RetryingRegistrationConfiguration
- getInitialTableSize(int, int, int, int) - Static method in class org.apache.flink.runtime.operators.hash.MutableHashTable
- getInitialTokens() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
-
Gets the initial tokens.
- getInPhysicalEdges(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getInput() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformationWrapper
- getInput(int) - Method in class org.apache.flink.runtime.operators.BatchTask
- getInput(int) - Method in interface org.apache.flink.runtime.operators.TaskContext
- getInput1() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the first input
Transformationof thisTwoInputTransformation. - getInput2() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the second input
Transformationof thisTwoInputTransformation. - getInputActivityClock() - Method in class org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarksContext
- getInputBytes() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getInputChannel(InputChannelID) - Method in interface org.apache.flink.runtime.io.network.NetworkClientHandler
- getInputChannelId() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- getInputChannelId() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageInputChannelId
- getInputChannelId() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageConsumerSpec
- getInputChannelIdx() - Method in class org.apache.flink.runtime.checkpoint.channel.InputChannelInfo
- getInputChannelNums() - Method in class org.apache.flink.runtime.shuffle.TaskInputsOutputsDescriptor
- getInputChannelOffsets() - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStatePendingResult
- getInputChannels() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- getInputChannelState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
- getInputChannelStateFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
- getInputChannelStateHandles() - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter.ChannelStateWriteResult
- getInputChannelsWithData() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- getInputComparator(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getInputEdge() - Method in class org.apache.flink.streaming.api.graph.StreamConfig.SourceInputConfig
- getInputFormat() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getInputFormat() - Method in interface org.apache.flink.streaming.api.operators.InputFormatOperatorFactory
- getInputFormat() - Method in class org.apache.flink.streaming.api.operators.SimpleInputFormatOperatorFactory
- getInputFormats() - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer.FormatUserCodeTable
- getInputFormats() - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
- getInputGate(int) - Method in interface org.apache.flink.runtime.execution.Environment
- getInputGate(int) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getInputGate(InputGateID) - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
- getInputGateIndex() - Method in interface org.apache.flink.runtime.io.network.partition.consumer.CheckpointableInput
- getInputGateIndex() - Method in class org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate
- getInputGateIndex() - Method in class org.apache.flink.streaming.api.graph.StreamConfig.NetworkInputConfig
- getInputGateIndex() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
- getInputGateNums() - Method in class org.apache.flink.runtime.shuffle.TaskInputsOutputsDescriptor
- getInputGates() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
- getInputGroup() - Method in class org.apache.flink.runtime.shuffle.ShuffleIOOwnerContext
- getInputIndex() - Method in class org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput
- getInputIndex() - Method in class org.apache.flink.streaming.api.operators.sort.SortingDataInput
- getInputIndex() - Method in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
- getInputIndex() - Method in interface org.apache.flink.streaming.runtime.io.StreamTaskInput
-
Returns the input index of this input.
- getInputIndex() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
- getInputLocalStrategy(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getInputMask() - Method in class org.apache.flink.streaming.api.operators.InputSelection
- getInputPartitionTypes() - Method in class org.apache.flink.runtime.shuffle.TaskInputsOutputsDescriptor
- getInputRequirement() - Method in class org.apache.flink.streaming.api.graph.StreamConfig.NetworkInputConfig
- getInputRequirements() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getInputRescalingDescriptor() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
- getInputRescalingDescriptor() - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
-
Returns the input channel mapping for rescaling with in-flight data or
InflightDataRescalingDescriptor.NO_RESCALE. - getInputRescalingDescriptor() - Method in interface org.apache.flink.runtime.state.TaskStateManager
- getInputRescalingDescriptor() - Method in class org.apache.flink.runtime.state.TaskStateManagerImpl
- getInputs() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- getInputs() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- getInputs() - Method in class org.apache.flink.runtime.jobgraph.topology.DefaultLogicalVertex
- getInputs() - Method in interface org.apache.flink.runtime.jobgraph.topology.LogicalVertex
-
Get the input
LogicalEdges of the vertex. - getInputs() - Method in interface org.apache.flink.streaming.api.operators.MultipleInputStreamOperator
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.CacheTransformation
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.LegacySinkTransformation
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.LegacySourceTransformation
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.ReduceTransformation
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.SideOutputTransformation
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformationWrapper
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.TimestampsAndWatermarksTransformation
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
- getInputs() - Method in class org.apache.flink.streaming.api.transformations.UnionTransformation
- getInputs(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getInputSelectable() - Method in class org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput.SelectableSortingInputs
- getInputSerializer(int) - Method in class org.apache.flink.runtime.operators.BatchTask
- getInputSerializer(int) - Method in interface org.apache.flink.runtime.operators.TaskContext
- getInputSerializer(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getInputSplitData() - Method in class org.apache.flink.runtime.jobmaster.SerializedInputSplit
- getInputSplitProvider() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the input split provider assigned to this environment.
- getInputSplitProvider() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getInputSplitProvider() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Returns the input split provider associated with the operator.
- getInputSplitSource() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- getInputStream() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
- getInputSubtaskIndex() - Method in class org.apache.flink.runtime.io.network.api.SubtaskConnectionDescriptor
- getInputType() - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
- getInputType() - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
- getInputType() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Returns the
TypeInformationfor the elements of the input. - getInputType() - Method in class org.apache.flink.streaming.api.transformations.ReduceTransformation
-
Returns the
TypeInformationfor the elements of the input. - getInputType() - Method in class org.apache.flink.streaming.api.transformations.TimestampsAndWatermarksTransformation
-
Returns the
TypeInformationfor the elements of the input. - getInputType1() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the
TypeInformationfor the elements from the first input. - getInputType2() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the
TypeInformationfor the elements from the second input. - getInputTypes() - Method in class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
-
Returns the
TypeInformationfor the elements from the inputs. - getInstalledContext() - Static method in class org.apache.flink.runtime.security.SecurityUtils
- getInstalledModules() - Static method in class org.apache.flink.runtime.security.SecurityUtils
- getInstance() - Static method in class org.apache.flink.runtime.blob.VoidBlobWriter
- getInstance() - Static method in class org.apache.flink.runtime.heartbeat.NoOpHeartbeatManager
- getInstance() - Static method in class org.apache.flink.runtime.heartbeat.NoOpHeartbeatServices
- getInstance() - Static method in class org.apache.flink.runtime.messages.webmonitor.RequestJobsOverview
- getInstance() - Static method in class org.apache.flink.runtime.messages.webmonitor.RequestJobsWithIDsOverview
- getInstance() - Static method in class org.apache.flink.runtime.messages.webmonitor.RequestStatusOverview
- getInstance() - Method in interface org.apache.flink.runtime.plugable.DeserializationDelegate
- getInstance() - Method in class org.apache.flink.runtime.plugable.NonReusingDeserializationDelegate
- getInstance() - Method in class org.apache.flink.runtime.plugable.ReusingDeserializationDelegate
- getInstance() - Method in class org.apache.flink.runtime.plugable.SerializationDelegate
- getInstance() - Static method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManagerFactory
- getInstance() - Static method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.WebContentHandlerSpecification
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatusHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointTriggerHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerCustomLogHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerLogFileHeader
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerLogListHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerProfilingFileHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerProfilingHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerProfilingListHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerStdoutFileHeader
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerThreadDumpHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.EmptyMessageParameters
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.EmptyRequestBody
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.EmptyResponseBody
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.coordination.ClientCoordinationHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.JobManagerJobConfigurationHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.JobManagerJobEnvironmentHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.JobStatusInfoHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedJobMetricsHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedSubtaskMetricsHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedTaskManagerMetricsHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerOperatorMetricsHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexMetricsHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointTriggerHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobCancellationHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobClientHeartbeatHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobManagerEnvironmentHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobManagerLogUrlHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobVertexFlameGraphHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerCustomLogHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogsHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingFileHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingListHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerStdoutFileHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerThreadDumpHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.TaskManagerLogUrlHeaders
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.YarnCancelJobTerminationHeaders
-
Deprecated.
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.YarnStopJobTerminationHeaders
-
Deprecated.
- getInstance() - Static method in class org.apache.flink.runtime.shuffle.EmptyShuffleMasterSnapshot
- getInstance(Configuration) - Static method in class org.apache.flink.runtime.util.profiler.ProfilingService
- getInstanceId() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerRegistration
- getInstanceId() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerSlot
- getInstanceId() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerInfo
-
Get the instanceId of this task manager.
- getInstanceId() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerSlotInformation
- getInstanceID() - Method in class org.apache.flink.runtime.resourcemanager.registration.TaskExecutorConnection
- getInstanceIdByResourceId(ResourceID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- getIntermediateDataSetId() - Method in class org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionInfo
- getIntermediateDataSetID() - Method in class org.apache.flink.runtime.executiongraph.PartitionInfo
- getIntermediateDataSetID() - Method in class org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
- getIntermediateDataSetID() - Method in class org.apache.flink.runtime.scheduler.strategy.ConsumedPartitionGroup
-
Get the ID of IntermediateDataSet this ConsumedPartitionGroup belongs to.
- getIntermediateDataSetIdsToConsume() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- getIntermediateDatasetIdToProduce() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
- getIntermediateResult() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
- getInternal() - Method in interface org.apache.flink.runtime.state.internal.InternalAppendingState
-
Get internally stored value.
- getInternalCoordinator() - Method in class org.apache.flink.runtime.operators.coordination.RecreateOnResetOperatorCoordinator
- getInternalIndex() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueueElement
- getInternalIndex() - Method in interface org.apache.flink.runtime.state.heap.HeapPriorityQueueElement
-
Returns the current index of this object in the internal array of
HeapPriorityQueue. - getInternalIndex() - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
- getInternalIndex() - Method in class org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve.SubpartitionStatus
- getInternalListCopySerializer() - Method in class org.apache.flink.runtime.state.PartitionableListState
- getInternalMapCopySerializer() - Method in class org.apache.flink.runtime.state.HeapBroadcastState
- getInternalTimerService(String, TypeSerializer<K>, TypeSerializer<N>, Triggerable<K, N>) - Method in interface org.apache.flink.streaming.api.operators.InternalTimeServiceManager
-
Creates an
InternalTimerServicefor handling a group of timers identified by the givenname. - getInternalTimerService(String, TypeSerializer<K>, TypeSerializer<N>, Triggerable<K, N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManagerImpl
- getInternalTimerService(String, TypeSerializer<K>, TypeSerializer<N>, Triggerable<K, N>) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeServiceManager
- getInternalTimerService(String, TypeSerializer<N>, Triggerable<K, N>) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperator
-
Returns a
InternalTimerServicethat can be used to query current processing time and event time and to set timers. - getInternalTimerService(String, TypeSerializer<N>, Triggerable<K, N>) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperatorV2
- getInternalTimerService(String, TypeSerializer<N>, Triggerable<K, N>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Returns a
InternalTimerServicethat can be used to query current processing time and event time and to set timers. - getInternalTimerService(String, TypeSerializer<N>, Triggerable<K, N>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
Returns a
InternalTimerServicethat can be used to query current processing time and event time and to set timers. - getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.AbstractIncrementalStateHandle
- getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl
- getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendLocalHandle
- getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateHandleStreamImpl
- getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.changelog.inmemory.InMemoryChangelogStateHandle
- getIntersection(KeyGroupRange) - Method in interface org.apache.flink.runtime.state.KeyedStateHandle
-
Returns a state over a range that is the intersection between this handle's key-group range and the provided key-group range.
- getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.KeyGroupRange
-
Create a range that represent the intersection between this range and the given range.
- getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
-
Returns a key-group range with offsets which is the intersection of the internal key-group range with the given key-group range.
- getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.KeyGroupsSavepointStateHandle
- getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
- getIntervalSettings() - Method in class org.apache.flink.runtime.metrics.ReporterSetup
- getInvokableClass(ClassLoader) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns the invokable class which represents the task of this vertex.
- getInvokableClassName() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
- getInvokableClassName() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns the name of the invokable class which represents the task of this vertex.
- getIoExecutor() - Method in class org.apache.flink.runtime.dispatcher.DispatcherServices
- getIoExecutor() - Method in class org.apache.flink.runtime.dispatcher.PartialDispatcherServices
- getIoExecutor() - Method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
- getIoExecutor() - Method in class org.apache.flink.runtime.resourcemanager.active.AbstractResourceManagerDriver
- getIoExecutor() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerProcessContext
- getIoExecutor() - Method in class org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
- getIOExecutor() - Method in class org.apache.flink.runtime.failure.DefaultFailureEnricherContext
- getIOExecutor() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- getIOExecutor() - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- getIOExecutor() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
- getIOManager() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the current
IOManager. - getIOManager() - Method in class org.apache.flink.runtime.operators.BatchTask
- getIOManager() - Method in interface org.apache.flink.runtime.operators.TaskContext
- getIOManager() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
- getIOManager() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getIOMetricGroup() - Method in class org.apache.flink.runtime.metrics.groups.InternalOperatorMetricGroup
-
Returns the OperatorIOMetricGroup for this operator.
- getIOMetricGroup() - Method in class org.apache.flink.runtime.metrics.groups.InternalSinkCommitterMetricGroup
- getIOMetricGroup() - Method in class org.apache.flink.runtime.metrics.groups.InternalSinkWriterMetricGroup
- getIOMetricGroup() - Method in class org.apache.flink.runtime.metrics.groups.InternalSourceReaderMetricGroup
- getIOMetricGroup() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
Returns the TaskIOMetricGroup for this task.
- getIOMetrics() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
- getIOMetrics() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
- getIOMetrics() - Method in class org.apache.flink.runtime.executiongraph.Execution
- getIOMetrics() - Method in class org.apache.flink.runtime.executiongraph.TaskExecutionStateTransition
- getIOMetrics() - Method in class org.apache.flink.runtime.jobmaster.event.ExecutionVertexFinishedEvent
- getIOMetrics() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
- getIOMetrics() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
- getIoMetricsInfo() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- getIOWait() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
- getIsSolutionSetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getIssueDate(Clock, String, AbstractDelegationTokenIdentifier) - Static method in class org.apache.flink.runtime.hadoop.HadoopUserUtils
- getIsWorksetIteration() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getIsWorksetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getIterationAggregators() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
- getIterationAggregators(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getIterationHeadFinalOutputConfig() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getIterationHeadIndexOfSyncOutput() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getIterationHeadPartialSolutionOrWorksetInputIndex() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getIterationHeadSolutionSetInputIndex() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getIterationId() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getIterationId() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
- getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
- getIterationSourceSinkPairs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getIterationWaitTime() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getIterator() - Method in class org.apache.flink.runtime.operators.sort.ExternalSorter
- getIterator() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
Gets an iterator over all records in this buffer in their logical order.
- getIterator() - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Gets an iterator over all records in this buffer in their logical order.
- getIterator() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
Gets an iterator over all records in this buffer in their logical order.
- getIterator() - Method in class org.apache.flink.runtime.operators.TempBarrier
-
This method resets the input!
- getIterator() - Method in interface org.apache.flink.runtime.operators.util.CloseableInputProvider
-
Gets the iterator over this input.
- getIterator() - Method in class org.apache.flink.runtime.operators.util.SimpleCloseableInputProvider
- getIterator(int) - Method in interface org.apache.flink.runtime.state.IterableStateSnapshot
- getIterator(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<S>, StateSnapshotTransformer<S>) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMapSnapshot
- getIterator(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<S>, StateSnapshotTransformer<S>) - Method in class org.apache.flink.runtime.state.heap.StateMapSnapshot
- getIteratorForKeyGroup(int) - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueStateSnapshot
- getJmOperatorFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
- getJmxPort() - Method in class org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
- getJmxPort() - Method in class org.apache.flink.runtime.resourcemanager.TaskExecutorRegistration
- getJmxPort() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- getJob() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
- getJob(JobID) - Method in class org.apache.flink.runtime.taskexecutor.DefaultJobTable
- getJob(JobID) - Method in interface org.apache.flink.runtime.taskexecutor.JobTable
-
Gets the job registered under jobId.
- getJobAccumulators() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
- getJobConfiguration() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the job-wide configuration object that was attached to the JobGraph.
- getJobConfiguration() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getJobConfiguration() - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- getJobConfiguration() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
- getJobConfiguration() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns the configuration object for this job.
- getJobConfiguration() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the job configuration object which was attached to the original
JobGraph. - getJobConfiguration() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getJobConfiguration() - Method in class org.apache.flink.runtime.taskmanager.Task
- getJobConfiguration() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getJobConfiguration() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
- getJobConfiguration() - Method in interface org.apache.flink.streaming.runtime.tasks.ContainingTaskDetails
- getJobExecutionResult() - Method in class org.apache.flink.runtime.minicluster.MiniClusterJobClient
- getJobExecutionResult() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
- getJobGraph() - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- getJobGraph() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Gets the assembled
JobGraphwith a randomJobID. - getJobGraph(ClassLoader, JobID) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Gets the assembled
JobGraphwith a specifiedJobID. - getJobGraphStore() - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
- getJobGraphStore() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the submitted job graph store for the job manager.
- getJobGraphStore() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
- getJobGraphWriter() - Method in class org.apache.flink.runtime.dispatcher.DispatcherServices
- getJobGraphWriter() - Method in class org.apache.flink.runtime.dispatcher.PartialDispatcherServicesWithJobPersistenceComponents
- getJobId() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
- getJobId() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
- getJobId() - Method in class org.apache.flink.runtime.client.JobStatusMessage
- getJobId() - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
- getJobId() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Returns the task's job ID.
- getJobId() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- getJobId() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getJobId() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
- getJobId() - Method in class org.apache.flink.runtime.highavailability.JobResultEntry
- getJobId() - Method in class org.apache.flink.runtime.jobmaster.AllocatedSlotReport
- getJobId() - Method in class org.apache.flink.runtime.jobmaster.factories.DefaultJobMasterServiceProcessFactory
- getJobId() - Method in interface org.apache.flink.runtime.jobmaster.factories.JobMasterServiceProcessFactory
-
Gets the
JobIDof the job for which this factory createsJobMasterServiceProcess. - getJobId() - Method in class org.apache.flink.runtime.jobmaster.JobResult
- getJobId() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
- getJobId() - Method in class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview.JobIdWithStatus
- getJobId() - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Returns the JobID the KvState instances belong to.
- getJobId() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerSlot
- getJobId() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerSlotInformation
- getJobId() - Method in class org.apache.flink.runtime.rest.handler.job.AsynchronousJobOperationKey
-
Get the job id for the given operation key.
- getJobId() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getJobId() - Method in class org.apache.flink.runtime.rest.messages.JobConfigInfo
- getJobId() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.SlotInfo
- getJobId() - Method in class org.apache.flink.runtime.scheduler.ExecutionGraphInfo
- getJobId() - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- getJobId() - Method in interface org.apache.flink.runtime.shuffle.JobShuffleContext
- getJobId() - Method in class org.apache.flink.runtime.shuffle.JobShuffleContextImpl
- getJobId() - Method in class org.apache.flink.runtime.slots.ResourceRequirements
- getJobId() - Method in exception org.apache.flink.runtime.taskexecutor.exceptions.SlotOccupiedException
- getJobId() - Method in interface org.apache.flink.runtime.taskexecutor.JobTable.Connection
- getJobId() - Method in interface org.apache.flink.runtime.taskexecutor.JobTable.Job
-
Returns the
JobIDwhich is associated with this job. - getJobId() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotAllocationSnapshot
- getJobId() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
- getJobID() - Method in class org.apache.flink.runtime.accumulators.AccumulatorSnapshot
- getJobID() - Method in exception org.apache.flink.runtime.client.JobExecutionException
- getJobID() - Method in class org.apache.flink.runtime.dispatcher.cleanup.CheckpointResourcesCleanupRunner
- getJobID() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the ID of the job that the task belongs to.
- getJobID() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the
JobIDfor this execution graph. - getJobID() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
- getJobID() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getJobID() - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
- getJobID() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns the ID of the job.
- getJobID() - Method in interface org.apache.flink.runtime.jobmaster.JobManagerRunner
-
Get the job id of the executed job.
- getJobID() - Method in class org.apache.flink.runtime.jobmaster.JobMasterServiceLeadershipRunner
- getJobID() - Method in class org.apache.flink.runtime.minicluster.MiniClusterJobClient
- getJobID() - Method in class org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
- getJobID() - Method in class org.apache.flink.runtime.scheduler.adaptive.JobGraphJobInformation
- getJobID() - Method in class org.apache.flink.runtime.state.KeyedStateBackendParametersImpl
- getJobID() - Method in interface org.apache.flink.runtime.state.StateBackend.KeyedStateBackendParameters
- getJobID() - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotPayload
- getJobID() - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
-
Get the job id of the slot allocated for.
- getJobID() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getJobID() - Method in class org.apache.flink.runtime.taskmanager.Task
- getJobIds() - Method in class org.apache.flink.runtime.jobmanager.DefaultJobGraphStore
- getJobIds() - Method in interface org.apache.flink.runtime.jobmanager.JobGraphStore
-
Get all job ids of submitted job graphs to the submitted job graph store.
- getJobIds() - Method in class org.apache.flink.runtime.jobmanager.StandaloneJobGraphStore
- getJobIDString() - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager.SubtaskKey
- getJobInfo() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the
JobInfoobject associated with current job. - getJobInfo() - Method in class org.apache.flink.runtime.failure.DefaultFailureEnricherContext
- getJobInfo() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getJobInformation() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Return the sub task's job information.
- getJobInformationCache() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
- getJobLeaderIdService() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
- getJobLeaderService() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
- getJobListeners() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the config JobListeners.
- getJobManagerAddress(Configuration) - Static method in class org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
-
Returns the JobManager's hostname and port extracted from the given
Configuration. - getJobManagerBindAddress() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
- getJobManagerExternalAddress() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
- getJobManagerExternalPortRange() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
- getJobManagerFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
- getJobManagerGateway() - Method in class org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
- getJobManagerGateway() - Method in interface org.apache.flink.runtime.taskexecutor.JobTable.Connection
- getJobManagerJobFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
- getJobManagerLeaderElection(JobID) - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
- getJobManagerLeaderElection(JobID) - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the
LeaderElectionfor the job with the givenJobID. - getJobManagerLeaderElection(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
- getJobManagerLeaderElection(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
- getJobManagerLeaderRetriever(JobID) - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
- getJobManagerLeaderRetriever(JobID) - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Deprecated.This method should only be used by the legacy code where the JobManager acts as the master.
- getJobManagerLeaderRetriever(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
- getJobManagerLeaderRetriever(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
- getJobManagerLeaderRetriever(JobID, String) - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
- getJobManagerLeaderRetriever(JobID, String) - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the leader retriever for the job JobMaster which is responsible for the given job.
- getJobManagerLeaderRetriever(JobID, String) - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
- getJobManagerLeaderRetriever(JobID, String) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
- getJobManagerManagedKeyedState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns the managed keyed state from the job manager, which represents the ground truth about what this state should represent.
- getJobManagerManagedOperatorState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns the managed operator state from the job manager, which represents the ground truth about what this state should represent.
- getJobManagerMetricGroup() - Method in class org.apache.flink.runtime.dispatcher.DispatcherServices
- getJobManagerMetricGroupFactory() - Method in class org.apache.flink.runtime.dispatcher.PartialDispatcherServices
- getJobManagerMetricStore() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
Returns the
MetricStore.ComponentMetricStorefor the JobManager. - getJobManagerOperatorMetricStore() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.TaskMetricStore
- getJobManagerOperatorMetricStore(String, String) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
- getJobManagerOwnedSnapshot() - Method in class org.apache.flink.runtime.state.SnapshotResult
- getJobManagerOwnedState() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFinalizer
- getJobManagerRawKeyedState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns the raw keyed state from the job manager, which represents the ground truth about what this state should represent.
- getJobManagerRawOperatorState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns the raw operator state from the job manager, which represents the ground truth about what this state should represent.
- getJobManagerResourceID() - Method in class org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
- getJobManagerRunners() - Method in class org.apache.flink.runtime.dispatcher.DefaultJobManagerRunnerRegistry
- getJobManagerRunners() - Method in interface org.apache.flink.runtime.dispatcher.JobManagerRunnerRegistry
-
Returns the registered
JobManagerRunnerinstances. - getJobManagerRunners() - Method in class org.apache.flink.runtime.dispatcher.OnMainThreadJobManagerRunnerRegistry
- getJobMasterGateway() - Method in class org.apache.flink.runtime.dispatcher.cleanup.CheckpointResourcesCleanupRunner
- getJobMasterGateway() - Method in interface org.apache.flink.runtime.jobmaster.JobManagerRunner
-
Get the
JobMasterGatewayof theJobMaster. - getJobMasterGateway() - Method in class org.apache.flink.runtime.jobmaster.JobMasterServiceLeadershipRunner
- getJobMasterGatewayFuture() - Method in class org.apache.flink.runtime.jobmaster.DefaultJobMasterServiceProcess
- getJobMasterGatewayFuture() - Method in interface org.apache.flink.runtime.jobmaster.JobMasterServiceProcess
-
Future which is completed with the
JobMasterGatewayonce theJobMasterServicehas been created. - getJobMasterGatewayFuture() - Method in enum org.apache.flink.runtime.jobmaster.JobMasterServiceProcess.WaitingForLeadership
- getJobMasterId() - Method in class org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
- getJobMasterId() - Method in interface org.apache.flink.runtime.taskexecutor.JobTable.Connection
- getJobMasterMainThreadExecutor() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getJobMasterMainThreadExecutor() - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- getJobMasterMainThreadExecutor() - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
- getJobMetricsGroup(JobID) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
- getJobMetricStore(String) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
Returns the
MetricStore.ComponentMetricStorefor the given job ID. - getJobName() - Method in class org.apache.flink.runtime.client.JobStatusMessage
- getJobName() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the job name for the execution graph.
- getJobName() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
- getJobName() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getJobName() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
- getJobName() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
- getJobName() - Method in class org.apache.flink.runtime.rest.messages.JobConfigInfo
- getJobName() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getJobResult() - Method in class org.apache.flink.runtime.highavailability.JobResultEntry
- getJobResultStore() - Method in class org.apache.flink.runtime.dispatcher.DispatcherServices
- getJobResultStore() - Method in class org.apache.flink.runtime.dispatcher.PartialDispatcherServicesWithJobPersistenceComponents
- getJobResultStore() - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
- getJobResultStore() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the store that holds information about the state of finished jobs.
- getJobResultStore() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
- getJobs() - Method in class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
- getJobs() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
- getJobs() - Method in class org.apache.flink.runtime.taskexecutor.DefaultJobTable
- getJobs() - Method in interface org.apache.flink.runtime.taskexecutor.JobTable
-
Gets all registered jobs.
- getJobsPath() - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
- getJobState() - Method in class org.apache.flink.runtime.client.JobStatusMessage
- getJobStatus() - Method in exception org.apache.flink.runtime.messages.FlinkJobTerminatedWithoutCancellationException
- getJobStatus() - Method in class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview.JobIdWithStatus
- getJobStatus() - Method in class org.apache.flink.runtime.messages.webmonitor.JobStatusInfo
- getJobStatus() - Method in class org.apache.flink.runtime.minicluster.MiniClusterJobClient
- getJobStatus() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getJobStatus() - Method in class org.apache.flink.runtime.scheduler.adaptive.CreatingExecutionGraph
- getJobStatus(JobID) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- getJobStatusHooks() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
- getJobStatusHooks() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getJobsWithStatus() - Method in class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview
- getJobTable() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
- getJobTargetAddress() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotAllocationSnapshot
- getJobTerminationFuture() - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- getJobTerminationFuture() - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- getJobTerminationFuture() - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
- getJobTimeout() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
- getJobType() - Method in interface org.apache.flink.runtime.execution.Environment
- getJobType() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the
JobTypefor this execution graph. - getJobType() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
- getJobType() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getJobType() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
- getJobType() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
- getJobType() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getJobType() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getJobType() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getJobType() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
- getJobVertex() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- getJobVertex() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getJobVertex(JobVertexID) - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the job vertex for the given
JobVertexID. - getJobVertex(JobVertexID) - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
- getJobVertex(JobVertexID) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getJobVertex(JobVertexID) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- getJobVertex(JobVertexID) - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
- getJobVertexClass() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getJobvertexId() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getJobVertexId() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
- getJobVertexId() - Method in interface org.apache.flink.runtime.execution.Environment
-
Gets the ID of the JobVertex for which this task executes a parallel subtask.
- getJobVertexId() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
Returns the
JobVertexIDfor this job vertex. - getJobVertexId() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
- getJobVertexId() - Method in class org.apache.flink.runtime.executiongraph.ExecutionAttemptID
- getJobVertexId() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- getJobVertexId() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
- getJobVertexId() - Method in class org.apache.flink.runtime.jobmaster.event.ExecutionJobVertexInitializedEvent
- getJobVertexId() - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Returns the JobVertexID the KvState instances belong to.
- getJobVertexId() - Method in class org.apache.flink.runtime.scheduler.strategy.ExecutionVertexID
- getJobVertexId() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getJobVertexId() - Method in class org.apache.flink.runtime.taskmanager.Task
- getJobVertexID() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getJobVertexID() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- getJobVertexID() - Method in class org.apache.flink.runtime.scheduler.adaptive.allocator.JobAllocationsInformation.VertexAllocationInformation
- getJobVertexID() - Method in interface org.apache.flink.runtime.scheduler.adaptive.allocator.JobInformation.VertexInformation
- getJobVertexIds() - Method in class org.apache.flink.runtime.jobgraph.forwardgroup.ForwardGroup
- getJobVertexIds() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
- getJobVertexInfos() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getJobVertexInputInfo(JobVertexID, IntermediateDataSetID) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getJobVertexInputInfo(JobVertexID, IntermediateDataSetID) - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
-
Get the input info of a certain input of a certain job vertex.
- getJobVertexInputInfos() - Method in class org.apache.flink.runtime.executiongraph.ParallelismAndInputInfos
- getJobVertexInputInfos() - Method in class org.apache.flink.runtime.jobmaster.event.ExecutionJobVertexInitializedEvent
- getJobVertexMetrics() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- getJobVertexParallelisms() - Method in class org.apache.flink.runtime.jobgraph.JobResourceRequirements
- getJobVertexStats(JobID, AccessExecutionJobVertex) - Method in interface org.apache.flink.runtime.webmonitor.stats.VertexStatsTracker
-
Returns statistics for a job vertex.
- getJobVertexStats(JobID, AccessExecutionJobVertex) - Method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexThreadInfoTracker
- getJobVertices() - Method in class org.apache.flink.runtime.jobgraph.JobResourceRequirements
- getJobVerticesPerState() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getJson() - Method in class org.apache.flink.runtime.webmonitor.history.ArchivedJson
- getJSON() - Method in class org.apache.flink.streaming.api.graph.JSONGenerator
- getJsonPlan() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the job plan as a JSON string.
- getJsonPlan() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
- getJsonPlan() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getJsonPlan() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getJsonPlan() - Method in class org.apache.flink.runtime.rest.messages.JobPlanInfo
- getJvmDirectMemorySize() - Method in class org.apache.flink.runtime.util.config.memory.CommonProcessMemorySpec
- getJvmDirectMemorySize() - Method in interface org.apache.flink.runtime.util.config.memory.FlinkMemory
- getJvmDirectMemorySize() - Method in class org.apache.flink.runtime.util.config.memory.jobmanager.JobManagerFlinkMemory
- getJvmDirectMemorySize() - Method in interface org.apache.flink.runtime.util.config.memory.ProcessMemorySpec
- getJvmDirectMemorySize() - Method in class org.apache.flink.runtime.util.config.memory.taskmanager.TaskExecutorFlinkMemory
- getJvmHeapMemorySize() - Method in class org.apache.flink.runtime.util.config.memory.CommonProcessMemorySpec
- getJvmHeapMemorySize() - Method in interface org.apache.flink.runtime.util.config.memory.FlinkMemory
- getJvmHeapMemorySize() - Method in class org.apache.flink.runtime.util.config.memory.jobmanager.JobManagerFlinkMemory
- getJvmHeapMemorySize() - Method in interface org.apache.flink.runtime.util.config.memory.ProcessMemorySpec
- getJvmHeapMemorySize() - Method in class org.apache.flink.runtime.util.config.memory.taskmanager.TaskExecutorFlinkMemory
- getJvmMetaspace() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
-
Returns the maximum Metaspace size allowed for the task manager.
- getJvmMetaspaceAndOverhead() - Method in class org.apache.flink.runtime.util.config.memory.CommonProcessMemorySpec
- getJvmMetaspaceSize() - Method in class org.apache.flink.runtime.util.config.memory.CommonProcessMemorySpec
- getJvmMetaspaceSize() - Method in interface org.apache.flink.runtime.util.config.memory.ProcessMemorySpec
- getJvmOverhead() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
-
Returns the threshold for defining the maximum amount of memory used for the JVM overhead.
- getJvmOverheadSize() - Method in class org.apache.flink.runtime.util.config.memory.CommonProcessMemorySpec
- getJvmOverheadSize() - Method in interface org.apache.flink.runtime.util.config.memory.ProcessMemorySpec
- getJvmStartupOptions() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Gets the system parameters and environment parameters that were passed to the JVM on startup.
- getJvmStartupOptionsArray() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Gets the system parameters and environment parameters that were passed to the JVM on startup.
- getJvmVersion() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Gets the version of the JVM in the form "VM_Name - Vendor - Spec/Version".
- getKey() - Method in class org.apache.flink.runtime.asyncprocessing.RecordContext
- getKey() - Method in class org.apache.flink.runtime.io.network.partition.PartitionTrackerEntry
- getKey() - Method in class org.apache.flink.runtime.rest.messages.ConfigurationInfoEntry
- getKey() - Method in class org.apache.flink.runtime.rest.messages.job.FailureLabelFilterParameter.FailureLabel
- getKey() - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Returns the key of this parameter, e.g.
- getKey() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap.StateMapEntry
- getKey() - Method in interface org.apache.flink.runtime.state.Keyed
-
Returns the key attribute.
- getKey() - Method in class org.apache.flink.runtime.state.restore.KeyGroupEntry
- getKey() - Method in interface org.apache.flink.runtime.state.StateEntry
-
Returns the key of this entry.
- getKey() - Method in class org.apache.flink.runtime.state.StateEntry.SimpleStateEntry
- getKey() - Method in interface org.apache.flink.streaming.api.operators.InternalTimer
-
Returns the key that is bound to this timer.
- getKey() - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
- getKey(IN) - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ArrayKeySelector
- getKey(IN) - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ComparableKeySelector
- getKey(IN) - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.OneKeySelector
- getKeyAByKeyB(B) - Method in class org.apache.flink.runtime.util.DualKeyLinkedMap
- getKeyBByKeyA(A) - Method in class org.apache.flink.runtime.util.DualKeyLinkedMap
- getKeyContext() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- getKeyedStateBackend() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- getKeyedStateBackend() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- getKeyedStateBackend() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
- getKeyedStateManagedFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
- getKeyedStateRawFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
- getKeyedStateStore() - Method in interface org.apache.flink.runtime.state.ManagedInitializationContext
-
Returns an interface that allows for registering keyed state with the backend.
- getKeyedStateStore() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
- getKeyedStateStore() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- getKeyedStateStore() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- getKeyedStateStore() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
- getKeyedStateStoreV2() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
- getKeyedStateStreamFuture() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
- getKeyGroup() - Method in class org.apache.flink.runtime.asyncprocessing.RecordContext
- getKeyGroup() - Method in class org.apache.flink.runtime.state.changelog.StateChange
- getKeyGroupCompressionDecorator() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- getKeyGroupEntries() - Method in class org.apache.flink.runtime.state.restore.KeyGroup
- getKeyGroupId() - Method in class org.apache.flink.runtime.state.KeyGroupStatePartitionStreamProvider
-
Returns the key group that corresponds to the data in the provided stream.
- getKeyGroupId() - Method in class org.apache.flink.runtime.state.restore.KeyGroup
- getKeyGroupId(int) - Method in class org.apache.flink.runtime.state.KeyGroupRange
- getKeyGroupId(int) - Method in interface org.apache.flink.runtime.state.KeyGroupsList
-
Returns the id of the keygroup at the given index, where index in interval [0,
KeyGroupsList.getNumberOfKeyGroups()[. - getKeyGroupList() - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
-
Returns a list of all key-groups which can be written to this stream.
- getKeyGroupOffset() - Method in class org.apache.flink.runtime.state.heap.StateTable
- getKeyGroupOffset(int) - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
-
Returns the offset for the given key-group.
- getKeyGroupRange() - Method in class org.apache.flink.runtime.scheduler.adaptive.allocator.JobAllocationsInformation.VertexAllocationInformation
- getKeyGroupRange() - Method in class org.apache.flink.runtime.state.AbstractIncrementalStateHandle
- getKeyGroupRange() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- getKeyGroupRange() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl
- getKeyGroupRange() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendLocalHandle
- getKeyGroupRange() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateHandleStreamImpl
- getKeyGroupRange() - Method in class org.apache.flink.runtime.state.changelog.inmemory.InMemoryChangelogStateHandle
- getKeyGroupRange() - Method in interface org.apache.flink.runtime.state.CheckpointableKeyedStateBackend
-
Returns the key groups which this state backend is responsible for.
- getKeyGroupRange() - Method in interface org.apache.flink.runtime.state.FullSnapshotResources
-
Returns the
KeyGroupRangeof this snapshot. - getKeyGroupRange() - Method in interface org.apache.flink.runtime.state.InternalKeyContext
-
Returns the key groups for this backend.
- getKeyGroupRange() - Method in class org.apache.flink.runtime.state.InternalKeyContextImpl
- getKeyGroupRange() - Method in class org.apache.flink.runtime.state.KeyedStateBackendParametersImpl
- getKeyGroupRange() - Method in interface org.apache.flink.runtime.state.KeyedStateHandle
-
Returns the range of the key groups contained in the state.
- getKeyGroupRange() - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
- getKeyGroupRange() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
- getKeyGroupRange() - Method in interface org.apache.flink.runtime.state.StateBackend.KeyedStateBackendParameters
- getKeyGroupRange() - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
- getKeyGroupWriter() - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueStateSnapshot
- getKeyGroupWriter() - Method in interface org.apache.flink.runtime.state.StateSnapshot
-
This method returns
StateSnapshot.StateKeyGroupWriterand should be called in the asynchronous part of the snapshot. - getKeys(String, N) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
- getKeys(String, N) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
- getKeys(String, N) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
- getKeys(N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
- getKeys(N) - Method in class org.apache.flink.runtime.state.heap.StateMap
- getKeys(N) - Method in class org.apache.flink.runtime.state.heap.StateTable
- getKeysAndNamespaces() - Method in class org.apache.flink.runtime.state.heap.StateTable
- getKeysAndNamespaces(String) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
- getKeysAndNamespaces(String) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
- getKeysAndNamespaces(String) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
- getKeySelector() - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Gets the key selector that can get the key by which the stream if partitioned from the elements.
- getKeySelector() - Method in class org.apache.flink.streaming.api.transformations.KeyedBroadcastStateTransformation
- getKeySelector() - Method in class org.apache.flink.streaming.api.transformations.ReduceTransformation
- getKeySelector() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
- getKeySelector() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorFactory
- getKeySerializer() - Method in class org.apache.flink.runtime.query.KvStateInfo
- getKeySerializer() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- getKeySerializer() - Method in interface org.apache.flink.runtime.state.FullSnapshotResources
-
Returns key
TypeSerializer. - getKeySerializer() - Method in class org.apache.flink.runtime.state.heap.StateTable
- getKeySerializer() - Method in interface org.apache.flink.runtime.state.internal.InternalKvState
-
Returns the
TypeSerializerfor the type of key this state is associated to. - getKeySerializer() - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
- getKeySerializer() - Method in class org.apache.flink.runtime.state.KeyedStateBackendParametersImpl
- getKeySerializer() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
- getKeySerializer() - Method in interface org.apache.flink.runtime.state.StateBackend.KeyedStateBackendParameters
- getKeySerializer() - Method in class org.apache.flink.streaming.api.datastream.QueryableStateStream
-
Deprecated.Returns the key serializer for the queryable state instance.
- getKeySerializer() - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
- getKeySerializer() - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
- getKeySerializer() - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
- getKeySerializerSnapshot() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
- getKeySerializerSnapshot() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
- getKeytab() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
- getKeyType() - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Gets the type of the key by which the stream is partitioned.
- getKeyTypeInfo() - Method in class org.apache.flink.streaming.api.transformations.ReduceTransformation
- getKrb5LoginModuleName() - Static method in class org.apache.flink.runtime.security.KerberosUtils
- getKvState(KvStateID) - Method in class org.apache.flink.runtime.query.KvStateRegistry
-
Returns the
KvStateEntrycontaining the requested instance as identified by the given KvStateID, along with itsKvStateInfoornullif none is registered. - getKvStateClientProxy() - Method in class org.apache.flink.runtime.taskexecutor.KvStateService
- getKvStateId() - Method in class org.apache.flink.runtime.state.restore.KeyGroupEntry
- getKvStateID(int) - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Returns the registered KvStateID for the key group index or
nullif none is registered yet. - getKvStateLocation(String) - Method in class org.apache.flink.runtime.query.KvStateLocationRegistry
-
Returns the
KvStateLocationfor the registered KvState instance ornullif no location information is available. - getKvStateLocationOracle(JobID) - Method in interface org.apache.flink.runtime.query.KvStateClientProxy
-
Retrieves a future containing the currently leading key-value state location oracle.
- getKvStateLocationRegistry() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getKvStateLocationRegistry() - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- getKvStateRegistry() - Method in class org.apache.flink.runtime.state.KeyedStateBackendParametersImpl
- getKvStateRegistry() - Method in interface org.apache.flink.runtime.state.StateBackend.KeyedStateBackendParameters
- getKvStateRegistry() - Method in class org.apache.flink.runtime.taskexecutor.KvStateService
- getKvStateServer() - Method in class org.apache.flink.runtime.taskexecutor.KvStateService
- getKvStateServerAddress(int) - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Returns the registered server address for the key group index or
nullif none is registered yet. - getKvStateService() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
- getLast() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
-
Returns the last checkpoint ID (current - 1).
- getLastAccessTimestamp() - Method in class org.apache.flink.runtime.state.ttl.TtlValue
- getLastBufferOperationTimestamp() - Method in class org.apache.flink.runtime.io.disk.BatchShuffleReadBufferPool
- getLastBufferSize() - Method in class org.apache.flink.runtime.throughput.BufferDebloater
- getLastCheckpointedOffset() - Method in class org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
- getLastEstimatedTimeToConsume() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- getLastEstimatedTimeToConsumeBuffers() - Method in class org.apache.flink.runtime.throughput.BufferDebloater
- getLastHeartbeat() - Method in class org.apache.flink.runtime.heartbeat.DefaultHeartbeatMonitor
- getLastHeartbeat() - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatMonitor
-
Gets the last heartbeat.
- getLastHeartbeat() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- getLastHeartbeatFrom(ResourceID) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatManager
-
Returns the last received heartbeat from the given target.
- getLastHeartbeatFrom(ResourceID) - Method in class org.apache.flink.runtime.heartbeat.NoOpHeartbeatManager
- getLastOutputCollector() - Method in class org.apache.flink.runtime.operators.BatchTask
- getLastState() - Method in class org.apache.flink.runtime.checkpoint.DefaultLastStateConnectionStateListener
- getLastState() - Method in interface org.apache.flink.runtime.checkpoint.LastStateConnectionStateListener
-
Return the last state the listener was notified about.
- getLastTasksConfig() - Method in class org.apache.flink.runtime.operators.BatchTask
- getLastUpdateTime() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
- getLastUpdateTime() - Method in interface org.apache.flink.runtime.rest.handler.legacy.metrics.MetricFetcher
- getLastUpdateTime() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricFetcherImpl
- getLastUpdateTime() - Method in enum org.apache.flink.runtime.rest.handler.legacy.metrics.VoidMetricFetcher
- getLastUsedCheckpointID() - Method in class org.apache.flink.runtime.checkpoint.filemerging.LogicalFile
- getLatencyTrackingStateConfig() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the latest acknowledged subtask stats or
nullif none was acknowledged yet. - getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
- getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
- getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
- getLatestAckTimestamp() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the ack timestamp of the latest acknowledged subtask or
-1if none was acknowledged yet. - getLatestAckTimestamp() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
- getLatestAckTimestamp() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- getLatestAckTimestamp() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
- getLatestCheckpoint() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
Returns the latest
CompletedCheckpointinstance ornullif none was added. - getLatestCheckpointId() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
Returns the id of the latest completed checkpoints.
- getLatestCheckpointId() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
- getLatestCheckpointId() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierTracker
- getLatestCheckpointId() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
- getLatestCheckpoints() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
- getLatestCompletedCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
- getLatestFailedCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
- getLatestRestoredCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
-
Returns the latest restored checkpoint.
- getLatestSavepoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
- getLatestVersion(Collection<E>) - Static method in interface org.apache.flink.runtime.rest.versioning.RestAPIVersion
-
Accept versions and one of them as a comparator, and get the latest one.
- getLeaderAddress() - Method in class org.apache.flink.runtime.leaderelection.LeaderInformation
- getLeaderAddressFuture() - Method in class org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess
- getLeaderAddressFuture() - Method in enum org.apache.flink.runtime.dispatcher.runner.StoppedDispatcherLeaderProcess
- getLeaderAddressFuture() - Method in class org.apache.flink.runtime.jobmaster.DefaultJobMasterServiceProcess
- getLeaderAddressFuture() - Method in interface org.apache.flink.runtime.jobmaster.JobMasterServiceProcess
-
Future which is completed with the
JobMasterServiceaddress once it is created. - getLeaderAddressFuture() - Method in enum org.apache.flink.runtime.jobmaster.JobMasterServiceProcess.WaitingForLeadership
- getLeaderFuture() - Method in class org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
-
Returns the current JobManagerGateway future.
- getLeaderId(JobID) - Method in class org.apache.flink.runtime.resourcemanager.DefaultJobLeaderIdService
- getLeaderId(JobID) - Method in interface org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
Get the leader's
JobMasterIdfuture for the given job. - getLeaderInformationFuture() - Method in class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderInformationListener
- getLeaderLatchPath() - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
- getLeaderNow() - Method in class org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
-
Returns the current leader information if available.
- getLeaderPath() - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
- getLeaderPath(String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
- getLeaderPathForDispatcher() - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
-
Get the leader path for Dispatcher.
- getLeaderPathForDispatcher() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperLeaderElectionHaServices
- getLeaderPathForJob(JobID) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
- getLeaderPathForJobManager(JobID) - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
-
Get the leader path for specific JobManager.
- getLeaderPathForJobManager(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperLeaderElectionHaServices
- getLeaderPathForResourceManager() - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
-
Get the leader path for ResourceManager.
- getLeaderPathForResourceManager() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperLeaderElectionHaServices
- getLeaderPathForRestServer() - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
-
Get the leader path for RestServer.
- getLeaderPathForRestServer() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperLeaderElectionHaServices
- getLeaderResourceManager() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerServiceImpl
- getLeaderSessionId() - Method in class org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess
- getLeaderSessionId() - Method in enum org.apache.flink.runtime.dispatcher.runner.StoppedDispatcherLeaderProcess
- getLeaderSessionId() - Method in class org.apache.flink.runtime.jobmaster.DefaultJobMasterServiceProcess
- getLeaderSessionId() - Method in interface org.apache.flink.runtime.jobmaster.JobMasterServiceProcess
-
The leader session id of this process.
- getLeaderSessionId() - Method in enum org.apache.flink.runtime.jobmaster.JobMasterServiceProcess.WaitingForLeadership
- getLeaderSessionID() - Method in class org.apache.flink.runtime.leaderelection.LeaderInformation
- getLeaderSessionID(String) - Method in class org.apache.flink.runtime.leaderelection.DefaultLeaderElectionService
-
Returns the current leader session ID for the given
componentIdornull, if the session wasn't confirmed. - getLeftTimestamp() - Method in class org.apache.flink.streaming.api.functions.co.ProcessJoinFunction.Context
- getLegacyTransformation() - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
- getLength() - Method in class org.apache.flink.runtime.checkpoint.filemerging.LogicalFile
- getLength() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileSegment
- getLength() - Method in class org.apache.flink.runtime.io.network.buffer.BufferHeader
- getLength() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
- getLength() - Method in class org.apache.flink.runtime.state.ChainedStateHandle
-
Returns the length of the operator chain.
- getLength() - Method in class org.apache.flink.runtime.state.JavaSerializer
- getLength() - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
- getLength() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
- getLength() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
- getLength() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
- getLength() - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
- getLength() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
- getLength() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
- getLength() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
- getLibraryCacheManager() - Method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
- getLibraryCacheManager() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.FileChannelInputView
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.HeaderlessChannelReaderInputView
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.RandomAccessInputView
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Gets the limit for reading bytes from the given memory segment.
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
- getLineageGraph() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getLineageVertex() - Method in class org.apache.flink.streaming.api.functions.source.legacy.FromElementsFunction
-
Deprecated.
- getLineageVertex() - Method in interface org.apache.flink.streaming.api.lineage.LineageVertexProvider
- getLineageVertex() - Method in class org.apache.flink.streaming.api.transformations.TransformationWithLineage
-
Returns the lineage vertex of this
Transformation. - getListenerManagers() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
- getListState(ListStateDescriptor<S>) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
- getListState(ListStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
- getListState(ListStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
- getListState(ListStateDescriptor<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
- getListState(ListStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.v2.DefaultKeyedStateStoreV2
- getListState(ListStateDescriptor<T>) - Method in interface org.apache.flink.runtime.state.v2.KeyedStateStoreV2
-
Gets a handle to the system's key / value list state.
- getListState(ListStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
- getLocality() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Gets the locality of this slot.
- getLocality() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
- getLocality() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSelectionStrategy.SlotInfoAndLocality
- getLocalPath() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle.HandleAndLocalPath
- getLocalRecoveryConfig() - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
- getLocalRecoveryConfig() - Method in class org.apache.flink.runtime.state.NoOpTaskLocalStateStoreImpl
- getLocalRecoveryConfig() - Method in interface org.apache.flink.runtime.state.TaskLocalStateStore
-
Returns the
LocalRecoveryConfigfor this task local state store. - getLocalRecoveryConfig() - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
- getLocalRecoveryDirectoryProvider() - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
- getLocalStateDirectory() - Method in class org.apache.flink.runtime.entrypoint.WorkingDirectory
- getLocalStateDirectoryProvider() - Method in class org.apache.flink.runtime.state.LocalRecoveryConfig
- getLocalTaskOwnedDirectory(LocalSnapshotDirectoryProvider, JobID) - Static method in class org.apache.flink.runtime.state.ChangelogTaskLocalStateStore
- getLocation() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointInfo
- getLocationConstraint(int) - Method in interface org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
-
Returns the
CoLocationConstraintfor a specificsubTaskIndex. - getLocationConstraint(int) - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroupImpl
- getLocationReference() - Method in interface org.apache.flink.runtime.state.CheckpointStorageLocation
-
Gets a reference to the storage location.
- getLocationReference() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
- getLocationReference() - Method in class org.apache.flink.runtime.state.memory.NonPersistentMetadataCheckpointStorageLocation
- getLocationReference() - Method in class org.apache.flink.runtime.state.memory.PersistentMetadataCheckpointStorageLocation
- getLogicalFile(LogicalFile.LogicalFileId) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
- getLogicalFileId() - Method in class org.apache.flink.runtime.state.filemerging.SegmentFileStateHandle
- getLogicalScope(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Returns the logical scope of this group, for example
"taskmanager.job.task". - getLogicalScope(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
- getLogicalScope(CharacterFilter, char) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Returns the logical scope of this group, for example
"taskmanager.job.task". - getLogicalScope(CharacterFilter, char) - Method in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
- getLoginContextNames() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
- getLogInfos() - Method in class org.apache.flink.runtime.rest.messages.LogListInfo
- getLoopTimeout(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getLowerBound() - Method in class org.apache.flink.runtime.jobgraph.JobVertexResourceRequirements.Parallelism
- getMailboxExecutor() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
-
Provides the mailbox executor iff this factory implements
YieldingOperatorFactory. - getMailboxExecutor() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorParameters
- getMailboxExecutor(int) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
Returns an executor service facade to submit actions to the mailbox.
- getMailboxExecutorFactory() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- getMailboxLatency() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- getMailboxMetricsControl() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
Gets
MailboxMetricsControllerfor control and access to mailbox metrics. - getMailboxSize() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- getMailboxThroughput() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- getMailCounter() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
-
Gets
Counterfor number of mails processed. - getMailOptions() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.Mail
- getMainExecutor() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointPlanCalculatorContext
-
Acquires the main thread executor for this job.
- getMainExecutor() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraphCheckpointPlanCalculatorContext
- getMainMailboxExecutor() - Method in interface org.apache.flink.runtime.execution.Environment
- getMainMailboxExecutor() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getMainMailboxExecutor() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
- getMainOperator() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- getMainOperatorOutput() - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
- getMainOperatorOutput() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- getMainThreadExecutor() - Method in class org.apache.flink.runtime.resourcemanager.active.AbstractResourceManagerDriver
- getMainThreadExecutor() - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- getMainThreadExecutor() - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.BatchJobRecoveryContext
-
Provides the main thread executor.
- getMainThreadExecutor() - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- getManaged() - Method in class org.apache.flink.runtime.util.config.memory.taskmanager.TaskExecutorFlinkMemory
- getManagedDir(FileMergingSnapshotManager.SubtaskKey, CheckpointedStateScope) - Method in interface org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager
-
Get the managed directory of the file-merging snapshot manager, created in
FileMergingSnapshotManager.initFileSystem(org.apache.flink.core.fs.FileSystem, org.apache.flink.core.fs.Path, org.apache.flink.core.fs.Path, org.apache.flink.core.fs.Path, int)orFileMergingSnapshotManager.registerSubtaskForSharedStates(org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager.SubtaskKey). - getManagedDir(FileMergingSnapshotManager.SubtaskKey, CheckpointedStateScope) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
- getManagedDirName() - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager.SubtaskKey
-
Generate an unique managed directory name for one subtask.
- getManagedDirStateHandle(FileMergingSnapshotManager.SubtaskKey, CheckpointedStateScope) - Method in interface org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager
-
Get the
DirectoryStreamStateHandleof the managed directory, created inFileMergingSnapshotManager.initFileSystem(org.apache.flink.core.fs.FileSystem, org.apache.flink.core.fs.Path, org.apache.flink.core.fs.Path, org.apache.flink.core.fs.Path, int)orFileMergingSnapshotManager.registerSubtaskForSharedStates(org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager.SubtaskKey). - getManagedDirStateHandle(FileMergingSnapshotManager.SubtaskKey, CheckpointedStateScope) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
- getManagedKeyedState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
- getManagedKeyedState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
Deprecated.
- getManagedKeyedStateHandles(OperatorState, KeyGroupRange) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
-
Collect
managedKeyedStateHandleswhich have intersection with givenKeyGroupRangefromoperatorState. - getManagedMB() - Method in class org.apache.flink.runtime.rest.messages.ResourceProfileInfo
- getManagedMemory() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the managed memory needed.
- getManagedMemoryFraction() - Method in class org.apache.flink.runtime.state.KeyedStateBackendParametersImpl
- getManagedMemoryFraction() - Method in interface org.apache.flink.runtime.state.StateBackend.KeyedStateBackendParameters
- getManagedMemoryFractionOperatorUseCaseOfSlot(ManagedMemoryUseCase, Configuration, Configuration, ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
Fraction of total managed memory in the slot that this operator should use for the given use case.
- getManagedMemoryOperatorScopeUseCaseWeights() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getManagedMemorySize() - Method in class org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
- getManagedMemorySize() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorResourceSpec
- getManagedMemorySize() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
- getManagedMemorySize() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
- getManagedMemorySlotScopeUseCases() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getManagedMemoryTotal() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
-
Returns the total amount of memory reserved for by the MemoryManager.
- getManagedMemSize() - Method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec
- getManagedOperatorState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
- getManagedOperatorState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
Deprecated.
- getMapForKeyGroup(int) - Method in class org.apache.flink.runtime.state.heap.StateTable
- getMappedIndexes(int) - Method in class org.apache.flink.runtime.checkpoint.RescaleMappings
- getMapState(MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
- getMapState(MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
- getMapState(MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
- getMapState(MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.runtime.state.v2.DefaultKeyedStateStoreV2
- getMapState(MapStateDescriptor<UK, UV>) - Method in interface org.apache.flink.runtime.state.v2.KeyedStateStoreV2
-
Gets a handle to the system's key/value map state.
- getMapState(MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
- getMarkedTime() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
-
Returns the timestamp marked by the LatencyMarker.
- getMarkPartitionFinishedStrategy() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getMarkPartitionFinishedStrategy() - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
- getMarkPartitionFinishedStrategy() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.AdaptiveBatchScheduler
- getMarkPartitionFinishedStrategy() - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- getMasterAgentMemorySpec() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskTierFactory
- getMasterAgentMemorySpec() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory.MemoryTierFactory
- getMasterAgentMemorySpec() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierFactory
- getMasterAgentMemorySpec() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierFactory
-
Get the
TieredStorageMemorySpecof the master-side agent. - getMasterHooks() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
- getMasterHookStates() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
- getMasterStates() - Method in class org.apache.flink.runtime.checkpoint.metadata.CheckpointMetadata
- getMasterStates() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
- getMatchesFor(PT) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
- getMatchFor(PT) - Method in class org.apache.flink.runtime.operators.hash.AbstractHashTableProber
- getMatchFor(PT) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable.HashTableProber
- getMatchFor(PT) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
- getMatchFor(PT, BT) - Method in class org.apache.flink.runtime.operators.hash.AbstractHashTableProber
- getMatchFor(PT, T) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable.HashTableProber
- getMatchFor(PT, T) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
-
Searches the hash table for the record with the given key.
- getMaterializationID() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl
- getMaterializationID() - Method in interface org.apache.flink.runtime.state.changelog.ChangelogStateBackendHandle
- getMaterializationID() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendLocalHandle
- getMaterializedStateHandles() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl
- getMaterializedStateHandles() - Method in interface org.apache.flink.runtime.state.changelog.ChangelogStateBackendHandle
- getMaterializedStateHandles() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendLocalHandle
- getMax() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
- getMax() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
- getMaxBufferSize() - Method in class org.apache.flink.runtime.throughput.BufferDebloatConfiguration
- getMaxBuffersPerChannel() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- getMaxCapacity() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Returns the maximum size of the buffer, i.e. the capacity of the underlying
MemorySegment. - getMaxCapacity() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
- getMaxCapacity() - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- getMaxCapacity() - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- getMaxCapacity() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- getMaxCapacity() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- getMaxCompressedSize(int) - Method in class org.apache.flink.runtime.io.compression.AirBlockCompressor
- getMaxCompressedSize(int) - Method in interface org.apache.flink.runtime.io.compression.BlockCompressor
-
Get the max compressed size for a given original size.
- getMaxCompressedSize(int) - Method in class org.apache.flink.runtime.io.compression.Lz4BlockCompressor
- getMaxConcurrentCheckpoints() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
- getMaxConcurrentCheckpoints() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the maximum number of checkpoint attempts that may be in progress at the same time.
- getMaxConcurrentCheckpoints() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getMaxConcurrentRequests() - Method in class org.apache.flink.runtime.io.disk.BatchShuffleReadBufferPool
- getMaxContentLength() - Method in class org.apache.flink.runtime.rest.RestClientConfiguration
-
Returns the max content length that the REST client endpoint could handle.
- getMaxContentLength() - Method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
-
Returns the max content length that the REST server endpoint could handle.
- getMaxDepth(int) - Static method in class org.apache.flink.runtime.operators.sort.QuickSort
-
Deepest recursion before giving up and doing a heapsort.
- getMaximum() - Method in class org.apache.flink.runtime.checkpoint.StatsSummary
-
Returns the maximum seen value.
- getMaximum() - Method in class org.apache.flink.runtime.checkpoint.StatsSummarySnapshot
-
Returns the maximum seen value.
- getMaximum() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.StatsSummaryDto
- getMaximumDelayForTriggeringRescale() - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler.Settings
- getMaximumNumberOfRetainedCheckpoints(Configuration, Logger) - Static method in class org.apache.flink.runtime.checkpoint.DefaultCompletedCheckpointStoreUtils
-
Extracts maximum number of retained checkpoints configuration from the passed
Configuration. - getMaximumParallelism() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Gets the maximum parallelism of all operations in this job graph.
- getMaxJvmHeapMemory() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
The maximum JVM heap size, in bytes.
- getMaxNonReclaimableBuffers(Object) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemoryManager
-
Return the number of the non-reclaimable buffers for the owner.
- getMaxNonReclaimableBuffers(Object) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemoryManagerImpl
- getMaxNumberOfMemorySegments() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
Returns the maximum number of memory segments this buffer pool should use.
- getMaxNumberOfMemorySegments() - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
- getMaxNumberOfRetainedCheckpoints() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
Returns the max number of retained checkpoints.
- getMaxNumberOfRetainedCheckpoints() - Method in enum org.apache.flink.runtime.checkpoint.DeactivatedCheckpointCompletedCheckpointStore
- getMaxNumberOfRetainedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.DefaultCompletedCheckpointStore
- getMaxNumberOfRetainedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.EmbeddedCompletedCheckpointStore
- getMaxNumberOfRetainedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
- getMaxNumberOfSubtasks() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
- getMaxOverdraftBuffersPerGate() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
Returns the max overdraft buffer size of per gate.
- getMaxOverdraftBuffersPerGate() - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
- getMaxOverdraftBuffersPerGate() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- getMaxParallelism() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- getMaxParallelism() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getMaxParallelism() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
- getMaxParallelism() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
Returns the max parallelism for this job vertex.
- getMaxParallelism() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
- getMaxParallelism() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- getMaxParallelism() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getMaxParallelism() - Method in class org.apache.flink.runtime.jobgraph.forwardgroup.ForwardGroup
- getMaxParallelism() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Gets the maximum parallelism for the task.
- getMaxParallelism() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getMaxParallelism() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- getMaxParallelism() - Method in interface org.apache.flink.runtime.scheduler.adaptive.allocator.JobInformation.VertexInformation
- getMaxParallelism() - Method in class org.apache.flink.runtime.scheduler.DefaultVertexParallelismInfo
- getMaxParallelism() - Method in interface org.apache.flink.runtime.scheduler.VertexParallelismInformation
-
Returns the vertex's max parallelism.
- getMaxParallelism() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the maximum degree of parallelism defined for the program.
- getMaxParallelism() - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
- getMaxRegistrationDuration() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
- getMaxRegistrationTimeoutMillis() - Method in class org.apache.flink.runtime.registration.RetryingRegistrationConfiguration
- getMaxSingleMeasurement() - Method in class org.apache.flink.runtime.metrics.TimerGauge
- getMaxSize() - Method in class org.apache.flink.runtime.util.config.memory.RangeFraction
- getMaxSlotNum() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
- getMaxStackTraceDepth() - Method in class org.apache.flink.runtime.webmonitor.threadinfo.ThreadInfoSamplesRequest
-
Returns the configured maximum depth of the collected stack traces.
- getMaxStateSize() - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorageAccess
-
Gets the size (in bytes) that a individual chunk of state may have at most.
- getMaxStateSize() - Method in class org.apache.flink.runtime.state.storage.JobManagerCheckpointStorage
-
Gets the maximum size that an individual state can have, as configured in the constructor (by default 5242880).
- getMaxSubtasksPerChannelStateFile() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
- getMaxSubtasksPerChannelStateFile() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getMaxTotalCpu() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
- getMaxTotalMem() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
- getMaxWatermark() - Method in class org.apache.flink.runtime.source.event.WatermarkAlignmentEvent
- getMean() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
- getMemoryConfiguration() - Method in class org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
- getMemoryConfiguration() - Method in class org.apache.flink.runtime.resourcemanager.TaskExecutorRegistration
- getMemoryConfiguration() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- getMemoryManager() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the current
MemoryManager. - getMemoryManager() - Method in class org.apache.flink.runtime.operators.BatchTask
- getMemoryManager() - Method in interface org.apache.flink.runtime.operators.TaskContext
- getMemoryManager() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
- getMemoryManager() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getMemoryPoolStatsAsString(List<MemoryPoolMXBean>) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
-
Gets the memory pool statistics from the JVM.
- getMemorySegment() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Deprecated.
- getMemorySegment() - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- getMemorySegment() - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- getMemorySegment() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- getMemorySegment() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
Returns the underlying memory segment.
- getMemorySegmentOffset() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Deprecated.
- getMemorySegmentOffset() - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- getMemorySegmentOffset() - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- getMemorySegmentOffset() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- getMemorySegmentOffset() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- getMemorySize() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Returns the total size of memory handled by this memory manager.
- getMemorySizeFromConfig(Configuration, ConfigOption<MemorySize>) - Static method in class org.apache.flink.runtime.util.config.memory.ProcessMemoryUtils
- getMemoryTierName() - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageUtils
- getMemoryUsageStatsAsString(MemoryMXBean) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
-
Gets the memory footprint of the JVM in a string representation.
- getMergingWindowSet() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Retrieves the
MergingWindowSetfor the currently active key. - getMessage() - Method in class org.apache.flink.runtime.rest.messages.ProfilingInfo
- getMessageHeaders() - Method in class org.apache.flink.runtime.rest.handler.AbstractRestHandler
- getMetadata() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceID
- getMetadataFilePath() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
- getMetadataHandle() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
- getMetadataHandle() - Method in interface org.apache.flink.runtime.state.CompletedCheckpointStorageLocation
-
Gets the state handle to the checkpoint's metadata.
- getMetadataHandle() - Method in class org.apache.flink.runtime.state.filesystem.FsCompletedCheckpointStorageLocation
- getMetaDataStateHandle() - Method in class org.apache.flink.runtime.state.AbstractIncrementalStateHandle
- getMetaDataStateHandle() - Method in interface org.apache.flink.runtime.state.IncrementalKeyedStateHandle
- getMetaInfo() - Method in class org.apache.flink.runtime.io.network.partition.PartitionTrackerEntry
- getMetaInfo() - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueSnapshotRestoreWrapper
- getMetaInfo() - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueStateSnapshot
- getMetaInfo() - Method in class org.apache.flink.runtime.state.heap.StateTable
- getMetaInfoSnapshot() - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueStateSnapshot
- getMetaInfoSnapshot() - Method in interface org.apache.flink.runtime.state.StateSnapshot
-
Returns a snapshot of the state's meta data.
- getMetaInfoSnapshots() - Method in interface org.apache.flink.runtime.state.FullSnapshotResources
-
Returns the list of
meta info snapshotsfor this state snapshot. - getMetaspace() - Method in class org.apache.flink.runtime.util.config.memory.JvmMetaspaceAndOverhead
- getMetric(String) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.ComponentMetricStore
- getMetric(String, String) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.ComponentMetricStore
- getMetricGroup() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the task specific metric group.
- getMetricGroup() - Method in class org.apache.flink.runtime.failure.DefaultFailureEnricherContext
- getMetricGroup() - Method in class org.apache.flink.runtime.operators.BatchTask
- getMetricGroup() - Method in interface org.apache.flink.runtime.operators.TaskContext
- getMetricGroup() - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- getMetricGroup() - Method in class org.apache.flink.runtime.state.KeyedStateBackendParametersImpl
- getMetricGroup() - Method in class org.apache.flink.runtime.state.metrics.LatencyTrackingStateConfig
- getMetricGroup() - Method in interface org.apache.flink.runtime.state.StateBackend.KeyedStateBackendParameters
- getMetricGroup() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getMetricGroup() - Method in class org.apache.flink.runtime.taskmanager.Task
- getMetricGroup() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- getMetricGroup() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- getMetricGroup() - Method in class org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarksContext
- getMetricGroup() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
- getMetricGroup() - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor.EvictorContext
-
Returns the metric group for this
Evictor. - getMetricGroup() - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Returns the metric group for this
Trigger. - getMetricGroup() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
- getMetricIdentifier(String) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Returns the fully qualified metric name, for example
"host-7.taskmanager-2.window_word_count.my-mapper.metricName". - getMetricIdentifier(String) - Method in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
- getMetricIdentifier(String) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
- getMetricIdentifier(String, CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Returns the fully qualified metric name, for example
"host-7.taskmanager-2.window_word_count.my-mapper.metricName". - getMetricIdentifier(String, CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
- getMetricIdentifier(String, CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
- getMetricIdentifier(String, CharacterFilter, int, char) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Returns the fully qualified metric name using the configured delimiter for the reporter with the given index, for example
"host-7.taskmanager-2.window_word_count.my-mapper.metricName". - getMetricQueryServiceAddress() - Method in class org.apache.flink.runtime.dispatcher.DispatcherServices
- getMetricQueryServiceAddress() - Method in class org.apache.flink.runtime.dispatcher.PartialDispatcherServices
- getMetricQueryServiceGatewayRpcAddress() - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
-
Returns the gateway of the
MetricQueryServiceor null, if none is started. - getMetricQueryServiceGatewayRpcAddress() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
Returns the address under which the
MetricQueryServiceis reachable. - getMetricQueryServiceRpcService() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
Returns the rpc service that the
MetricQueryServiceruns in. - getMetricRegistry() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerProcessContext
- getMetrics() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetricsResponseBody
- getMetrics() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricCollectionResponseBody
- getMetricsIfPartitionOccupyingLocalResource(ResultPartitionID) - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
- getMetricsIfPartitionOccupyingLocalResource(ResultPartitionID) - Method in interface org.apache.flink.runtime.shuffle.ShuffleEnvironment
-
Get metrics of the partition if it still occupies some resources locally and have not been released yet.
- getMetricsOfPartition(ResultPartitionID) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
- getMetricStore() - Method in interface org.apache.flink.runtime.rest.handler.legacy.metrics.MetricFetcher
-
Get
MetricStorewhich contains all currently fetched metrics. - getMetricStore() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricFetcherImpl
-
Returns the MetricStore containing all stored metrics.
- getMetricStore() - Method in enum org.apache.flink.runtime.rest.handler.legacy.metrics.VoidMetricFetcher
- getMimeTypeForExtension(String) - Static method in class org.apache.flink.runtime.rest.handler.util.MimeTypes
-
Gets the MIME type for the file with the given extension.
- getMimeTypeForFileName(String) - Static method in class org.apache.flink.runtime.rest.handler.util.MimeTypes
-
Gets the MIME type for the file with the given name, by extension.
- getMin() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
- getMin() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
- getMinBufferSize() - Method in class org.apache.flink.runtime.throughput.BufferDebloatConfiguration
- getMinBuffersPerGate() - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageUtils
-
Get the number of minimum buffers per input gate.
- getMinBuffersPerResultPartition() - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageUtils
-
*
- getMinFileSizeThreshold() - Method in class org.apache.flink.runtime.state.storage.FileSystemCheckpointStorage
-
Gets the threshold below which state is stored as part of the metadata, rather than in files.
- getMinimum() - Method in class org.apache.flink.runtime.checkpoint.StatsSummary
-
Returns the minimum seen value.
- getMinimum() - Method in class org.apache.flink.runtime.checkpoint.StatsSummarySnapshot
-
Returns the minimum seen value.
- getMinimum() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.StatsSummaryDto
- getMinMaxFloatingBuffersPerInputGate(int) - Static method in class org.apache.flink.runtime.shuffle.NettyShuffleUtils
-
Calculates and returns the floating network buffer pool size used by the input gate.
- getMinMaxNetworkBuffersPerResultPartition(int, int, int, int, int, boolean, int, ResultPartitionType) - Static method in class org.apache.flink.runtime.shuffle.NettyShuffleUtils
-
Calculates and returns local network buffer pool size used by the result partition.
- getMinOffloadingSize() - Method in class org.apache.flink.runtime.blob.BlobServer
-
Returns the configuration used by the BLOB server.
- getMinOffloadingSize() - Method in interface org.apache.flink.runtime.blob.BlobWriter
-
Returns the min size before data will be offloaded to the BLOB store.
- getMinOffloadingSize() - Method in class org.apache.flink.runtime.blob.VoidBlobWriter
- getMinParallelism() - Method in interface org.apache.flink.runtime.scheduler.adaptive.allocator.JobInformation.VertexInformation
- getMinParallelism() - Method in class org.apache.flink.runtime.scheduler.DefaultVertexParallelismInfo
- getMinParallelism() - Method in interface org.apache.flink.runtime.scheduler.VertexParallelismInformation
-
Returns a vertex's min parallelism.
- getMinPauseBetweenCheckpoints() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
- getMinPauseBetweenCheckpoints() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Gets the minimal pause between checkpointing attempts.
- getMinResources() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Gets the minimum resource for the task.
- getMinResources() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Gets the minimum resources for this operator.
- getMinResources() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getMinSize() - Method in class org.apache.flink.runtime.util.config.memory.RangeFraction
- getMinSlotNum() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
- getMinTotalCpu() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
- getMinTotalMem() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
- getMissingResources() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.DefaultResourceTracker
- getMissingResources() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ResourceTracker
-
Returns a collection of
ResourceRequirementsthat describe which resources the corresponding job is missing. - getMode() - Method in class org.apache.flink.runtime.rest.messages.cluster.ProfilingRequestBody
- getModificationTime() - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
- getModificationTime() - Method in interface org.apache.flink.streaming.api.functions.source.TimestampedInputSplit
- getMtime() - Method in class org.apache.flink.runtime.rest.messages.LogInfo
- getMultipartFileUploads(ChannelHandlerContext) - Static method in class org.apache.flink.runtime.rest.FileUploadHandler
- getMutex() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor
-
Deprecated.
- getName() - Method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
- getName() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
- getName() - Method in class org.apache.flink.runtime.checkpoint.CheckpointType
- getName() - Method in class org.apache.flink.runtime.checkpoint.SavepointType
- getName() - Method in interface org.apache.flink.runtime.checkpoint.SnapshotType
- getName() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
Returns the name for this job vertex.
- getName() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
- getName() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- getName() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns the name assigned to the job graph.
- getName() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns the name of the vertex.
- getName() - Method in class org.apache.flink.runtime.metrics.ReporterSetup
- getName() - Method in class org.apache.flink.runtime.metrics.TraceReporterSetup
- getName() - Method in class org.apache.flink.runtime.rest.handler.router.RouterHandler
- getName() - Method in class org.apache.flink.runtime.rest.HttpHeader
-
Returns the name of this HTTP header.
- getName() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getName() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- getName() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
- getName() - Method in class org.apache.flink.runtime.rest.messages.LogInfo
- getName() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
- getName() - Method in class org.apache.flink.runtime.scheduler.adaptive.JobGraphJobInformation
- getName() - Method in interface org.apache.flink.runtime.state.delegate.DelegatingStateBackend
- getName() - Method in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
- getName() - Method in class org.apache.flink.runtime.state.RegisteredStateMetaInfoBase
- getName() - Method in interface org.apache.flink.runtime.state.StateBackend
-
Return the name of this backend, default is simple class name.
- getName() - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Gets the name of the current data stream.
- getName() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Gets the name of the task, in the form "taskname (2/5)".
- getNamespace() - Method in class org.apache.flink.runtime.asyncprocessing.StateRequest
- getNamespace() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap.StateMapEntry
- getNamespace() - Method in interface org.apache.flink.runtime.state.StateEntry
-
Returns the namespace of this entry.
- getNamespace() - Method in class org.apache.flink.runtime.state.StateEntry.SimpleStateEntry
- getNamespace() - Method in interface org.apache.flink.streaming.api.operators.InternalTimer
-
Returns the namespace that is bound to this timer.
- getNamespace() - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
- getNamespace(InternalPartitionedState<N>) - Method in class org.apache.flink.runtime.asyncprocessing.RecordContext
- getNamespaceSerializer() - Method in class org.apache.flink.runtime.query.KvStateInfo
- getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.heap.StateTable
- getNamespaceSerializer() - Method in interface org.apache.flink.runtime.state.internal.InternalKvState
-
Returns the
TypeSerializerfor the type of namespace this state is associated to. - getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
- getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.v2.RegisteredKeyValueStateBackendMetaInfo
- getNamespaceSerializer() - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
- getNamespaceSerializer() - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
- getNamespaceSerializerSnapshot() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
- getNestedSerializers(ArrayListSerializer<T>) - Method in class org.apache.flink.runtime.state.ArrayListSerializerSnapshot
- getNestedSerializers(TtlStateFactory.TtlSerializer<T>) - Method in class org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializerSnapshot
- getNestedSerializers(CoGroupedStreams.UnionSerializer<T1, T2>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerSnapshot
- getNestedSerializers(IntervalJoinOperator.BufferEntrySerializer<T>) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializerSnapshot
- getNestedSerializers(TimerSerializer<K, N>) - Method in class org.apache.flink.streaming.api.operators.TimerSerializerSnapshot
- getNestedSerializers(StreamElementSerializer<T>) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerSnapshot
- getNestedTrigger() - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
- getNetRuntime() - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
- getNetRuntime() - Method in class org.apache.flink.runtime.jobmaster.JobResult
- getNetRuntime(TimeUnit) - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
-
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.
- getNettyConnectionId() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyConnectionWriter
-
Get the id of connection in the writer.
- getNettyConnectionId() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyConnectionWriterImpl
- getNettyHttpMethod() - Method in enum org.apache.flink.runtime.rest.HttpMethodWrapper
- getNetwork() - Method in class org.apache.flink.runtime.util.config.memory.taskmanager.TaskExecutorFlinkMemory
- getNetworkBufferPool() - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
- getNetworkBuffersPerInputChannel(int) - Static method in class org.apache.flink.runtime.shuffle.NettyShuffleUtils
-
Calculates and returns the number of required exclusive network buffers per input channel.
- getNetworkInterfaceNames() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
- getNetworkMB() - Method in class org.apache.flink.runtime.rest.messages.ResourceProfileInfo
- getNetworkMemory() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the network memory needed.
- getNetworkMemory() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
-
Returns the configured maximum network memory.
- getNetworkMemorySize() - Method in class org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
- getNetworkMemorySize() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
- getNetworkMemSize() - Method in class org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
- getNetworkMemSize() - Method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec
- getNetworkMemSize() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorResourceSpec
- getNetworkRetries() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
- getNewInMemoryPartition(int, int) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Returns a new inMemoryPartition object.
- getNewInMemoryPartition(int, int) - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
- getNewIterationNodeId() - Static method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
- getNewToOldSubtasksMapping(int, int) - Method in enum org.apache.flink.runtime.io.network.api.writer.SubtaskStateMapper
-
Returns a mapping new subtask index to all old subtask indexes.
- getNext() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
Blocking call waiting for next
BufferOrEvent. - getNext() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- getNext() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
- getNext() - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
- getNextBuffer() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
- getNextBuffer() - Method in class org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionDirectTransferReader
- getNextBuffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Returns the next buffer from the consumed subpartitions or
Optional.empty()if there is no data to return. - getNextBuffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
- getNextBuffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RecoveredInputChannel
- getNextBuffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- getNextBuffer() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.TieredStorageResultSubpartitionView
- getNextBuffer() - Method in class org.apache.flink.runtime.io.network.partition.NoOpResultSubpartitionView
- getNextBuffer() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartitionView
- getNextBuffer() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
-
Returns the next
Bufferinstance of this queue iterator. - getNextBuffer() - Method in class org.apache.flink.runtime.io.network.partition.UnionResultSubpartitionView
- getNextBuffer(MemorySegment) - Method in interface org.apache.flink.runtime.io.network.partition.DataBuffer
-
Copies data in this
DataBufferto the targetMemorySegmentin subpartition index order and returnsBufferWithSubpartitionwhich contains the copied data and the corresponding subpartition index. - getNextBuffer(MemorySegment) - Method in class org.apache.flink.runtime.io.network.partition.HashBasedDataBuffer
- getNextBuffer(MemorySegment) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageSortBuffer
- getNextBuffer(MemorySegment) - Method in class org.apache.flink.runtime.io.network.partition.SortBasedDataBuffer
- getNextBuffer(TieredStoragePartitionId, TieredStorageSubpartitionId) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageConsumerClient
- getNextBuffer(TieredStoragePartitionId, TieredStorageSubpartitionId, int) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskTierConsumerAgent
- getNextBuffer(TieredStoragePartitionId, TieredStorageSubpartitionId, int) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory.MemoryTierConsumerAgent
- getNextBuffer(TieredStoragePartitionId, TieredStorageSubpartitionId, int) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierConsumerAgent
- getNextBuffer(TieredStoragePartitionId, TieredStorageSubpartitionId, int) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierConsumerAgent
-
Get buffer from the consumer agent.
- getNextDataType() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition.BufferAndBacklog
- getNextInputSplit() - Method in class org.apache.flink.runtime.executiongraph.Execution
- getNextInputSplit(ClassLoader) - Method in interface org.apache.flink.runtime.jobgraph.tasks.InputSplitProvider
-
Requests the next input split to be consumed by the calling task.
- getNextInputSplit(ClassLoader) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcInputSplitProvider
- getNextInputSplit(String, int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getNextInputSplit(String, int) - Method in class org.apache.flink.runtime.executiongraph.SpeculativeExecutionVertex
- getNextReceivedBuffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- getNextRecord(T) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
- getNextRecord(T) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
- getNextReturnedBlock() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockReader
-
Gets the next memory segment that has been filled with data by the reader.
- getNextReturnedBlock() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockWriter
-
Gets the next memory segment that has been written and is available again.
- getNextReturnedBlock() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelReader
-
Gets the next memory segment that has been filled with data by the reader.
- getNextReturnedBlock() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelWriter
-
Gets the next memory segment that has been written and is available again.
- getNextSubpartitionToConsume() - Method in class org.apache.flink.runtime.io.network.partition.RoundRobinSubpartitionSelector
- getNextSubpartitionToConsume() - Method in interface org.apache.flink.runtime.io.network.partition.SubpartitionSelector
-
Returns the next subpartition to consume data.
- getNioBuffer(int, int) - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Gets a new
ByteBufferinstance wrapping this buffer's bytes. - getNioBuffer(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- getNioBuffer(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- getNioBuffer(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- getNioBuffer(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- getNioBufferReadable() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Gets a new
ByteBufferinstance wrapping this buffer's readable bytes, i.e. betweenBuffer.getReaderIndex()andBuffer.getSize(). - getNioBufferReadable() - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- getNioBufferReadable() - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
-
This method is only called by tests and by event-deserialization, like checkpoint barriers.
- getNioBufferReadable() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- getNioBufferReadable() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- getNioFileChannel() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
- getNioFileChannel() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
- getNodeId() - Method in class org.apache.flink.runtime.blocklist.BlockedNode
- getNodeId() - Method in class org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
- getNodeId() - Method in class org.apache.flink.runtime.resourcemanager.TaskExecutorRegistration
- getNodeId() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
- getNodeId() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
Return the ID of node where the task manager is located on.
- getNodeId() - Method in class org.apache.flink.runtime.taskmanager.UnresolvedTaskManagerLocation
- getNonMaterializedStateHandles() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl
- getNonMaterializedStateHandles() - Method in interface org.apache.flink.runtime.state.changelog.ChangelogStateBackendHandle
- getNonMaterializedStateHandles() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendLocalHandle
- getNonReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
- getNonReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.FullOuterJoinDriver
- getNonReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.LeftOuterJoinDriver
- getNonReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.RightOuterJoinDriver
- getNormalizeKeyLen() - Method in class org.apache.flink.streaming.api.operators.sortpartition.FixedLengthByteKeyAndValueComparator
- getNormalizeKeyLen() - Method in class org.apache.flink.streaming.api.operators.sortpartition.VariableLengthByteKeyAndValueComparator
- getNow() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getNow() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
- getNow() - Method in interface org.apache.flink.runtime.webmonitor.retriever.GatewayRetriever
-
Returns the currently retrieved gateway if there is such an object.
- getNumAckSubtasks() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- getNumAckSubtasks() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
- getNumberAvailableSlots() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- getNumberBlockedFreeSlots() - Method in class org.apache.flink.runtime.resourcemanager.ResourceOverview
- getNumberBlockedTaskManagers() - Method in class org.apache.flink.runtime.resourcemanager.ResourceOverview
- getNumberCollectedStates() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- getNumberCollectedStates() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getNumberCompletedCheckpoints() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
- getNumberCPUCores() - Static method in class org.apache.flink.runtime.util.Hardware
-
Gets the number of CPU cores (hardware contexts) that the JVM has access to.
- getNumberFailedCheckpoints() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
- getNumberFreeSlots() - Method in class org.apache.flink.runtime.resourcemanager.ResourceOverview
- getNumberFreeSlots() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ClusterResourceStatisticsProvider
-
Get total number of free slots.
- getNumberFreeSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedSlotManager
- getNumberFreeSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- getNumberFreeSlots() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
- getNumberFreeSlotsOf(InstanceID) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ClusterResourceStatisticsProvider
-
Get number of free slots from the TaskManager with the given instance id.
- getNumberFreeSlotsOf(InstanceID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedSlotManager
- getNumberFreeSlotsOf(InstanceID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- getNumberFreeSlotsOf(InstanceID) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
- getNumberInProgressCheckpoints() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
- getNumberOfAcknowledgedSubtasks() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the number of acknowledged subtasks.
- getNumberOfAcknowledgedSubtasks() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
- getNumberOfAcknowledgedSubtasks() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
- getNumberOfAcknowledgedSubtasks() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
- getNumberOfAcknowledgedTasks() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
- getNumberOfActiveConnections() - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
- getNumberOfActiveConnections() - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
- getNumberOfActiveConnections() - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
- getNumberOfAllocatedBytes() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
-
Returns the number of currently allocated bytes.
- getNumberOfArenas() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
- getNumberOfAssignedPartitions() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
- getNumberOfAvailableBuffers() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- getNumberOfAvailableMemorySegments() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
Returns the number memory segments, which are currently held by this buffer pool.
- getNumberOfAvailableMemorySegments() - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
- getNumberOfAvailableMemorySegments() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
- getNumberOfChainedStubs() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getNumberOfCommittables() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableSummary
- getNumberOfCompletedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
-
Returns the number of completed checkpoints.
- getNumberOfConsumedPartitionGroupsById(IntermediateResultPartitionID) - Method in class org.apache.flink.runtime.executiongraph.EdgeManager
- getNumberOfCPUCores() - Method in class org.apache.flink.runtime.instance.HardwareDescription
-
Returns the number of CPU cores available to the JVM on the compute node.
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.CrossDriver
- getNumberOfDriverComparators() - Method in interface org.apache.flink.runtime.operators.Driver
-
Gets the number of comparators required for this driver.
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.JoinDriver
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.MapDriver
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.NoOpDriver
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.ReduceDriver
- getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
- getNumberOfEventsUntilInterruptInIterativeBroadcastGate(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getNumberOfEventsUntilInterruptInIterativeGate(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getNumberOfFailedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
-
Returns the number of failed checkpoints.
- getNumberOfFailedCommittables() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableSummary
- getNumberOfInProgressCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
-
Returns the number of in progress checkpoints.
- getNumberOfInputChannels() - Method in interface org.apache.flink.runtime.io.network.partition.consumer.CheckpointableInput
- getNumberOfInputChannels() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
- getNumberOfInputChannels() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- getNumberOfInputChannels() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
-
Returns the total number of input channels across all unioned input gates.
- getNumberOfInputChannels() - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
- getNumberOfInputChannels() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
- getNumberOfInputChannels() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
- getNumberOfInputs() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getNumberOfInputs() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns the number of inputs.
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.CrossDriver
- getNumberOfInputs() - Method in interface org.apache.flink.runtime.operators.Driver
-
Gets the number of inputs that the task has.
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.JoinDriver
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.MapDriver
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.NoOpDriver
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.ReduceDriver
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
- getNumberOfIterations() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getNumberOfKeyGroups() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- getNumberOfKeyGroups() - Method in interface org.apache.flink.runtime.state.InternalKeyContext
-
Returns the number of key-groups aka max parallelism.
- getNumberOfKeyGroups() - Method in class org.apache.flink.runtime.state.InternalKeyContextImpl
- getNumberOfKeyGroups() - Method in class org.apache.flink.runtime.state.KeyedStateBackendParametersImpl
- getNumberOfKeyGroups() - Method in class org.apache.flink.runtime.state.KeyGroupRange
- getNumberOfKeyGroups() - Method in interface org.apache.flink.runtime.state.KeyGroupsList
-
Returns the number of key group ids in the list.
- getNumberOfKeyGroups() - Method in interface org.apache.flink.runtime.state.StateBackend.KeyedStateBackendParameters
- getNumberOfNetworkInputs() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getNumberOfNonAcknowledgedOperatorCoordinators() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
- getNumberOfNonAcknowledgedTasks() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
- getNumberOfOperators() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- getNumberOfOutputs() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getNumberOfOutstandingRequests() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileWriter
- getNumberOfOutstandingRequests() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileWriter
-
Returns the number of outstanding requests.
- getNumberOfPartitions() - Method in class org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionInfo
- getNumberOfPartitions() - Method in class org.apache.flink.runtime.state.OperatorStateCheckpointOutputStream
- getNumberOfPendingCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
- getNumberOfPendingCommittables() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableSummary
- getNumberOfPendingRequests() - Method in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator
- getNumberOfProducedIntermediateDataSets() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns the number of produced intermediate data sets.
- getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionDirectTransferReader
- getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.BufferWritingResultPartition
- getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RecoveredInputChannel
- getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
Gets the current number of received buffers which have not been processed yet.
- getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.TieredStorageResultSubpartitionView
- getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartition
- getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.NoOpResultSubpartitionView
- getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartition
- getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartitionView
- getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Returns the total number of queued buffers of all subpartitions.
- getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
Get the current size of the queue.
- getNumberOfQueuedBuffers() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
- getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.SortMergeResultPartition
- getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.UnionResultSubpartitionView
- getNumberOfQueuedBuffers(int) - Method in class org.apache.flink.runtime.io.network.partition.BufferWritingResultPartition
- getNumberOfQueuedBuffers(int) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartition
- getNumberOfQueuedBuffers(int) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Returns the number of queued buffers of the given target subpartition.
- getNumberOfQueuedBuffers(int) - Method in class org.apache.flink.runtime.io.network.partition.SortMergeResultPartition
- getNumberOfReferenceHolders(JobID) - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
- getNumberOfRegisteredBufferPools() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
- getNumberOfRegisteredMasterHooks() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Gets the number of currently register master hooks.
- getNumberOfRegisteredTaskManagers() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- getNumberOfRegisteredTaskManagers() - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Gets the currently registered number of TaskManagers.
- getNumberOfRequestedMemorySegments() - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
- getNumberOfRequiredBuffers() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- getNumberOfRequiredMemorySegments() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
Returns the number of guaranteed (minimum number of) memory segments of this buffer pool.
- getNumberOfRequiredMemorySegments() - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
- getNumberOfRequiredSlots() - Method in class org.apache.flink.runtime.slots.ResourceRequirement
- getNumberOfRestarts() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getNumberOfRestarts() - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Gets the number of restarts, including full restarts and fine grained restarts.
- getNumberOfRestarts() - Method in class org.apache.flink.runtime.executiongraph.failover.ExecutionFailureHandler
- getNumberOfRestarts() - Method in class org.apache.flink.runtime.scheduler.DefaultScheduler
- getNumberOfRestarts() - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- getNumberOfRestoredCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
-
Returns the number of restored checkpoints.
- getNumberOfRetainedCheckpoints() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
Returns the current number of retained checkpoints.
- getNumberOfRetainedCheckpoints() - Method in enum org.apache.flink.runtime.checkpoint.DeactivatedCheckpointCompletedCheckpointStore
- getNumberOfRetainedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.DefaultCompletedCheckpointStore
- getNumberOfRetainedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.EmbeddedCompletedCheckpointStore
- getNumberOfRetainedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
- getNumberOfRetainedSuccessfulCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
- getNumberOfRetries() - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
- getNumberOfSamples() - Method in class org.apache.flink.runtime.throughput.BufferDebloatConfiguration
- getNumberOfSlots() - Method in class org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
- getNumberOfSlots() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
- getNumberOfSubpartitions() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
- getNumberOfSubpartitions() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
- getNumberOfSubpartitions() - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
- getNumberOfSubpartitions() - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
- getNumberOfSubpartitions() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- getNumberOfSubpartitions() - Method in class org.apache.flink.runtime.shuffle.PartitionDescriptor
- getNumberOfSubtasks() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the total number of subtasks involved in this checkpoint.
- getNumberOfSubtasks() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
- getNumberOfSubtasks() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
- getNumberOfSubtasks() - Method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexThreadInfoStats
- getNumberOfSubtasks() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableSummary
- getNumberOfSubtasks() - Method in interface org.apache.flink.streaming.runtime.operators.sink.committables.CheckpointCommittableManager
-
Returns the number of upstream subtasks belonging to the checkpoint.
- getNumberOfUnfinishedPartitions() - Method in class org.apache.flink.runtime.scheduler.strategy.ConsumedPartitionGroup
- getNumberOfUsedMemorySegments() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
- getNumberOfVariablesWithReferences() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableManager
- getNumberOfVertices() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns the number of all vertices.
- getNumberRegisteredSlots() - Method in class org.apache.flink.runtime.resourcemanager.ResourceOverview
- getNumberRegisteredSlots() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ClusterResourceStatisticsProvider
-
Get total number of registered slots.
- getNumberRegisteredSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedSlotManager
- getNumberRegisteredSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- getNumberRegisteredSlots() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
- getNumberRegisteredSlotsOf(InstanceID) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ClusterResourceStatisticsProvider
-
Get number of registered slots from the TaskManager with the given instance id.
- getNumberRegisteredSlotsOf(InstanceID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedSlotManager
- getNumberRegisteredSlotsOf(InstanceID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- getNumberRegisteredSlotsOf(InstanceID) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
- getNumberReporters() - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
-
Returns the number of registered reporters.
- getNumberReporters() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
- getNumberReporters() - Method in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
- getNumberRestoredCheckpoints() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
- getNumberSlots() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- getNumberSlots() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
- getNumberTaskManagers() - Method in class org.apache.flink.runtime.resourcemanager.ResourceOverview
- getNumBroadcastInputs() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getNumBuffers() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
Returns the current size of this buffer pool.
- getNumBuffers() - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
- getNumBuffers() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.index.FileDataIndexRegionHelper.Region
-
Get the number of buffers in this region.
- getNumBuffers() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.ProducerMergedPartitionFileIndex.FixedSizeRegion
- getNumBuffersInLocalCounter() - Method in class org.apache.flink.runtime.io.network.metrics.InputChannelMetrics
- getNumBuffersInRemoteCounter() - Method in class org.apache.flink.runtime.io.network.metrics.InputChannelMetrics
- getNumBuffersOutCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- getNumBuffersPerRequest() - Method in class org.apache.flink.runtime.io.disk.BatchShuffleReadBufferPool
- getNumBuffersTriggerFlushRatio() - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageUtils
-
When the number of buffers that have been requested exceeds this threshold, trigger the flushing operation in each
TierProducerAgent. - getNumBytes() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
-
Get output bytes.
- getNumBytesIn() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
- getNumBytesInCounter() - Method in class org.apache.flink.runtime.metrics.groups.InternalOperatorIOMetricGroup
- getNumBytesInCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- getNumBytesInLocalCounter() - Method in class org.apache.flink.runtime.io.network.metrics.InputChannelMetrics
- getNumBytesInRemoteCounter() - Method in class org.apache.flink.runtime.io.network.metrics.InputChannelMetrics
- getNumBytesOut() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
- getNumBytesOutCounter() - Method in class org.apache.flink.runtime.metrics.groups.InternalOperatorIOMetricGroup
- getNumBytesOutCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- getNumBytesProduced() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.AllToAllBlockingResultInfo
- getNumBytesProduced() - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.BlockingResultInfo
-
Return the num of bytes produced(numBytesProduced) by the producer.
- getNumBytesProduced() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.PointwiseBlockingResultInfo
- getNumBytesProduced(IndexRange, IndexRange) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.AllToAllBlockingResultInfo
- getNumBytesProduced(IndexRange, IndexRange) - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.BlockingResultInfo
-
Return the aggregated num of bytes according to the index range for partition and subpartition.
- getNumBytesProduced(IndexRange, IndexRange) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.PointwiseBlockingResultInfo
- getNumBytesSendCounter() - Method in class org.apache.flink.runtime.metrics.groups.InternalSinkWriterMetricGroup
- getNumCommittablesAlreadyCommittedCounter() - Method in class org.apache.flink.runtime.metrics.groups.InternalSinkCommitterMetricGroup
- getNumCommittablesFailureCounter() - Method in class org.apache.flink.runtime.metrics.groups.InternalSinkCommitterMetricGroup
- getNumCommittablesRetryCounter() - Method in class org.apache.flink.runtime.metrics.groups.InternalSinkCommitterMetricGroup
- getNumCommittablesSuccessCounter() - Method in class org.apache.flink.runtime.metrics.groups.InternalSinkCommitterMetricGroup
- getNumCommittablesTotalCounter() - Method in class org.apache.flink.runtime.metrics.groups.InternalSinkCommitterMetricGroup
- getNumCompressedBytes() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
-
Get output compressed bytes, return num bytes if there is no compression.
- getNumConsumers() - Method in class org.apache.flink.runtime.scheduler.strategy.ConsumedPartitionGroup
-
In dynamic graph cases, the number of consumers of ConsumedPartitionGroup can be different even if they contain the same IntermediateResultPartition.
- getNumElements() - Method in class org.apache.flink.streaming.api.functions.source.legacy.FromElementsFunction
-
Deprecated.Gets the number of elements produced in total by this function.
- getNumElementsEmitted() - Method in class org.apache.flink.streaming.api.functions.source.legacy.FromElementsFunction
-
Deprecated.Gets the number of elements emitted so far.
- getNumFinishedVertices() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getNumFinishedVertices() - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- getNumFiredTimers() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- getNumGuaranteedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemorySpec
- getNumInputs() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
- getNumInputs() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getNumIoThreads() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
- getNumJobsCancelled() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
- getNumJobsFailed() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
- getNumJobsFinished() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
- getNumJobsRunningOrPending() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
- getNumKeyGroups() - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Returns the number of key groups of the operator the KvState instances belong to.
- getNumMailsProcessedCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- getNumNeeded() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceDeclaration
- getNumOccupiedMemorySegments() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
Gets the number of memory segments used by this partition, which includes build side memory buffers and overflow memory segments.
- getNumOutputs() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getNumPartitions() - Method in interface org.apache.flink.runtime.executiongraph.IntermediateResultInfo
-
Get number of partitions for this result.
- getNumPartitions() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.AllToAllBlockingResultInfo
- getNumPartitions() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.PointwiseBlockingResultInfo
- getNumPendingRequests() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolBridge
- getNumPriorityElements() - Method in class org.apache.flink.runtime.io.network.partition.PrioritizedDeque
-
Returns the current number of priority elements ([0;
PrioritizedDeque.size()]). - getNumRecordsIn() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
- getNumRecordsInCounter() - Method in class org.apache.flink.runtime.metrics.groups.InternalOperatorIOMetricGroup
- getNumRecordsInCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- getNumRecordsInErrorsCounter() - Method in class org.apache.flink.runtime.metrics.groups.InternalSourceReaderMetricGroup
- getNumRecordsInRateMeter() - Method in class org.apache.flink.runtime.metrics.groups.InternalOperatorIOMetricGroup
- getNumRecordsOut() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
- getNumRecordsOutCounter() - Method in class org.apache.flink.runtime.metrics.groups.InternalOperatorIOMetricGroup
- getNumRecordsOutCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- getNumRecordsOutErrorsCounter() - Method in class org.apache.flink.runtime.metrics.groups.InternalSinkWriterMetricGroup
- getNumRecordsOutRate() - Method in class org.apache.flink.runtime.metrics.groups.InternalOperatorIOMetricGroup
- getNumRecordsSendCounter() - Method in class org.apache.flink.runtime.metrics.groups.InternalSinkWriterMetricGroup
- getNumRecordsSendErrorsCounter() - Method in class org.apache.flink.runtime.metrics.groups.InternalSinkWriterMetricGroup
- getNumRegions() - Method in class org.apache.flink.runtime.io.network.partition.PartitionedFile
- getNumRegisteredKeyGroups() - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Returns the current number of registered key groups.
- getNumRegisteredPartitions() - Method in class org.apache.flink.runtime.io.network.partition.DataSetMetaInfo
- getNumRequiredComparators() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
- getNumSamples() - Method in class org.apache.flink.runtime.webmonitor.threadinfo.ThreadInfoSamplesRequest
-
Returns the number of samples that are requested to be collected.
- getNumSlots() - Method in class org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
- getNumSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingTaskManager
- getNumSlots() - Method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec
- getNumSlotsAvailable() - Method in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
- getNumSlotsFreeAndBlocked() - Method in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
- getNumSlotsPerWorker() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
- getNumSlotStatus() - Method in class org.apache.flink.runtime.taskexecutor.SlotReport
- getNumSlotsTotal() - Method in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
- getNumSubpartitions(int) - Method in interface org.apache.flink.runtime.executiongraph.IntermediateResultInfo
-
Get number of subpartitions for the given partition.
- getNumSubpartitions(int) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.AllToAllBlockingResultInfo
- getNumSubpartitions(int) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.PointwiseBlockingResultInfo
- getNumSubtasks() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- getNumSubtasks() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
- getNumTargetKeyGroups() - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
- getNumTargetKeyGroups() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- getNumTaskInputs() - Method in class org.apache.flink.runtime.iterative.task.IterationHeadTask
- getNumTaskInputs() - Method in class org.apache.flink.runtime.operators.BatchTask
- getNumTaskManagers() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
- getNumTaskManagersBlocked() - Method in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
- getNumTaskManagersConnected() - Method in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
- getNumTasks() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
- getNumTotalBuffers() - Method in class org.apache.flink.runtime.io.disk.BatchShuffleReadBufferPool
- getNumTotalPartitions() - Method in class org.apache.flink.runtime.io.network.partition.DataSetMetaInfo
- getNumTotalPartitions() - Method in class org.apache.flink.runtime.taskexecutor.partition.ClusterPartitionReport.ClusterPartitionReportEntry
- getNumWriteBehindBuffers(int) - Static method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Determines the number of buffers to be used for asynchronous write behind.
- getOccupancy() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
Gets the number of bytes currently occupied in this hash table.
- getOccupancy() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
- getOccupancy() - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Gets the number of bytes currently occupied in this sorter, records and sort index.
- getOccupancy() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
- getOffset() - Method in class org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
- getOffset() - Method in class org.apache.flink.streaming.api.operators.collect.CollectCoordinationRequest
- getOffsetForKeyGroup(int) - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
- getOffsets() - Method in class org.apache.flink.runtime.state.AbstractChannelStateHandle
- getOffsets() - Method in class org.apache.flink.runtime.state.AbstractChannelStateHandle.StateContentMetaInfo
- getOffsets() - Method in class org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
- getOldSubtaskIndexes(int) - Method in class org.apache.flink.runtime.checkpoint.InflightDataRescalingDescriptor
- getOldSubtasks(int, int, int) - Method in enum org.apache.flink.runtime.io.network.api.writer.SubtaskStateMapper
-
Returns all old subtask indexes that need to be read to restore all buffers for the given new subtask index on rescale.
- getOne() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
- getOpenFileHandlesLimit() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Tries to retrieve the maximum number of open file handles.
- getOperationCaches() - Method in class org.apache.flink.runtime.dispatcher.DispatcherServices
- getOperationCaches() - Method in class org.apache.flink.runtime.dispatcher.PartialDispatcherServices
- getOperationKey(HandlerRequest<EmptyRequestBody>) - Method in class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.StatusHandler
-
Extract the operation key under which the operation result future is stored.
- getOperationKey(HandlerRequest<EmptyRequestBody>) - Method in class org.apache.flink.runtime.rest.handler.dataset.ClusterDataSetDeleteHandlers.ClusterDataSetDeleteStatusHandler
- getOperationKey(HandlerRequest<EmptyRequestBody>) - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingStatusHandler
- getOperationKey(HandlerRequest<EmptyRequestBody>) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalStatusHandler
- getOperationKey(HandlerRequest<EmptyRequestBody>) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointStatusHandler
- getOperator() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getOperator() - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
- getOperator() - Method in class org.apache.flink.streaming.api.transformations.LegacySinkTransformation
- getOperator() - Method in class org.apache.flink.streaming.api.transformations.LegacySourceTransformation
- getOperator() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
- getOperator() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
- getOperator() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
- getOperatorAttributes() - Method in class org.apache.flink.streaming.api.operators.MapPartitionOperator
- getOperatorAttributes() - Method in class org.apache.flink.streaming.api.operators.PartitionAggregateOperator
- getOperatorAttributes() - Method in class org.apache.flink.streaming.api.operators.PartitionReduceOperator
- getOperatorAttributes() - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
- getOperatorAttributes() - Method in class org.apache.flink.streaming.api.operators.sortpartition.KeyedSortPartitionOperator
- getOperatorAttributes() - Method in class org.apache.flink.streaming.api.operators.sortpartition.SortPartitionOperator
- getOperatorAttributes() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
Called to get the OperatorAttributes of the operator.
- getOperatorAttributes() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
-
Is called to get the OperatorAttributes of the operator.
- getOperatorAttributes() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
- getOperatorConfig() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- getOperatorConfig() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- getOperatorCoordinatorEventGateway() - Method in interface org.apache.flink.runtime.execution.Environment
-
Gets the gateway through which operators can send events to the operator coordinators.
- getOperatorCoordinatorEventGateway() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getOperatorCoordinators() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- getOperatorCoordinators() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- getOperatorCoordinatorSnapshotFutures() - Method in class org.apache.flink.runtime.jobmaster.event.ExecutionVertexFinishedEvent
- getOperatorDescription() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- getOperatorDescription() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getOperatorEventDispatcher() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorParameters
- getOperatorEventDispatcher() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- getOperatorEventGateway(OperatorID) - Method in interface org.apache.flink.runtime.operators.coordination.OperatorEventDispatcher
-
Gets the gateway through which events can be passed to the OperatorCoordinator for the operator identified by the given OperatorID.
- getOperatorEventGateway(OperatorID) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorEventDispatcherImpl
- getOperatorFactory() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getOperatorFactory() - Method in class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
-
Returns the
StreamOperatorFactoryof this Transformation. - getOperatorFactory() - Method in class org.apache.flink.streaming.api.transformations.LegacySinkTransformation
-
Returns the
StreamOperatorFactoryof thisLegacySinkTransformation. - getOperatorFactory() - Method in class org.apache.flink.streaming.api.transformations.LegacySourceTransformation
-
Returns the
StreamOperatorFactoryof thisLegacySourceTransformation. - getOperatorFactory() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Returns the
StreamOperatorFactoryof this Transformation. - getOperatorFactory() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the
StreamOperatorFactoryof this Transformation. - getOperatorFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
- getOperatorId() - Method in class org.apache.flink.runtime.jobgraph.OperatorInstanceID
- getOperatorId() - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator.Context
-
Gets the ID of the operator to which the coordinator belongs.
- getOperatorId() - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator.Provider
-
Gets the ID of the operator to which the coordinator belongs.
- getOperatorId() - Method in class org.apache.flink.runtime.operators.coordination.RecreateOnResetOperatorCoordinator.Provider
- getOperatorId() - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator.Provider
- getOperatorId() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
- getOperatorID() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- getOperatorID() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getOperatorID() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- getOperatorID() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- getOperatorID() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
- getOperatorID() - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
- getOperatorIdentifier() - Method in class org.apache.flink.runtime.state.KeyedStateBackendParametersImpl
- getOperatorIdentifier() - Method in class org.apache.flink.runtime.state.OperatorStateBackendParametersImpl
- getOperatorIdentifier() - Method in interface org.apache.flink.runtime.state.StateBackend.KeyedStateBackendParameters
- getOperatorIdentifier() - Method in interface org.apache.flink.runtime.state.StateBackend.OperatorStateBackendParameters
- getOperatorIDs() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
Returns a list containing the ID pairs of all operators contained in this execution job vertex.
- getOperatorIDs() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- getOperatorLevelCachingDescription() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Gets the operator-level caching description for this input.
- getOperatorName() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- getOperatorName() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- getOperatorName() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getOperatorName() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getOperatorName() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Return the operator name.
- getOperatorName() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
Return the operator name.
- getOperatorNonChainedOutputs(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getOperatorPrettyName() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- getOperatorsMemory() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the memory the operators needed.
- getOperatorStateBackend() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- getOperatorStateBackend() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- getOperatorStateBackend() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
- getOperatorStateManagedFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
- getOperatorStateMetaInfoSnapshots() - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
- getOperatorStateRawFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
- getOperatorStates() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
- getOperatorStates() - Method in class org.apache.flink.runtime.checkpoint.metadata.CheckpointMetadata
- getOperatorStates() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
- getOperatorStateStore() - Method in interface org.apache.flink.runtime.state.ManagedInitializationContext
-
Returns an interface that allows for registering operator state with the backend.
- getOperatorStateStore() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
- getOperatorStateStreamFuture() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
- getOperatorUid() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- getOperatorUniqueID() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Returned value is guaranteed to be unique between operators within the same job and to be stable and the same across job submissions.
- getOption(String) - Method in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
- getOption(StateMetaInfoSnapshot.CommonOptionsKeys) - Method in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
- getOptions() - Method in class org.apache.flink.runtime.entrypoint.ClusterConfigurationParserFactory
- getOptions() - Method in class org.apache.flink.runtime.entrypoint.DynamicParametersConfigurationParserFactory
- getOptions() - Method in class org.apache.flink.runtime.entrypoint.EntrypointClusterConfigurationParserFactory
- getOptions() - Method in class org.apache.flink.runtime.entrypoint.ModifiableClusterConfigurationParserFactory
- getOptions() - Method in interface org.apache.flink.runtime.entrypoint.parser.ParserResultFactory
-
Returns all relevant
Optionsfor parsing the command line arguments. - getOptionsImmutable() - Method in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
- getOrAddOperator(String) - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
- getOrAddOperator(OperatorID, String) - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
- getOrAddOperator(OperatorID, String) - Method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredTaskMetricGroup
- getOrAddOperator(AbstractID, String, OperatorID, String) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerJobMetricGroup
- getOrAddOperator(AbstractID, String, OperatorID, String) - Method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredJobManagerJobMetricGroup
- getOrAllocateSharedResource(String, Object, LongFunctionWithException<T, Exception>, long) - Method in class org.apache.flink.runtime.memory.SharedResources
-
Gets the shared memory resource for the given owner and registers a lease.
- getOrCreateExecutor(JobVertexID, int, SupplierWithException<CheckpointStorageWorkerView, ? extends IOException>, int) - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriteRequestExecutorFactory
- getOrCreateExecutorFactory(JobID) - Method in class org.apache.flink.runtime.state.TaskExecutorChannelStateExecutorFactoryManager
- getOrCreateJob(JobID, SupplierWithException<? extends JobTable.JobServices, E>) - Method in class org.apache.flink.runtime.taskexecutor.DefaultJobTable
- getOrCreateJob(JobID, SupplierWithException<? extends JobTable.JobServices, E>) - Method in interface org.apache.flink.runtime.taskexecutor.JobTable
-
Gets a registered
JobTable.Jobor creates one if not present. - getOrCreateKeyedState(N, TypeSerializer<N>, StateDescriptor<T>) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperator
-
Create new state (v2) based on new state descriptor.
- getOrCreateKeyedState(N, TypeSerializer<N>, StateDescriptor<T>) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperatorV2
-
Create new state (v2) based on new state descriptor.
- getOrCreateKeyedState(N, TypeSerializer<N>, StateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
-
Create new state (v2) based on new state descriptor.
- getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, T>) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
-
Creates or retrieves a keyed state backed by this state backend.
- getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, T>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, T>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, T>) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
- getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, T>) - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
- getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, V>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- getOrCreatePhysicalFileForCheckpoint(FileMergingSnapshotManager.SubtaskKey, long, CheckpointedStateScope) - Method in class org.apache.flink.runtime.checkpoint.filemerging.AcrossCheckpointFileMergingSnapshotManager
- getOrCreatePhysicalFileForCheckpoint(FileMergingSnapshotManager.SubtaskKey, long, CheckpointedStateScope) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
-
Get a reused physical file or create one.
- getOrCreatePhysicalFileForCheckpoint(FileMergingSnapshotManager.SubtaskKey, long, CheckpointedStateScope) - Method in class org.apache.flink.runtime.checkpoint.filemerging.WithinCheckpointFileMergingSnapshotManager
- getOrCreateResultDataSet(IntermediateDataSetID, ResultPartitionType) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- getOrDecideHybridPartitionDataConsumeConstraint(Configuration, boolean) - Static method in class org.apache.flink.runtime.scheduler.adaptivebatch.AdaptiveBatchSchedulerFactory
- getOrResolveClassLoader(Collection<PermanentBlobKey>, Collection<URL>) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager.ClassLoaderHandle
-
Gets or resolves the user code class loader for the associated job.
- getOtherConcurrentAttempts() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- getOtherConcurrentAttempts() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
- getOutEdgeIndices() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getOutEdges() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getOutput() - Method in class org.apache.flink.runtime.state.filesystem.FSDataOutputStreamWrapper
- getOutput() - Method in class org.apache.flink.runtime.state.filesystem.RecoverableStreamWrapper
- getOutput() - Method in class org.apache.flink.streaming.api.datastream.DataStream.Collector
-
Returns an iterator over the collected elements.
- getOutput() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorParameters
- getOutputCollector() - Method in class org.apache.flink.runtime.operators.BatchTask
- getOutputCollector() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
- getOutputCollector() - Method in interface org.apache.flink.runtime.operators.TaskContext
- getOutputCollector(AbstractInvokable, TaskConfig, ClassLoader, List<RecordWriter<?>>, int, int) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Creates the
Collectorfor the given task, as described by the given configuration. - getOutputComparator(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getOutputDataDistribution(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getOutputFile() - Method in class org.apache.flink.runtime.rest.messages.ProfilingInfo
- getOutputFormat() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getOutputFormat() - Method in interface org.apache.flink.streaming.api.operators.OutputFormatOperatorFactory
- getOutputFormat() - Method in class org.apache.flink.streaming.api.operators.SimpleOutputFormatOperatorFactory
- getOutputFormats() - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer.FormatUserCodeTable
- getOutputFormats() - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
- getOutputGroup() - Method in class org.apache.flink.runtime.shuffle.ShuffleIOOwnerContext
- getOutputPartitioner(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getOutputRescalingDescriptor() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
- getOutputRescalingDescriptor() - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
-
Returns the output channel mapping for rescaling with in-flight data or
InflightDataRescalingDescriptor.NO_RESCALE. - getOutputRescalingDescriptor() - Method in interface org.apache.flink.runtime.state.TaskStateManager
- getOutputRescalingDescriptor() - Method in class org.apache.flink.runtime.state.TaskStateManagerImpl
- getOutputSerializer(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getOutputShipStrategy(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getOutputStream() - Method in class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFile
- getOutputSubtaskIndex() - Method in class org.apache.flink.runtime.io.network.api.SubtaskConnectionDescriptor
- getOutputTag() - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
- getOutputTag() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
- getOutputTag() - Method in class org.apache.flink.streaming.api.transformations.SideOutputTransformation
- getOverhead() - Method in class org.apache.flink.runtime.util.config.memory.JvmMetaspaceAndOverhead
- getOversizedRecordCount() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
-
Gets the number of oversized records handled by this combiner.
- getOwner() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemorySpec
- getOwnerName() - Method in class org.apache.flink.runtime.shuffle.ShuffleIOOwnerContext
- getOwningJob(AllocationID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Returns the owning job of the
TaskSlotidentified by the givenAllocationID. - getOwningJob(AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- getOwningTaskName() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- getOwningTaskName() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- getP50() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.StatsSummaryDto
- getP90() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.StatsSummaryDto
- getP95() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.StatsSummaryDto
- getP99() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.StatsSummaryDto
- getP999() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.StatsSummaryDto
- getPageSize() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Gets the size of the pages handled by the memory manager.
- getPageSize() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
- getPageSize(Configuration) - Static method in class org.apache.flink.runtime.util.ConfigurationParserUtils
-
Parses the configuration to get the page size and validates the value.
- getPairComparatorFactory(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getParallelism() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- getParallelism() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getParallelism() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
Returns the parallelism for this job vertex.
- getParallelism() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
- getParallelism() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- getParallelism() - Method in class org.apache.flink.runtime.executiongraph.ParallelismAndInputInfos
- getParallelism() - Method in class org.apache.flink.runtime.jobgraph.forwardgroup.ForwardGroup
- getParallelism() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Gets the parallelism of the task.
- getParallelism() - Method in class org.apache.flink.runtime.jobgraph.JobVertexResourceRequirements
- getParallelism() - Method in class org.apache.flink.runtime.jobmaster.event.ExecutionJobVertexInitializedEvent
- getParallelism() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- getParallelism() - Method in class org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
- getParallelism() - Method in interface org.apache.flink.runtime.scheduler.adaptive.allocator.JobInformation.VertexInformation
- getParallelism() - Method in class org.apache.flink.runtime.scheduler.DefaultVertexParallelismInfo
- getParallelism() - Method in interface org.apache.flink.runtime.scheduler.VertexParallelismInformation
-
Returns a vertex's parallelism.
- getParallelism() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Gets the parallelism for this operator.
- getParallelism() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the parallelism with which operation are executed by default.
- getParallelism() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getParallelism(JobVertexID) - Method in class org.apache.flink.runtime.jobgraph.JobResourceRequirements
- getParallelism(JobVertexID) - Method in class org.apache.flink.runtime.scheduler.adaptive.allocator.VertexParallelism
- getParallelismInfo(JobVertexID) - Method in class org.apache.flink.runtime.scheduler.DefaultVertexParallelismStore
- getParallelismInfo(JobVertexID) - Method in interface org.apache.flink.runtime.scheduler.VertexParallelismStore
-
Returns a given vertex's parallelism information.
- getParallelismOptional(JobVertexID) - Method in class org.apache.flink.runtime.scheduler.adaptive.allocator.VertexParallelism
- getParallelSubtaskIndex() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
Returns the subtask index of this execution.
- getParallelSubtaskIndex() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
Returns the subtask index of this execution vertex.
- getParallelSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
- getParallelSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
- getParallelSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.Execution
- getParallelSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getParameters(OperatorID) - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
- getParentGroup() - Method in class org.apache.flink.runtime.shuffle.ShuffleIOOwnerContext
- getParentMetricGroup() - Method in class org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
- getPartialRecordLength() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumerWithPartialRecordLength
- getPartition() - Method in class org.apache.flink.runtime.shuffle.DefaultPartitionWithMetrics
- getPartition() - Method in interface org.apache.flink.runtime.shuffle.PartitionWithMetrics
- getPartitionById(IntermediateResultPartitionID) - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
Returns the partition with the given ID.
- getPartitionBytes() - Method in class org.apache.flink.runtime.shuffle.DefaultShuffleMetrics
- getPartitionBytes() - Method in interface org.apache.flink.runtime.shuffle.ShuffleMetrics
- getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
TODO: NOTE: This method does a lot of work caching / retrieving states just to update the namespace.
- getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
-
Creates or retrieves a partitioned state backed by this state backend.
- getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Creates a partitioned state handle, using the state backend configured for this task.
- getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
Creates a partitioned state handle, using the state backend configured for this task.
- getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
- getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
-
Creates a partitioned state handle, using the state backend configured for this task.
- getPartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
- getPartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Creates a partitioned state handle, using the state backend configured for this task.
- getPartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
Creates a partitioned state handle, using the state backend configured for this task.
- getPartitionedState(StateDescriptor<S, ?>) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Retrieves a
Stateobject that can be used to interact with fault-tolerant state that is scoped to the window and key of the current trigger invocation. - getPartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
- getPartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.PerWindowStateStore
- getPartitioner() - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
- getPartitioner() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
- getPartitioner() - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
Returns the
StreamPartitionerthat must be used for partitioning the elements of the inputTransformation. - getPartitionGroupReleaseStrategy() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getPartitionGroupReleaseStrategy() - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
- getPartitionId() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
- getPartitionId() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
- getPartitionId() - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
- getPartitionId() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
- getPartitionId() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageConsumerSpec
- getPartitionId() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierShuffleDescriptor
- getPartitionId() - Method in exception org.apache.flink.runtime.io.network.partition.PartitionException
- getPartitionId() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- getPartitionId() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionID
- getPartitionId() - Method in class org.apache.flink.runtime.shuffle.PartitionDescriptor
- getPartitionID() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStoragePartitionId
- getPartitionIdx() - Method in class org.apache.flink.runtime.checkpoint.channel.ResultSubpartitionInfo
- getPartitionIndex() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- getPartitionIndexRange() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertexInputInfo
-
Get the partition range this subtask should consume.
- getPartitioningFanOutNoEstimates(int) - Static method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Gets the number of partitions to be used for an initial hash-table, when no estimates are available.
- getPartitionManager() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- getPartitionMetrics() - Method in class org.apache.flink.runtime.shuffle.DefaultPartitionWithMetrics
- getPartitionMetrics() - Method in interface org.apache.flink.runtime.shuffle.PartitionWithMetrics
- getPartitionNumber() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
- getPartitionNumber() - Method in class org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
- getPartitionNumber() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
Gets the partition number of this partition.
- getPartitionNumber() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
Gets the partition number of this partition.
- getPartitionPath(TieredStoragePartitionId, String) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.SegmentPartitionFile
- getPartitionProducer() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getPartitionProducer() - Method in class org.apache.flink.runtime.executiongraph.SpeculativeExecutionVertex
- getPartitionRequestListeners() - Method in class org.apache.flink.runtime.io.network.partition.PartitionRequestListenerManager
- getPartitionRequestListenerTimeout() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- getPartitionReuseCount() - Method in class org.apache.flink.runtime.shuffle.TaskInputsOutputsDescriptor
- getPartitions() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
- getPartitionsOccupyingLocalResources() - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
Report unreleased partitions.
- getPartitionsOccupyingLocalResources() - Method in interface org.apache.flink.runtime.shuffle.ShuffleEnvironment
-
Report partitions which still occupy some resources locally.
- getPartitionStateChecker() - Method in interface org.apache.flink.runtime.taskexecutor.JobTable.Connection
- getPartitionStateSerializer() - Method in class org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
- getPartitionTracker() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getPartitionTracker() - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
- getPartitionType() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
- getPartitionType() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Returns the type of this result partition.
- getPartitionType() - Method in class org.apache.flink.runtime.shuffle.PartitionDescriptor
- getPartitionType() - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
- getPartitionTypes() - Method in class org.apache.flink.runtime.shuffle.TaskInputsOutputsDescriptor
- getPartitionWithMetrics(Duration, Set<ResultPartitionID>) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- getPartitionWithMetrics(Duration, Set<ResultPartitionID>) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Get specified partitions and their metrics (identified by
expectedPartitions), the metrics include sizes of sub-partitions in a result partition. - getPartitionWithMetrics(Duration, Set<ResultPartitionID>) - Method in interface org.apache.flink.runtime.shuffle.JobShuffleContext
-
Retrieves specified partitions and their metrics (identified by
expectedPartitions), the metrics include sizes of sub-partitions in a result partition. - getPartitionWithMetrics(Duration, Set<ResultPartitionID>) - Method in class org.apache.flink.runtime.shuffle.JobShuffleContextImpl
- getPartitionWithMetrics(JobID, Duration, Set<ResultPartitionID>) - Method in class org.apache.flink.runtime.shuffle.NettyShuffleMaster
- getPartitionWithMetrics(JobID, Duration, Set<ResultPartitionID>) - Method in interface org.apache.flink.runtime.shuffle.ShuffleMaster
-
Retrieves specified partitions and their metrics (identified by
expectedPartitions), the metrics include sizes of sub-partitions in a result partition. - getPassThroughInputs() - Method in class org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput.SelectableSortingInputs
- getPath() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
-
Returns the path to the underlying temporary file.
- getPath() - Method in class org.apache.flink.runtime.rest.handler.router.RoutedRequest
- getPath() - Method in class org.apache.flink.runtime.webmonitor.history.ArchivedJson
- getPathFile() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
-
Returns the path to the underlying temporary file as a File.
- getPathForJob(JobID) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Returns the JobID as a String (with leading slash).
- getPathParameter(Class<PP>) - Method in class org.apache.flink.runtime.rest.handler.HandlerRequest
-
Returns the value of the
MessagePathParameterfor the given class. - getPathParameters() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatusMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointTriggerMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.cluster.FileMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.cluster.ProfilingFileMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteStatusMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteTriggerMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.EmptyMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.coordination.ClientCoordinationMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedJobMetricsParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedSubtaskMetricsParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregateTaskManagerMetricsParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerOperatorMetricsMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskAttemptMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.JobCancellationMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.JobClientHeartbeatParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.JobMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.JobTaskManagerMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.JobVertexMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.MessageParameters
-
Returns the collection of
MessagePathParameterthat the request supports. - getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerFileMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMessageParameters
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingFileMessageParameters
- getPaths() - Method in interface org.apache.flink.runtime.io.disk.FileChannelManager
-
Gets all the files corresponding to the config temp dirs.
- getPaths() - Method in class org.apache.flink.runtime.io.disk.FileChannelManagerImpl
- getPayload() - Method in class org.apache.flink.runtime.asyncprocessing.StateRequest
- getPayload() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Returns the set payload or null if none.
- getPayload() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
- getPendingCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
- getPendingCheckpointStats(long) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
- getPendingCheckpointStats(long) - Method in class org.apache.flink.runtime.checkpoint.DefaultCheckpointStatsTracker
- getPendingCheckpointStats(long) - Method in enum org.apache.flink.runtime.checkpoint.NoOpCheckpointStatsTracker
- getPendingRequests() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlotRequestBulk
-
Returns
ResourceProfiles of pending physical slot requests. - getPendingResource() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ClusterResourceStatisticsProvider
-
Get profile of total pending resources.
- getPendingResource() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- getPendingSlotAllocationRecords() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingTaskManager
- getPendingTaskManagerId() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingTaskManager
- getPendingTaskManagers() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- getPendingTaskManagersByTotalAndDefaultSlotResourceProfile(ResourceProfile, ResourceProfile) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- getPendingTaskManagersToAllocate() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceAllocationResult
- getPendingTaskManagersToAllocate() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceReconcileResult
- getPendingTaskManagersToRelease() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceReconcileResult
- getPermanentBlobService() - Method in class org.apache.flink.runtime.blob.BlobCacheService
- getPermanentBlobService() - Method in class org.apache.flink.runtime.blob.BlobServer
- getPermanentBlobService() - Method in interface org.apache.flink.runtime.blob.BlobService
-
Returns a BLOB service for accessing permanent BLOBs.
- getPermanentBlobService() - Method in interface org.apache.flink.runtime.blob.TaskExecutorBlobService
- getPersistedData() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
- getPersistedData() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
- getPersistedData() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
- getPersistedData() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
- getPersistedData() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
- getPersistedDataStats() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummary
- getPersistedDataStats() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummarySnapshot
- getPersistedDataStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
- getPersistedDataStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
- getPersistentDataSetId() - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
- getPhysicalFile() - Method in class org.apache.flink.runtime.checkpoint.filemerging.LogicalFile
- getPhysicalSlot() - Method in class org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlotRequest.Result
- getPhysicalSlotNumber() - Method in interface org.apache.flink.runtime.jobmaster.SlotInfo
-
Gets the number of the slot.
- getPhysicalSlotResourceProfile() - Method in class org.apache.flink.runtime.clusterframework.types.SlotProfile
-
Returns the desired resource profile for the physical slot to host this task slot.
- getPipelinedRegionOfVertex(ExecutionVertexID) - Method in class org.apache.flink.runtime.scheduler.adapter.DefaultExecutionTopology
- getPipelinedRegionOfVertex(VID) - Method in interface org.apache.flink.runtime.topology.Topology
-
The pipelined region for a specified vertex.
- getPluginManager() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
- getPoolSize(Configuration) - Static method in class org.apache.flink.runtime.entrypoint.ClusterEntrypointUtils
-
Gets and verify the io-executor pool size based on configuration.
- getPoolSizeCheckInterval() - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageUtils
-
Get the pool size check interval.
- getPort() - Method in class org.apache.flink.runtime.blob.AbstractBlobCache
-
Returns the port the BLOB server is listening on.
- getPort() - Method in class org.apache.flink.runtime.blob.BlobCacheService
- getPort() - Method in class org.apache.flink.runtime.blob.BlobServer
-
Returns the port on which the server is listening.
- getPort() - Method in interface org.apache.flink.runtime.blob.BlobService
-
Returns the port of the BLOB server that this BLOB service is working with.
- getPort() - Method in class org.apache.flink.runtime.scheduler.exceptionhistory.ExceptionHistoryEntry.ArchivedTaskManagerLocation
- getPort() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
Gets the port of the master (JobManager), where the program will be executed.
- getPos() - Method in class org.apache.flink.runtime.state.CompressibleFSDataInputStream
- getPos() - Method in class org.apache.flink.runtime.state.CompressibleFSDataOutputStream
- getPos() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
- getPos() - Method in class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
- getPos() - Method in class org.apache.flink.runtime.state.filesystem.FileMergingCheckpointStateOutputStream
- getPos() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
- getPos() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
- getPos() - Method in class org.apache.flink.runtime.state.filesystem.FsSegmentDataInputStream
- getPos() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
- getPosition() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileSegment
- getPostCheckpointAction() - Method in class org.apache.flink.runtime.checkpoint.SavepointType
- getPreferredAllocations() - Method in class org.apache.flink.runtime.clusterframework.types.SlotProfile
-
Returns the desired allocation ids for the slot.
- getPreferredLocationBasedOnState() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
Gets the preferred location to execute the current task execution attempt, based on the state that the execution attempt will resume.
- getPreferredLocationBasedOnState() - Method in class org.apache.flink.runtime.executiongraph.SpeculativeExecutionVertex
- getPreferredLocations() - Method in class org.apache.flink.runtime.clusterframework.types.SlotProfile
-
Returns the preferred locations for the slot.
- getPreferredLocations(ExecutionVertexID, Set<ExecutionVertexID>) - Method in class org.apache.flink.runtime.scheduler.DefaultPreferredLocationsRetriever
- getPreferredLocations(ExecutionVertexID, Set<ExecutionVertexID>) - Method in interface org.apache.flink.runtime.scheduler.PreferredLocationsRetriever
-
Returns preferred locations of an execution vertex.
- getPreferredLocations(ExecutionVertexID, Set<ExecutionVertexID>) - Method in interface org.apache.flink.runtime.scheduler.SyncPreferredLocationsRetriever
-
Returns preferred locations of an execution vertex.
- getPreferredResources() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Gets the preferred resource for the task.
- getPreferredResources() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Gets the preferred resources for this operator.
- getPreferredResources() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getPreferredSnapshotExecutionType() - Method in class org.apache.flink.runtime.state.SavepointResources
- getPreProcessingOperationName() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Gets the name of the pro-processing operation for this input.
- getPreviousElementSerializer() - Method in class org.apache.flink.runtime.state.RegisteredPriorityQueueStateBackendMetaInfo
- getPreviousGlobalAggregate(String) - Method in class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
- getPreviousKeySerializer() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
- getPreviousNamespaceSerializer() - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
- getPreviousPartitionStateSerializer() - Method in class org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
- getPreviousSerializerSnapshot() - Method in class org.apache.flink.runtime.state.StateSerializerProvider
-
Gets the previous serializer snapshot.
- getPreviousStateSerializer() - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
- getPreviousStateSerializerSnapshot() - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
- getPreviousValueSerializer() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
- getPrincipal() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
- getPrioritizedInputChannelState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
- getPrioritizedManagedKeyedState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns an immutable list with all alternative snapshots to restore the managed keyed state, in the order in which we should attempt to restore.
- getPrioritizedManagedOperatorState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns an immutable list with all alternative snapshots to restore the managed operator state, in the order in which we should attempt to restore.
- getPrioritizedRawKeyedState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns an immutable list with all alternative snapshots to restore the raw keyed state, in the order in which we should attempt to restore.
- getPrioritizedRawOperatorState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns an immutable list with all alternative snapshots to restore the raw operator state, in the order in which we should attempt to restore.
- getPrioritizedResultSubpartitionState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
- getPriority() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.Mail
- getPriority(TieredStoragePartitionId, TieredStorageSubpartitionId, int, int, PartitionFileReader.ReadProgress) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.PartitionFileReader
-
Get the priority for reading a particular buffer from the partitioned file.
- getPriority(TieredStoragePartitionId, TieredStorageSubpartitionId, int, int, PartitionFileReader.ReadProgress) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.ProducerMergedPartitionFileReader
- getPriority(TieredStoragePartitionId, TieredStorageSubpartitionId, int, int, PartitionFileReader.ReadProgress) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.SegmentPartitionFileReader
- getPriorityEventAvailableFuture() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
Notifies when a priority event has been enqueued.
- getPriorityEventAvailableFuture() - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
- getPriorityQueue() - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueSnapshotRestoreWrapper
- getPrivateState() - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
- getProber(TypeComparator<PT>, TypePairComparator<PT, T>) - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
- getProber(TypeComparator<PT>, TypePairComparator<PT, T>) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
- getProber(TypeComparator<PT>, TypePairComparator<PT, T>) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
- getProbeSideBlockCount() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
- getProbeSideChannel() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
- getProbeSideComparator() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
- getProbeSideRecordCount() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
- getProcessedData() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
- getProcessedData() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
- getProcessedData() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
- getProcessedData() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
- getProcessedData() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
- getProcessedDataStats() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummary
- getProcessedDataStats() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummarySnapshot
- getProcessedDataStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
- getProcessedDataStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
- getProcessingTimeDelay(long, long) - Static method in class org.apache.flink.streaming.runtime.tasks.ProcessingTimeServiceUtil
-
Returns the remaining delay of the processing time specified by
processingTimestamp. - getProcessingTimeService() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Returns the
ProcessingTimeServiceresponsible for getting the current processing time and registering timers. - getProcessingTimeService() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
Returns the
ProcessingTimeServiceresponsible for getting the current processing time and registering timers. - getProcessingTimeService() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
- getProcessingTimeService() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorParameters
- getProcessingTimeServiceFactory() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- getProcessingTimeTimers() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
- getProcessorsCount() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
- getProducedDataSets() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- getProducedDataSets() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- getProducedPartitions() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
- getProducedPartitions() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getProducedResults() - Method in class org.apache.flink.runtime.jobgraph.topology.DefaultLogicalVertex
- getProducedResults() - Method in interface org.apache.flink.runtime.topology.Vertex
- getProducedType() - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ArrayKeySelector
- getProducedType() - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ComparableKeySelector
- getProducer() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
- getProducer() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
- getProducer() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
- getProducer() - Method in class org.apache.flink.runtime.jobgraph.topology.DefaultLogicalResult
- getProducer() - Method in interface org.apache.flink.runtime.topology.Result
- getProducerAgentMemorySpec() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskTierFactory
- getProducerAgentMemorySpec() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory.MemoryTierFactory
- getProducerAgentMemorySpec() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierFactory
- getProducerAgentMemorySpec() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierFactory
-
Get the
TieredStorageMemorySpecof the producer-side agent. - getProducerExecutionId() - Method in class org.apache.flink.runtime.shuffle.ProducerDescriptor
- getProducerExecutionState() - Method in interface org.apache.flink.runtime.io.network.partition.PartitionProducerStateProvider.ResponseHandle
- getProducerId() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionID
- getProducerLocation() - Method in class org.apache.flink.runtime.shuffle.ProducerDescriptor
- getProducersOfConsumedPartitionGroup(ConsumedPartitionGroup) - Method in class org.apache.flink.runtime.scheduler.ExecutionGraphToInputsLocationsRetrieverAdapter
- getProducersOfConsumedPartitionGroup(ConsumedPartitionGroup) - Method in interface org.apache.flink.runtime.scheduler.InputsLocationsRetriever
-
Get the producer execution vertices of a consumed result partition group.
- getProducerVertexId() - Method in class org.apache.flink.runtime.jobgraph.topology.DefaultLogicalEdge
- getProducerVertexId() - Method in interface org.apache.flink.runtime.jobgraph.topology.LogicalEdge
-
Returns the ID of producer vertex.
- getProfilingInfos() - Method in class org.apache.flink.runtime.rest.messages.ProfilingInfoList
- getProfilingList(String) - Method in class org.apache.flink.runtime.util.profiler.ProfilingService
- getProfilingMode() - Method in class org.apache.flink.runtime.rest.messages.ProfilingInfo
- getProfilingResultDir() - Method in class org.apache.flink.runtime.util.profiler.ProfilingService
- getProperties() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the properties of this checkpoint.
- getProperties() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
- getProperties() - Method in class org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
-
Returns the properties of the restored checkpoint.
- getProxyPortRange() - Method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
-
Returns the port range where the queryable state client proxy can listen.
- getPushChainDriverClass() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
- getQuantile(double) - Method in class org.apache.flink.runtime.checkpoint.StatsSummarySnapshot
-
Returns the value for the given quantile based on the represented histogram statistics or
Double.NaNif the histogram was not built. - getQuantile(double) - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
- getQueryableStateName() - Method in class org.apache.flink.streaming.api.datastream.QueryableStateStream
-
Deprecated.Returns the name under which the state can be queried.
- getQueryParameter(Class<QP>) - Method in class org.apache.flink.runtime.rest.handler.HandlerRequest
-
Returns the value of the
MessageQueryParameterfor the given class. - getQueryParameter(HandlerRequest<R>, Class<P>) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRequestUtils
-
Returns the value of a query parameter, or
nullif the query parameter is not set. - getQueryParameter(HandlerRequest<R>, Class<P>, X) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRequestUtils
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerMessageParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatusMessageParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointTriggerMessageParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.cluster.FileMessageParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.cluster.ProfilingFileMessageParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteStatusMessageParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteTriggerMessageParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.EmptyMessageParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.coordination.ClientCoordinationMessageParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.JobExceptionsMessageParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsMessageParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerOperatorMetricsMessageParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsMessageParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexMetricsMessageParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsMessageParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsMessageParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusMessageParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusMessageParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerMessageParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsMessageParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.JobCancellationMessageParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.JobClientHeartbeatParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.JobMessageParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.JobVertexFlameGraphParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.JobVertexMessageParameters
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.MessageParameters
-
Returns the collection of
MessageQueryParameterthat the request supports. - getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMessageParameters
- getQueryServiceMessageSizeLimit() - Method in class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
- getQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Returns the metric query service scope for this group.
- getRangeFraction(MemorySize, MemorySize, ConfigOption<Float>, Configuration) - Static method in class org.apache.flink.runtime.util.config.memory.ProcessMemoryUtils
- getRate() - Method in class org.apache.flink.runtime.metrics.ThresholdMeter
- getRawKeyedOperatorStateOutput() - Method in interface org.apache.flink.runtime.state.StateSnapshotContext
-
Returns an output stream for keyed state
- getRawKeyedOperatorStateOutput() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
- getRawKeyedState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
- getRawKeyedState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
Deprecated.
- getRawKeyedStateHandles(OperatorState, KeyGroupRange) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
- getRawKeyedStateInputs() - Method in interface org.apache.flink.runtime.state.StateInitializationContext
-
Returns an iterable to obtain input streams for previously stored keyed state partitions that are assigned to this operator.
- getRawKeyedStateInputs() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
- getRawOperatorState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
- getRawOperatorState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
Deprecated.
- getRawOperatorStateInputs() - Method in interface org.apache.flink.runtime.state.StateInitializationContext
-
Returns an iterable to obtain input streams for previously stored operator state partitions that are assigned to this operator.
- getRawOperatorStateInputs() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
- getRawOperatorStateOutput() - Method in interface org.apache.flink.runtime.state.StateSnapshotContext
-
Returns an output stream for operator state
- getRawOperatorStateOutput() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
- getReadBuffers() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.PartitionFileReader.ReadBufferResult
- getReadEndAfterSuperstepEnded() - Method in class org.apache.flink.runtime.iterative.concurrent.BlockingBackChannel
-
Called by iteration head after it has sent all input for the current superstep through the data channel (blocks iteration head).
- getReader(int) - Static method in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshotReadersWriters
-
Returns a reader for
StateMetaInfoSnapshotwith the requested state type and version number. - getReaderForVersion(int, ClassLoader) - Static method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters
- getReaderIndex() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Returns the reader index of this buffer.
- getReaderIndex() - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- getReaderIndex() - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- getReaderIndex() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- getReaderIndex() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- getReadPosition() - Method in class org.apache.flink.runtime.io.disk.RandomAccessInputView
- getReadProgress() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.PartitionFileReader.ReadBufferResult
- getReadyToServeFuture() - Method in class org.apache.flink.runtime.resourcemanager.active.ActiveResourceManager
- getReadyToServeFuture() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
Get the ready to serve future of the resource manager.
- getReadyToServeFuture() - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
- getReason() - Method in class org.apache.flink.runtime.jobmaster.JMTMRegistrationRejection
- getReason() - Method in class org.apache.flink.runtime.registration.RegistrationResponse.Failure
-
Gets the reason for the failure.
- getReason() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationRejection
- getReceiveRatePerInterface(int) - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
- getReceiverId() - Method in class org.apache.flink.runtime.io.network.netty.NettyPartitionRequestListener
- getReceiverId() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
- getReceiverId() - Method in interface org.apache.flink.runtime.io.network.partition.PartitionRequestListener
-
Get the input channel id of the notifier.
- getReceiveTimestamp() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetaData
- getRecentExpiredCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
- getRecord() - Method in class org.apache.flink.runtime.asyncprocessing.RecordContext
- getRecord(int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
- getRecord(int) - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Gets the record at the given logical position.
- getRecord(int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
- getRecord(T, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
- getRecord(T, int) - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Gets the record at the given logical position.
- getRecord(T, int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
- getRecordContext() - Method in class org.apache.flink.runtime.asyncprocessing.StateRequest
- getRecordCount() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
number of records in partition including garbage
- getRecordProcessor(int) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperator
- getRecordProcessor(int) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperatorV2
- getRecordProcessor(int) - Method in interface org.apache.flink.streaming.runtime.operators.asyncprocessing.AsyncStateProcessing
-
Get the record processor that could process record from input, which is the only entry for async processing.
- getRecordProcessor(Input<T>) - Static method in class org.apache.flink.streaming.runtime.io.RecordProcessorUtils
-
Get record processor for
Input, which will omit call ofInput.setKeyContextElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IN>)if it doesn't have key context. - getRecordProcessor1(TwoInputStreamOperator<T, ?, ?>) - Static method in class org.apache.flink.streaming.runtime.io.RecordProcessorUtils
-
Get record processor for the first input of
TwoInputStreamOperator, which will omit call ofStreamOperator.setKeyContextElement1(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<?>)if it doesn't have key context. - getRecordProcessor2(TwoInputStreamOperator<?, T, ?>) - Static method in class org.apache.flink.streaming.runtime.io.RecordProcessorUtils
-
Get record processor for the second input of
TwoInputStreamOperator, which will omit call ofStreamOperator.setKeyContextElement2(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<?>)if it doesn't have key context. - getRecordsRead() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- getRecordsWritten() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- getRecordWriter(int) - Method in class org.apache.flink.runtime.io.network.api.writer.MultipleRecordWriters
- getRecordWriter(int) - Method in class org.apache.flink.runtime.io.network.api.writer.NonRecordWriter
- getRecordWriter(int) - Method in interface org.apache.flink.runtime.io.network.api.writer.RecordWriterDelegate
-
Returns the internal actual record writer instance based on the output index.
- getRecordWriter(int) - Method in class org.apache.flink.runtime.io.network.api.writer.SingleRecordWriter
- getRecoveryClaimMode() - Method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
-
Tells how to restore from the given savepoint.
- getRecursionLevel() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
Gets this partition's recursion level.
- getRecycler() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Gets the buffer's recycler.
- getRecycler() - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- getRecycler() - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- getRecycler() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- getRecycler() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- getRedirectResponse(String, String, HttpResponseStatus) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRedirectUtils
- getReduceFunction() - Method in class org.apache.flink.runtime.state.v2.ReducingStateDescriptor
-
Returns the reduce function to be used for the reducing state.
- getReducer() - Method in class org.apache.flink.streaming.api.transformations.ReduceTransformation
- getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
- getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
- getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
- getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.v2.DefaultKeyedStateStoreV2
- getReducingState(ReducingStateDescriptor<T>) - Method in interface org.apache.flink.runtime.state.v2.KeyedStateStoreV2
-
Gets a handle to the system's key/value reducing state.
- getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
- getRedundantTaskManagerNum() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
- getReferenceBytes() - Method in class org.apache.flink.runtime.state.CheckpointStorageLocationReference
-
Gets the reference bytes.
- getReferenceCount() - Method in class org.apache.flink.runtime.asyncprocessing.ReferenceCounted
- getRefreshInterval() - Method in class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
- getRefreshInterval() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
- getRefusedDelayMillis() - Method in class org.apache.flink.runtime.registration.RetryingRegistrationConfiguration
- getRegionEndOffset() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.index.FileDataIndexRegionHelper.Region
-
Get the file end offset of the region.
- getRegionEndOffset() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.ProducerMergedPartitionFileIndex.FixedSizeRegion
- getRegionStartOffset() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.index.FileDataIndexRegionHelper.Region
-
Get the file start offset of this region.
- getRegionStartOffset() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.ProducerMergedPartitionFileIndex.FixedSizeRegion
- getRegisteredBroadcastStateNames() - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
- getRegisteredComponentIds() - Method in class org.apache.flink.runtime.leaderelection.LeaderInformationRegister
-
Returns the
componentIds for which leader information is stored. - getRegisteredExecutions() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getRegisteredExecutions() - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- getRegisteredPQStates() - Method in class org.apache.flink.runtime.state.HeapPriorityQueuesManager
- getRegisteredResource() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ClusterResourceStatisticsProvider
-
Get profile of total registered resources.
- getRegisteredResource() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedSlotManager
- getRegisteredResource() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- getRegisteredResource() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
- getRegisteredResourceOf(InstanceID) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ClusterResourceStatisticsProvider
-
Get profile of registered resources from the TaskManager with the given instance id.
- getRegisteredResourceOf(InstanceID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedSlotManager
- getRegisteredResourceOf(InstanceID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- getRegisteredResourceOf(InstanceID) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
- getRegisteredStateMetaInfoBase() - Method in class org.apache.flink.runtime.state.RegisteredStateMetaInfoBase.Key
- getRegisteredStateNames() - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
- getRegisteredTaskManager(InstanceID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- getRegisteredTaskManagers() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- getRegistrationId() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
-
Gets the ID that the ResourceManager assigned the registration.
- getRegistrationName() - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Returns the name under which the KvState instances have been registered.
- getRegularInput() - Method in class org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
- getRelativeBackChannelMemory() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getRelativeInputMaterializationMemory(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getRelativeMemoryDriver() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getRelativeMemoryInput(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getRelativePath() - Method in class org.apache.flink.runtime.state.filesystem.RelativeFileStateHandle
- getRelativeSolutionSetMemory() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getRelativeTimeMillis() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolService
- getReleaseFuture() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Gets the release future which is completed once the execution reaches a terminal state and the assigned resource has been released.
- getReleasePartitions() - Method in class org.apache.flink.runtime.executiongraph.TaskExecutionStateTransition
- getRemoteMaterializedStateHandles() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendLocalHandle
- getRemoteNonMaterializedStateHandles() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendLocalHandle
- getRemoteTierName() - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageUtils
- getRemoveKeys() - Method in class org.apache.flink.runtime.entrypoint.ModifiableClusterConfiguration
- getRemoveKeyValues() - Method in class org.apache.flink.runtime.entrypoint.ModifiableClusterConfiguration
- getReplaceKeyValues() - Method in class org.apache.flink.runtime.entrypoint.ModifiableClusterConfiguration
- getReporter() - Method in class org.apache.flink.runtime.metrics.ReporterSetup
- getReporter() - Method in class org.apache.flink.runtime.metrics.TraceReporterSetup
- getReporterIndex() - Method in class org.apache.flink.runtime.metrics.groups.ReporterScopedSettings
- getReporters() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
- getRepresentativeAttempt() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails.CurrentAttempts
- getRepresentativeAttempts() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
- getRequest() - Method in class org.apache.flink.runtime.rest.handler.router.RoutedRequest
- getRequestBody() - Method in class org.apache.flink.runtime.rest.handler.HandlerRequest
-
Returns the request body.
- getRequestClass() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatusHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointTriggerHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerCustomLogHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerLogFileHeader
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerLogListHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerProfilingFileHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerProfilingHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerProfilingListHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerStdoutFileHeader
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerThreadDumpHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.CustomHeadersDecorator
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteStatusHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteTriggerHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetListHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.coordination.ClientCoordinationHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobManagerJobConfigurationHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobManagerJobEnvironmentHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobResourceRequirementsHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobResourcesRequirementsUpdateHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobStatusInfoHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexWatermarksHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointTriggerHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobCancellationHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobClientHeartbeatHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobManagerEnvironmentHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobManagerLogUrlHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexFlameGraphHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerCustomLogHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogsHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingFileHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingListHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerStdoutFileHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerThreadDumpHeaders
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.TaskManagerLogUrlHeaders
- getRequestClass() - Method in interface org.apache.flink.runtime.rest.messages.UntypedResponseMessageHeaders
-
Returns the class of the request message.
- getRequestId() - Method in class org.apache.flink.runtime.messages.TaskBackPressureResponse
- getRequestId() - Method in class org.apache.flink.runtime.webmonitor.threadinfo.ThreadInfoSamplesRequest
-
Returns the ID of the sampling request.
- getRequestId() - Method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexThreadInfoStats
-
Returns the ID of the sample.
- getRequestSegmentsTimeout() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- getRequestType() - Method in class org.apache.flink.runtime.asyncprocessing.AbstractStateIterator
- getRequestType() - Method in class org.apache.flink.runtime.asyncprocessing.StateRequest
- getRequiredClasspathURLs() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
- getRequiredJarFileBlobKeys() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
- getRequirementCheckDelay() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
- getRescaleOnFailedCheckpointCount() - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler.Settings
- getReservedAllocations() - Method in class org.apache.flink.runtime.clusterframework.types.SlotProfile
-
Returns a set of all reserved allocation ids from the execution graph.
- getResource() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.SlotInfo
- getResourceAllocator() - Method in class org.apache.flink.runtime.resourcemanager.active.ActiveResourceManager
- getResourceAllocator() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- getResourceAllocator() - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
- getResourceCount(ResourceProfile) - Method in class org.apache.flink.runtime.util.ResourceCounter
-
Number of resources with the given
ResourceProfile. - getResourceEventHandler() - Method in class org.apache.flink.runtime.resourcemanager.active.AbstractResourceManagerDriver
- getResourceHandle() - Method in class org.apache.flink.runtime.memory.OpaqueMemoryResource
-
Gets the handle to the resource.
- getResourceId() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerProcessContext
- getResourceId() - Method in class org.apache.flink.runtime.resourcemanager.TaskExecutorRegistration
- getResourceId() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- getResourceId() - Method in interface org.apache.flink.runtime.taskexecutor.JobTable.Connection
- getResourceID() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceID
-
A ResourceID can always retrieve a ResourceID.
- getResourceID() - Method in interface org.apache.flink.runtime.clusterframework.types.ResourceIDRetrievable
-
Gets the ResourceID of the object.
- getResourceID() - Method in class org.apache.flink.runtime.clusterframework.types.SlotID
- getResourceID() - Method in class org.apache.flink.runtime.io.network.ConnectionID
- getResourceID() - Method in class org.apache.flink.runtime.jobmaster.JMTMRegistrationSuccess
- getResourceID() - Method in class org.apache.flink.runtime.resourcemanager.registration.TaskExecutorConnection
- getResourceID() - Method in class org.apache.flink.runtime.scheduler.exceptionhistory.ExceptionHistoryEntry.ArchivedTaskManagerLocation
- getResourceID() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- getResourceID() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
- getResourceID() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
Gets the ID of the resource in which the TaskManager is started.
- getResourceID() - Method in class org.apache.flink.runtime.taskmanager.UnresolvedTaskManagerLocation
- getResourceIdString() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceID
-
Gets the Resource Id as string.
- getResourceManagerGateway(GatewayRetriever<ResourceManagerGateway>) - Static method in class org.apache.flink.runtime.rest.handler.resourcemanager.AbstractResourceManagerHandler
- getResourceManagerGatewayRetriever() - Method in class org.apache.flink.runtime.dispatcher.DispatcherServices
- getResourceManagerGatewayRetriever() - Method in class org.apache.flink.runtime.dispatcher.PartialDispatcherServices
- getResourceManagerId() - Method in class org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess
- getResourceManagerId() - Method in class org.apache.flink.runtime.jobmaster.ResourceManagerAddress
- getResourceManagerId() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
-
Gets the unique ID that identifies the ResourceManager.
- getResourceManagerLeaderElection() - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
- getResourceManagerLeaderElection() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the
LeaderElectionfor the cluster's resource manager. - getResourceManagerLeaderElection() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
- getResourceManagerLeaderElection() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
- getResourceManagerLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
- getResourceManagerLeaderRetriever() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the leader retriever for the cluster's resource manager.
- getResourceManagerLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
- getResourceManagerLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
- getResourceManagerNode() - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
- getResourceManagerResourceId() - Method in class org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess
- getResourceOverview() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- getResourceProfile() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
Returns the resource profile for this job vertex.
- getResourceProfile() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
- getResourceProfile() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- getResourceProfile() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getResourceProfile() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
- getResourceProfile() - Method in interface org.apache.flink.runtime.jobmaster.SlotInfo
-
Returns the resource profile of the slot.
- getResourceProfile() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerSlot
- getResourceProfile() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerSlotInformation
-
Get resource profile of this slot.
- getResourceProfile() - Method in class org.apache.flink.runtime.slots.ResourceRequirement
- getResourceProfile() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotAllocationSnapshot
- getResourceProfile() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotOffer
- getResourceProfile() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
- getResourceProfile() - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
-
Get the resource profile of this slot.
- getResourceRequirements() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPool
-
Returns the current resource requirements.
- getResourceRequirements() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultDeclarativeSlotPool
- getResourceRequirements() - Method in class org.apache.flink.runtime.slots.ResourceRequirements
- getResources() - Method in class org.apache.flink.runtime.util.ResourceCounter
-
Gets all stored
ResourceProfiles. - getResourcesWithCount() - Method in class org.apache.flink.runtime.util.ResourceCounter
-
Gets the stored resources and their counts.
- getResponse(HttpResponseStatus, String) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRedirectUtils
- getResponseClass() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationStatusMessageHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationTriggerMessageHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerLogListHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerProfilingHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerProfilingListHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerThreadDumpHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.CustomHeadersDecorator
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetListHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.coordination.ClientCoordinationHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobManagerJobConfigurationHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobManagerJobEnvironmentHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobResourceRequirementsHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobResourcesRequirementsUpdateHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobStatusInfoHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexWatermarksHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobCancellationHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobClientHeartbeatHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobManagerEnvironmentHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobManagerLogUrlHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexFlameGraphHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
- getResponseClass() - Method in interface org.apache.flink.runtime.rest.messages.MessageHeaders
-
Returns the class of the response message.
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogsHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingListHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerThreadDumpHeaders
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.TaskManagerLogUrlHeaders
- getResponseHeaders() - Method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
-
Response headers that should be added to every HTTP response.
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatusHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointTriggerHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerLogListHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerProfilingHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerProfilingListHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerThreadDumpHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.CustomHeadersDecorator
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteStatusHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteTriggerHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetListHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.coordination.ClientCoordinationHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.JobManagerJobConfigurationHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.JobManagerJobEnvironmentHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.JobResourceRequirementsHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.JobResourcesRequirementsUpdateHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.JobStatusInfoHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexWatermarksHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointTriggerHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobCancellationHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobClientHeartbeatHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobManagerEnvironmentHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobManagerLogUrlHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobVertexFlameGraphHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
- getResponseStatusCode() - Method in interface org.apache.flink.runtime.rest.messages.MessageHeaders
-
Returns the http status code for the response.
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogsHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingListHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerThreadDumpHeaders
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.TaskManagerLogUrlHeaders
- getResponseTypeParameters() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationStatusMessageHeaders
- getResponseTypeParameters() - Method in class org.apache.flink.runtime.rest.messages.CustomHeadersDecorator
- getResponseTypeParameters() - Method in interface org.apache.flink.runtime.rest.messages.MessageHeaders
-
Returns the collection of type parameters for the response type.
- getRestAddress() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- getRestAddress() - Method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
- getRestartDelayMS() - Method in class org.apache.flink.runtime.executiongraph.failover.FailureHandlingResult
-
Returns the delay before the restarting.
- getRestartStrategy() - Method in class org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
- getRestBaseUrl() - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
-
Returns the base URL of the REST server endpoint.
- getRestBindAddress() - Method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
-
Returns the address that the REST server endpoint should bind itself to.
- getRestBindPortRange() - Method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
-
Returns the port range that the REST server endpoint should listen on.
- getRestoreCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.JobManagerTaskRestore
- getRestoreCheckpointId() - Method in interface org.apache.flink.runtime.state.TaskStateManager
-
Acquires the checkpoint id to restore from.
- getRestoreCheckpointId() - Method in class org.apache.flink.runtime.state.TaskStateManagerImpl
- getRestoredCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns the checkpoint id if this was created for a restored operator, null otherwise.
- getRestoredCheckpointId() - Method in interface org.apache.flink.runtime.state.ManagedInitializationContext
-
Returns id of the restored checkpoint, if state was restored from the snapshot of a previous execution.
- getRestoredCheckpointId() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
- getRestoredCheckpointId() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
-
Returns non-empty if the states provided by this context are restored from a checkpoint/savepoint.
- getRestoredCheckpointStatistics() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
- getRestoredKeyGroups() - Method in class org.apache.flink.runtime.state.restore.SavepointRestoreResult
- getRestoredProperties() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
- getRestorePath() - Method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
-
Returns the path to the savepoint to restore from.
- getRestoreTimestamp() - Method in class org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
-
Returns the timestamp when the checkpoint was restored.
- getRestoreTimestamp() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
- getRestPort() - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
- getRestPort() - Method in class org.apache.flink.runtime.entrypoint.component.DispatcherResourceManagerComponent
- getRestPort() - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
- getRestPort() - Method in interface org.apache.flink.runtime.rest.RestService
-
Port of the running rest service.
- getRestServerNode() - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
- getResult() - Method in class org.apache.flink.runtime.rest.handler.async.OperationResult
- getResultFuture() - Method in class org.apache.flink.runtime.dispatcher.cleanup.CheckpointResourcesCleanupRunner
- getResultFuture() - Method in class org.apache.flink.runtime.jobmaster.DefaultJobMasterServiceProcess
- getResultFuture() - Method in interface org.apache.flink.runtime.jobmaster.JobManagerRunner
-
Get the result future of this runner.
- getResultFuture() - Method in class org.apache.flink.runtime.jobmaster.JobMasterServiceLeadershipRunner
- getResultFuture() - Method in interface org.apache.flink.runtime.jobmaster.JobMasterServiceProcess
-
Future which is completed with the result of job execution.
- getResultFuture() - Method in enum org.apache.flink.runtime.jobmaster.JobMasterServiceProcess.WaitingForLeadership
- getResultId() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
- getResultId() - Method in interface org.apache.flink.runtime.executiongraph.IntermediateResultInfo
-
Get the intermediate result id.
- getResultId() - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingResultPartition
-
Gets id of the intermediate result.
- getResultId() - Method in class org.apache.flink.runtime.shuffle.PartitionDescriptor
- getResultOptimizerProperties() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- getResultPartition(IntermediateResultPartitionID) - Method in class org.apache.flink.runtime.scheduler.adapter.DefaultExecutionTopology
- getResultPartition(IntermediateResultPartitionID) - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingTopology
-
Looks up the
SchedulingResultPartitionfor the givenIntermediateResultPartitionID. - getResultPartitionAvailabilityChecker() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getResultPartitionAvailabilityChecker() - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- getResultPartitionAvailabilityChecker() - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- getResultPartitionBytes() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
- getResultPartitionBytes() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- getResultPartitionDeploymentDescriptor(IntermediateResultPartitionID) - Method in class org.apache.flink.runtime.executiongraph.Execution
- getResultPartitionId() - Method in class org.apache.flink.runtime.io.network.netty.NettyPartitionRequestListener
- getResultPartitionId() - Method in interface org.apache.flink.runtime.io.network.partition.PartitionRequestListener
-
Get the result partition id of the notifier.
- getResultPartitionId() - Method in class org.apache.flink.runtime.io.network.partition.PartitionTrackerEntry
- getResultPartitionId() - Method in class org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionInfo
- getResultPartitionID() - Method in class org.apache.flink.runtime.shuffle.NettyShuffleDescriptor
- getResultPartitionID() - Method in interface org.apache.flink.runtime.shuffle.ShuffleDescriptor
- getResultPartitionID() - Method in class org.apache.flink.runtime.shuffle.UnknownShuffleDescriptor
- getResultPartitionManager() - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
- getResultPartitionOrThrow(IntermediateResultPartitionID) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getResultPartitionOrThrow(IntermediateResultPartitionID) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Gets the intermediate result partition by the given partition ID, or throw an exception if the partition is not found.
- getResultPartitionOrThrow(IntermediateResultPartitionID) - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
- getResultPartitionType() - Method in class org.apache.flink.runtime.scheduler.strategy.ConsumedPartitionGroup
- getResultPartitionType() - Method in class org.apache.flink.runtime.scheduler.strategy.ConsumerVertexGroup
- getResults(TypeSerializer<T>) - Method in class org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
- getResultSubpartitionOffsets() - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStatePendingResult
- getResultSubpartitionState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
- getResultSubpartitionStateFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
- getResultSubpartitionStateHandles() - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter.ChannelStateWriteResult
- getResultType() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
- getResultType() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
- getResultType() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
- getResultType() - Method in class org.apache.flink.runtime.jobgraph.topology.DefaultLogicalResult
- getResultType() - Method in interface org.apache.flink.runtime.topology.Result
- getRetryingRegistrationConfiguration() - Method in class org.apache.flink.runtime.jobmaster.JobMasterConfiguration
- getRetryingRegistrationConfiguration() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
- getReturnQueue() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockReader
-
Gets the queue in which the full memory segments are queued after the asynchronous read is complete.
- getReturnQueue() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockWriter
-
Gets the queue in which the memory segments are queued after the asynchronous write is completed.
- getReturnQueue() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelReader
-
Gets the queue in which the full memory segments are queued after the read is complete.
- getReturnQueue() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelWriter
-
Gets the queue in which the memory segments are queued after the asynchronous write is completed
- getReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
- getReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.FullOuterJoinDriver
- getReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.LeftOuterJoinDriver
- getReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.RightOuterJoinDriver
- getRevisionInformation() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Returns the code revision (commit and commit date) of Flink, as generated by the Maven builds.
- getRightTimestamp() - Method in class org.apache.flink.streaming.api.functions.co.ProcessJoinFunction.Context
- getRmConfig() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerProcessContext
- getRmRuntimeServicesConfig() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerProcessContext
- getRoot() - Method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexFlameGraph
- getRootCause() - Method in class org.apache.flink.runtime.scheduler.exceptionhistory.FailureHandlingResultSnapshot
-
The actual failure that is handled.
- getRootCauseExecution() - Method in class org.apache.flink.runtime.scheduler.exceptionhistory.FailureHandlingResultSnapshot
-
Returns the
Executionthat handled the root cause for this failure. - getRouteResult() - Method in class org.apache.flink.runtime.rest.handler.router.RoutedRequest
- getRpcPort() - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
- getRPCPortRange(Configuration) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
Returns the port range for the common
RpcService. - getRpcService() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerProcessContext
- getRpcServiceSharing() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
- getRpcTimeout() - Method in class org.apache.flink.runtime.jobmaster.JobMasterConfiguration
- getRpcTimeout() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
- getRunningJobIds() - Method in class org.apache.flink.runtime.dispatcher.DefaultJobManagerRunnerRegistry
- getRunningJobIds() - Method in interface org.apache.flink.runtime.dispatcher.JobManagerRunnerRegistry
-
Returns
JobIDinstances of registeredJobManagerRunnerinstances. - getRunningJobIds() - Method in class org.apache.flink.runtime.dispatcher.OnMainThreadJobManagerRunnerRegistry
- getRuntimeContext() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Returns a context that allows the operator to query information about the execution and also to interact with systems such as broadcast variables and managed state.
- getRuntimeContext() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
Returns a context that allows the operator to query information about the execution and also to interact with systems such as broadcast variables and managed state.
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
- getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
- getSampleInterval() - Method in class org.apache.flink.runtime.state.metrics.LatencyTrackingStateConfig
- getSamples() - Method in class org.apache.flink.runtime.messages.TaskThreadInfoResponse
-
Returns a collection of ThreadInfoSample.
- getSamplesBySubtask() - Method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexThreadInfoStats
-
Returns the a map of thread info samples by subtask (execution ID).
- getSavepointPath() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalRequest
- getSavepointPath() - Method in exception org.apache.flink.runtime.scheduler.stopwithsavepoint.StopWithSavepointStoppingException
- getSavepointPath() - Method in interface org.apache.flink.runtime.scheduler.stopwithsavepoint.StopWithSavepointTerminationHandler
-
Returns the a
CompletableFuturereferring to the result of the stop-with-savepoint operation. - getSavepointPath() - Method in class org.apache.flink.runtime.scheduler.stopwithsavepoint.StopWithSavepointTerminationHandlerImpl
- getSavepointPath() - Method in class org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
-
Deprecated.Gets the directory where savepoints are stored by default (when no custom path is given to the savepoint trigger command).
- getSavepointPath() - Method in class org.apache.flink.runtime.state.storage.FileSystemCheckpointStorage
- getSavepointPath() - Method in class org.apache.flink.runtime.state.storage.JobManagerCheckpointStorage
- getSavepointRestoreSettings() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns the configured savepoint restore setting.
- getSavepointRestoreSettings() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getSavepointStatistics() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
- getSavepointStatus(AsynchronousJobOperationKey) - Method in class org.apache.flink.runtime.dispatcher.DispatcherCachedOperationsHandler
- getSavepointTriggerCache() - Method in class org.apache.flink.runtime.dispatcher.DispatcherOperationCaches
- getScalaVersion() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Returns the version of the used Scala compiler as String.
- getScheduledExecutor() - Method in class org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
- getSchedulerType() - Method in class org.apache.flink.runtime.jobmaster.DefaultSlotPoolServiceSchedulerFactory
- getSchedulerType() - Method in interface org.apache.flink.runtime.jobmaster.SlotPoolServiceSchedulerFactory
-
Returns the scheduler type this factory is creating.
- getSchedulerType() - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveSchedulerFactory
- getSchedulerType() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.AdaptiveBatchSchedulerFactory
- getSchedulerType() - Method in class org.apache.flink.runtime.scheduler.DefaultSchedulerFactory
- getSchedulerType() - Method in interface org.apache.flink.runtime.scheduler.SchedulerNGFactory
- getSchedulingTopology() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getSchedulingTopology() - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- getSchedulingTopology() - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- getScope() - Method in class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFile
- getScope() - Method in class org.apache.flink.runtime.state.filemerging.SegmentFileStateHandle
- getScopeComponents() - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Gets the scope as an array of the scope components, for example
["host-7", "taskmanager-2", "window_word_count", "my-mapper"]. - getScopeComponents() - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
- getScopeFormats() - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
-
Returns the scope formats.
- getScopeFormats() - Method in class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
- getScopeFormats() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
- getScopeFormats() - Method in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
- getSecondaryStreamException() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
- getSecondInput() - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
Returns the
BroadcastStream. - getSecondInput() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Returns the second
DataStream. - getSecurityConfig() - Method in class org.apache.flink.runtime.security.modules.HadoopModule
- getSecurityContextFactories() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
- getSecurityModuleFactories() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
- getSegmentBufferContexts() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.PartitionFileWriter.SubpartitionBufferContext
- getSegmentFinishDirPath(String, TieredStoragePartitionId, int) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.SegmentPartitionFile
- getSegmentId() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.PartitionFileWriter.SegmentBufferContext
- getSegmentId() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyPayload
- getSegmentIndexFromPointer(long) - Method in class org.apache.flink.runtime.io.network.partition.SortBuffer
- getSegmentOffsetFromPointer(long) - Method in class org.apache.flink.runtime.io.network.partition.SortBuffer
- getSegmentPath(String, TieredStoragePartitionId, int, long) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.SegmentPartitionFile
- getSegmentSize() - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
Gets the size of the segments used by this view.
- getSelectorForArray(int[], TypeInformation<X>) - Static method in class org.apache.flink.streaming.util.keys.KeySelectorUtil
- getSelectorForKeys(Keys<X>, TypeInformation<X>, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.keys.KeySelectorUtil
- getSelectorForOneKey(Keys<X>, Partitioner<K>, TypeInformation<X>, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.keys.KeySelectorUtil
- getSendAndReceiveBufferSize() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
- getSenderBacklog() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- getSendRatePerInterface(int) - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
- getSequenceNumber() - Method in class org.apache.flink.runtime.io.network.api.EventAnnouncement
- getSequenceNumber() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel.BufferAndAvailability
- getSequenceNumber() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition.BufferAndBacklog
- getSequentialChannelStateReader() - Method in interface org.apache.flink.runtime.state.TaskStateManager
- getSequentialChannelStateReader() - Method in class org.apache.flink.runtime.state.TaskStateManagerImpl
- getSerializationFuture() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getSerializedAccumulatorResults() - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
- getSerializedCheckpointException() - Method in class org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint
-
Gets the reason why the checkpoint was declined.
- getSerializedCoordinationRequest() - Method in class org.apache.flink.runtime.rest.messages.job.coordination.ClientCoordinationRequestBody
- getSerializedCoordinationResponse() - Method in class org.apache.flink.runtime.rest.messages.job.coordination.ClientCoordinationResponseBody
- getSerializedExecutionConfig() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
- getSerializedExecutionConfig() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns the
ExecutionConfig. - getSerializedJobInformation() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory
- getSerializedThrowable() - Method in class org.apache.flink.runtime.jobmaster.JobResult
-
Returns an empty
Optionalif the job finished successfully, otherwise theOptionalwill carry the failure cause. - getSerializedThrowable() - Method in class org.apache.flink.runtime.messages.checkpoint.SerializedCheckpointException
- getSerializedUserAccumulators() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
- getSerializedValue(byte[], TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<SV>) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
- getSerializedValue(byte[], TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<V>) - Method in interface org.apache.flink.runtime.state.internal.InternalKvState
-
Returns the serialized value for the given key and namespace.
- getSerializer() - Method in class org.apache.flink.runtime.state.v2.StateDescriptor
- getSerializer() - Method in class org.apache.flink.streaming.api.functions.source.legacy.FromElementsFunction
-
Deprecated.
- getSerializer(int) - Static method in class org.apache.flink.runtime.checkpoint.metadata.MetadataSerializers
-
Returns the
MetadataSerializerfor the given savepoint version. - getSerializerSnapshotsImmutable() - Method in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
- getServerAddress() - Method in interface org.apache.flink.runtime.query.KvStateServer
-
Returns the
addressthe server is listening to. - getServerAddress() - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
-
Returns the address on which this endpoint is accepting requests.
- getServerChannelHandlers() - Method in class org.apache.flink.runtime.io.network.netty.NettyProtocol
-
Returns the server channel handlers.
- getServerConnectBacklog() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
- getServerNumThreads() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
- getSharedDirHandle() - Method in class org.apache.flink.runtime.state.filemerging.FileMergingOperatorStreamStateHandle
- getSharedMemoryResourceForManagedMemory(String, LongFunctionWithException<T, Exception>, double) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Acquires a shared memory resource, identified by a type string.
- getSharedResources() - Method in interface org.apache.flink.runtime.execution.Environment
- getSharedResources() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
- getSharedResources() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getSharedState() - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
- getSharedStateDirectory() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
- getSharedStateHandle() - Method in class org.apache.flink.runtime.state.filesystem.FsMergingCheckpointStorageLocation
- getSharedStateHandles() - Method in class org.apache.flink.runtime.state.AbstractIncrementalStateHandle
- getSharedStateHandles() - Method in interface org.apache.flink.runtime.state.IncrementalKeyedStateHandle
-
Returns a list of all shared states and the corresponding localPath in the backend at the time this was created.
- getSharedStateHandles() - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
- getSharedStateRegistry() - Method in class org.apache.flink.runtime.checkpoint.AbstractCompleteCheckpointStore
- getSharedStateRegistry() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
Returns the
SharedStateRegistryused to register the shared state. - getSharedStateRegistry() - Method in enum org.apache.flink.runtime.checkpoint.DeactivatedCheckpointCompletedCheckpointStore
- getSharedStateRegistry() - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
- getSharingFilesStrategy() - Method in class org.apache.flink.runtime.checkpoint.CheckpointType
- getSharingFilesStrategy() - Method in class org.apache.flink.runtime.checkpoint.SavepointType
- getSharingFilesStrategy() - Method in interface org.apache.flink.runtime.checkpoint.SnapshotType
- getShipStrategyName() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Gets the name of the ship strategy for the represented input, like "forward", "partition hash", "rebalance", "broadcast", ...
- getShuffleDescriptor() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
- getShuffleDescriptor() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory.ShuffleDescriptorAndIndex
- getShuffleDescriptor() - Method in class org.apache.flink.runtime.executiongraph.PartitionInfo
- getShuffleDescriptor() - Method in class org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionInfo
- getShuffleDescriptorCache() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
- getShuffleDescriptors() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
- getShuffleDescriptors() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup
- getShuffleDescriptors() - Method in class org.apache.flink.runtime.io.network.partition.DataSetMetaInfo
- getShuffleDescriptors() - Method in class org.apache.flink.runtime.taskexecutor.partition.ClusterPartitionReport.ClusterPartitionReportEntry
- getShuffleEnvironment() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
- getShuffleMaster() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getShuffleMaster() - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
- getShuffleMaster() - Method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
- getShuffleMaster() - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.BatchJobRecoveryContext
-
Provides the
ShuffleMasterassociated with the job. - getShuffleMasterSnapshotFuture() - Method in class org.apache.flink.runtime.jobmaster.event.ExecutionVertexFinishedEvent
- getShutDownFuture() - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- getShutDownFuture() - Method in interface org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess.DispatcherGatewayService
- getShutDownFuture() - Method in class org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess
- getShutDownFuture() - Method in class org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherGatewayService
- getShutDownFuture() - Method in class org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherRunner
- getShutDownFuture() - Method in interface org.apache.flink.runtime.dispatcher.runner.DispatcherRunner
-
Return shut down future of this runner.
- getShutDownFuture() - Method in enum org.apache.flink.runtime.dispatcher.runner.StoppedDispatcherLeaderProcess
- getShutDownFuture() - Method in class org.apache.flink.runtime.entrypoint.component.DispatcherResourceManagerComponent
- getShutdownStatus() - Method in class org.apache.flink.runtime.checkpoint.EmbeddedCompletedCheckpointStore
- getSideOutput(OutputTag<X>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Gets the
DataStreamthat contains the elements that are emitted from an operation into the side output with the givenOutputTag. - getSink() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
- getSink() - Method in class org.apache.flink.streaming.runtime.operators.sink.SinkWriterOperatorFactory
- getSinkIDs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getSinkOperatorsUidHashes() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
- getSize() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
- getSize() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
-
Gets the size (in bytes) of the file underlying the channel.
- getSize() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Returns the size of the written data, i.e. the writer index, of this buffer.
- getSize() - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- getSize() - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- getSize() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- getSize() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- getSize() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
- getSize() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.index.FileDataIndexRegionHelper.Region
-
Get the total size in bytes of this region, including the fields and the buffers.
- getSize() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.ProducerMergedPartitionFileIndex.FixedSizeRegion
-
Get the total size in bytes of this region, including the fields and the buffers.
- getSize() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyPayloadManager
- getSize() - Method in class org.apache.flink.runtime.memory.OpaqueMemoryResource
-
Gets the size, in bytes.
- getSize() - Method in class org.apache.flink.runtime.rest.messages.LogInfo
- getSize() - Method in class org.apache.flink.runtime.state.AbstractChannelStateHandle.StateContentMetaInfo
- getSize() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
- getSize() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
- getSize() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
- getSizeOfFreeHeapMemory() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Gets an estimate of the size of the free heap memory.
- getSizeOfFreeHeapMemoryWithDefrag() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Gets an estimate of the size of the free heap memory.
- getSizeOfJvmHeap() - Method in class org.apache.flink.runtime.instance.HardwareDescription
-
Returns the size of the JVM heap memory
- getSizeOfManagedMemory() - Method in class org.apache.flink.runtime.instance.HardwareDescription
-
Returns the size of the memory managed by the system for caching, hashing, sorting, ...
- getSizeOfPhysicalMemory() - Method in class org.apache.flink.runtime.instance.HardwareDescription
-
Returns the size of physical memory in bytes available on the compute node.
- getSizeOfPhysicalMemory() - Static method in class org.apache.flink.runtime.util.Hardware
-
Returns the size of the physical memory in bytes.
- getSizeOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- getSizeOfQueuedBuffersUnsafe() - Method in class org.apache.flink.runtime.io.network.partition.BufferWritingResultPartition
- getSizeOfQueuedBuffersUnsafe() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartition
- getSizeOfQueuedBuffersUnsafe() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Returns the total size in bytes of queued buffers of all subpartitions.
- getSizeOfQueuedBuffersUnsafe() - Method in class org.apache.flink.runtime.io.network.partition.SortMergeResultPartition
- getSkew() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
- getSlide() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
- getSlide() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
- getSlot(Configuration) - Static method in class org.apache.flink.runtime.util.ConfigurationParserUtils
-
Parses the configuration to get the number of slots and validates the value.
- getSlotAllocationSnapshotDirectory() - Method in class org.apache.flink.runtime.entrypoint.WorkingDirectory
- getSlotAllocationSnapshotPersistenceService() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
- getSlotAssignments() - Method in class org.apache.flink.runtime.scheduler.adaptive.JobSchedulingPlan
- getSlotFor(ExecutionVertexID) - Method in class org.apache.flink.runtime.scheduler.adaptive.allocator.ReservedSlots
- getSlotId() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerSlot
- getSlotId() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerSlotInformation
- getSlotID() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotAllocationSnapshot
- getSlotID() - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
-
Get the unique identification of this slot.
- getSlotIdleTimeout() - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler.Settings
- getSlotIndex() - Method in class org.apache.flink.runtime.jobmaster.AllocatedSlotInfo
- getSlotIndex() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotAllocationSnapshot
- getSlotIndex() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotOffer
- getSlotInfo() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSelectionStrategy.SlotInfoAndLocality
- getSlotInfo() - Method in class org.apache.flink.runtime.scheduler.adaptive.JobSchedulingPlan.SlotAssignment
- getSlotInfo(AllocationID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultFreeSlotTracker
- getSlotInfo(AllocationID) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.FreeSlotTracker
-
Get slot info by allocation id, this slot must exist.
- getSlotInformation(AllocationID) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotPool
-
Returns slot information specified by the given allocationId.
- getSlotInformation(AllocationID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultAllocatedSlotPool
- getSlotManager() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
- getSlotManagerConfiguration() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
- getSlotNumber() - Method in class org.apache.flink.runtime.clusterframework.types.SlotID
- getSlotProfile() - Method in class org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlotRequest
- getSlotReport() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorHeartbeatPayload
- getSlotRequestId() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Gets the slot request id uniquely identifying the request with which this slot has been allocated.
- getSlotRequestId() - Method in class org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlotRequest
- getSlotRequestId() - Method in class org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlotRequest.Result
- getSlotRequestId() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
- getSlotRequestTimeout() - Method in class org.apache.flink.runtime.jobmaster.JobMasterConfiguration
- getSlotServiceStatus() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolService
- getSlotSharingGroup() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
Returns the slot sharing group for this job vertex.
- getSlotSharingGroup() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
- getSlotSharingGroup() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- getSlotSharingGroup() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Gets the slot sharing group that this vertex is associated with.
- getSlotSharingGroup() - Method in interface org.apache.flink.runtime.scheduler.adaptive.allocator.JobInformation.VertexInformation
- getSlotSharingGroup() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getSlotSharingGroup() - Method in interface org.apache.flink.streaming.api.graph.TransformationTranslator.Context
-
Returns the slot sharing group for the given transformation.
- getSlotSharingGroup(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Determines the slot sharing group of an operation across virtual nodes.
- getSlotSharingGroupId() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
- getSlotSharingGroupId() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- getSlotSharingGroupResource(String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getSlotSharingGroups() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
- getSlotSharingGroups() - Method in interface org.apache.flink.runtime.scheduler.adaptive.allocator.JobInformation
-
Returns all slot-sharing groups of the job.
- getSlotSharingGroups() - Method in class org.apache.flink.runtime.scheduler.adaptive.JobGraphJobInformation
- getSlotTimeout() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
- getSnapshot() - Method in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
-
Creates a snapshot of this accumulator registry.
- getSnapshotResources() - Method in class org.apache.flink.runtime.state.SavepointResources
- getSoftBackPressuredTimePerSecond() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- getSolutionSetComparator(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getSolutionSetSerializer(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getSortedInputs() - Method in class org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput.SelectableSortingInputs
- getSource() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Returns the data set at the source of the edge.
- getSource() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
- getSourceContext(ProcessingTimeService, Object, Output<StreamRecord<OUT>>, long, long, boolean) - Static method in class org.apache.flink.streaming.api.operators.StreamSourceContexts
-
Deprecated.
- getSourceCoordinators() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- getSourceEvent() - Method in class org.apache.flink.runtime.source.event.SourceEventWrapper
- getSourceId() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Gets the ID of the consumed data set.
- getSourceId() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
- getSourceIDs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getSourceMetricGroup() - Method in class org.apache.flink.streaming.api.operators.SourceOperator
- getSourceNodeId() - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
- getSourceOutput() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain.ChainedSource
- getSourceReader() - Method in class org.apache.flink.streaming.api.operators.SourceOperator
- getSourceTaskInput() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain.ChainedSource
- getSourceTaskInput(StreamConfig.SourceInputConfig) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- getSourceTaskInputs() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- getSourceVertex(StreamEdge) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getSpec() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceDeclaration
- getSpillingDirectories() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Gets the directories that the I/O manager spills to.
- getSpillingDirectoriesPaths() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Gets the directories that the I/O manager spills to, as path strings.
- getSpillingThresholdDriver() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getSpillingThresholdInput(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getSplitAssigner() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- getSplitState() - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
- getSplitState() - Method in interface org.apache.flink.streaming.api.functions.source.TimestampedInputSplit
- getSSLEnabled() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
- getSslHandlerFactory() - Method in class org.apache.flink.runtime.rest.RestClientConfiguration
-
Returns the
SSLEnginethat the REST client endpoint should use. - getSslHandlerFactory() - Method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
-
Returns the
SSLEnginethat the REST server endpoint should use. - getStacktrace() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.ExceptionInfo
- getStackTrace() - Method in class org.apache.flink.runtime.messages.ThreadInfoSample
- getStackTraceLocation() - Method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexFlameGraph.Node
- getStaggerOffset(long, long) - Method in enum org.apache.flink.streaming.api.windowing.assigners.WindowStagger
- getStart() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
Gets the starting timestamp of the window.
- getStartDelay() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
- getStartedFuture() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
Completion of this future indicates that the resource manager is fully started and is ready to serve.
- getStartIndex() - Method in class org.apache.flink.runtime.executiongraph.IndexRange
- getStartKeyGroup() - Method in class org.apache.flink.runtime.state.KeyGroupRange
- getStartOffset() - Method in class org.apache.flink.runtime.checkpoint.filemerging.LogicalFile
- getStartPos() - Method in class org.apache.flink.runtime.state.filemerging.SegmentFileStateHandle
- getStartTime() - Method in class org.apache.flink.runtime.client.JobStatusMessage
- getStartTime() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
- getStartTime() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getStartTime() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- getStartTime() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- getStartTime() - Method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexThreadInfoStats
-
Returns the timestamp, when the sample was triggered.
- getStartTimeCompatible() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- getStartTs() - Method in class org.apache.flink.runtime.checkpoint.SubTaskInitializationMetrics
- getState() - Method in class org.apache.flink.runtime.asyncprocessing.StateRequest
- getState() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
Returns the current
ExecutionStatefor this execution. - getState() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the current
JobStatusfor this execution graph. - getState() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
- getState() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
- getState() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getState() - Method in class org.apache.flink.runtime.executiongraph.Execution
- getState() - Method in interface org.apache.flink.runtime.executiongraph.JobStatusProvider
-
Returns the current
JobStatusfor this execution graph. - getState() - Method in class org.apache.flink.runtime.query.KvStateEntry
- getState() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerSlot
- getState() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerSlotInformation
- getState() - Method in interface org.apache.flink.runtime.scheduler.adaptive.StateFactory
- getState() - Method in class org.apache.flink.runtime.scheduler.JobStatusStore
- getState() - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingExecutionVertex
-
Gets the state of the execution vertex.
- getState() - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingResultPartition
-
Gets the
ResultPartitionState. - getState() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap.StateMapEntry
- getState() - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Returns the internal data structure.
- getState() - Method in interface org.apache.flink.runtime.state.StateEntry
-
Returns the state of this entry.
- getState() - Method in class org.apache.flink.runtime.state.StateEntry.SimpleStateEntry
- getState() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
Returns the current state of the mailbox as defined by the lifecycle enum
TaskMailbox.State. - getState() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
- getState(int) - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- getState(int) - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getState(ValueStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
- getState(ValueStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
- getState(ValueStateDescriptor<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
- getStateBackend() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getStateBackend(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getStateBackendName() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the state backend name for this ExecutionGraph.
- getStateBackendName() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
- getStateBackendName() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getStateChangelogStorage() - Method in interface org.apache.flink.runtime.state.TaskStateManager
-
Returns the configured state changelog storage for this task.
- getStateChangelogStorage() - Method in class org.apache.flink.runtime.state.TaskStateManagerImpl
- getStateChangelogStorageView(Configuration, ChangelogStateHandle) - Method in interface org.apache.flink.runtime.state.TaskStateManager
-
Returns the state changelog storage view of given
ChangelogStateHandlefor this task. - getStateChangelogStorageView(Configuration, ChangelogStateHandle) - Method in class org.apache.flink.runtime.state.TaskStateManagerImpl
- getStateClass() - Method in interface org.apache.flink.runtime.scheduler.adaptive.StateFactory
- getStateConsumedFuture() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
- getStateConsumedFuture() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- getStateConsumedFuture() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
- getStateConsumedFuture() - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
- getStateDescriptor() - Method in class org.apache.flink.runtime.state.v2.AbstractKeyedState
-
Return specific
StateDescriptor. - getStateDescriptor() - Method in class org.apache.flink.streaming.api.datastream.QueryableStateStream
-
Deprecated.Returns the state descriptor for the queryable state instance.
- getStateDescriptor() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
- getStateDescriptor() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorFactory
- getStateDescriptor() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
- getStateDescriptor() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorFactory
- getStateEndTimestamp(ExecutionState) - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
Returns the end timestamp for the given
ExecutionState. - getStateEndTimestamp(ExecutionState) - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
- getStateEndTimestamp(ExecutionState) - Method in class org.apache.flink.runtime.executiongraph.Execution
- getStateEndTimestamps() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
Returns the end timestamps for every
ExecutionState. - getStateEndTimestamps() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
- getStateEndTimestamps() - Method in class org.apache.flink.runtime.executiongraph.Execution
- getStateExecutor() - Method in class org.apache.flink.runtime.asyncprocessing.AsyncExecutionController
- getStateHandleId() - Method in class org.apache.flink.runtime.state.AbstractIncrementalStateHandle
- getStateHandleId() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl
- getStateHandleId() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendLocalHandle
- getStateHandleId() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateHandleStreamImpl
- getStateHandleId() - Method in class org.apache.flink.runtime.state.changelog.inmemory.InMemoryChangelogStateHandle
- getStateHandleId() - Method in interface org.apache.flink.runtime.state.KeyedStateHandle
-
Returns a unique state handle id to distinguish with other keyed state handles.
- getStateHandleId() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
- getStateHandles() - Method in class org.apache.flink.runtime.state.KeyedStateBackendParametersImpl
- getStateHandles() - Method in class org.apache.flink.runtime.state.OperatorStateBackendParametersImpl
- getStateHandles() - Method in interface org.apache.flink.runtime.state.StateBackend.KeyedStateBackendParameters
- getStateHandles() - Method in interface org.apache.flink.runtime.state.StateBackend.OperatorStateBackendParameters
- getStateId() - Method in class org.apache.flink.runtime.state.v2.StateDescriptor
- getStateIncrementalVisitor(int) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
- getStateIncrementalVisitor(int) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
- getStateIncrementalVisitor(int) - Method in class org.apache.flink.runtime.state.heap.StateMap
- getStateIncrementalVisitor(int) - Method in class org.apache.flink.runtime.state.heap.StateTable
- getStateIncrementalVisitor(int) - Method in interface org.apache.flink.runtime.state.internal.InternalKvState
-
Get global visitor of state entries.
- getStateKeySelector() - Method in class org.apache.flink.streaming.api.transformations.LegacySinkTransformation
-
Returns the
KeySelectorthat must be used for partitioning keyed state in this Sink. - getStateKeySelector() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Returns the
KeySelectorthat must be used for partitioning keyed state in this Operation. - getStateKeySelector1() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- getStateKeySelector1() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the
KeySelectorthat must be used for partitioning keyed state in this Operation for the first input. - getStateKeySelector2() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- getStateKeySelector2() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Returns the
KeySelectorthat must be used for partitioning keyed state in this Operation for the second input. - getStateKeySelectors() - Method in class org.apache.flink.streaming.api.transformations.KeyedMultipleInputTransformation
- getStateKeySerializer() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getStateKeySerializer(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getStateKeyType() - Method in class org.apache.flink.streaming.api.transformations.KeyedBroadcastStateTransformation
- getStateKeyType() - Method in class org.apache.flink.streaming.api.transformations.KeyedMultipleInputTransformation
- getStateKeyType() - Method in class org.apache.flink.streaming.api.transformations.LegacySinkTransformation
- getStateKeyType() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
- getStateKeyType() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
- getStateLocation(ExecutionVertexID) - Method in interface org.apache.flink.runtime.scheduler.StateLocationRetriever
-
Returns state location of an execution vertex.
- getStateMapSnapshotForKeyGroup(int) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTableSnapshot
- getStateMetaInfo() - Method in interface org.apache.flink.runtime.state.BackendWritableBroadcastState
- getStateMetaInfo() - Method in class org.apache.flink.runtime.state.HeapBroadcastState
- getStateMetaInfo() - Method in class org.apache.flink.runtime.state.PartitionableListState
- getStateMetaInfoSnapshots() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
- getStateMetaInfoSnapshots() - Method in class org.apache.flink.runtime.state.restore.SavepointRestoreResult
- getStateMetricName(String) - Static method in interface org.apache.flink.runtime.scheduler.metrics.StateTimeMetric
- getStateNameToPartitionOffsets() - Method in interface org.apache.flink.runtime.state.OperatorStateHandle
-
Returns a map of meta data for all contained states by their name.
- getStateNameToPartitionOffsets() - Method in class org.apache.flink.runtime.state.OperatorStreamStateHandle
- getStatePartitioner(int, ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getStatePartitioners() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getStateRequestHandler() - Method in class org.apache.flink.runtime.state.v2.AbstractKeyedState
- getStates() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- getStates() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getStateSerializer() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
- getStateSerializer() - Method in class org.apache.flink.runtime.state.heap.StateTable
- getStateSerializer() - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
- getStateSerializer() - Method in class org.apache.flink.runtime.state.v2.RegisteredKeyValueStateBackendMetaInfo
- getStateServerPortRange() - Method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
-
Returns the port range where the queryable state server can listen.
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the total checkpoint state size over all subtasks.
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
Deprecated.
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
-
Returns the size of the checkpointed state at this subtask.
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
- getStateSize() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
- getStateSize() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- getStateSize() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
- getStateSize() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
- getStateSize() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
- getStateSize() - Method in class org.apache.flink.runtime.state.AbstractChannelStateHandle
- getStateSize() - Method in class org.apache.flink.runtime.state.ChainedStateHandle
- getStateSize() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl
- getStateSize() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendLocalHandle
- getStateSize() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateHandleStreamImpl
- getStateSize() - Method in class org.apache.flink.runtime.state.changelog.inmemory.InMemoryChangelogStateHandle
- getStateSize() - Method in class org.apache.flink.runtime.state.DirectoryStateHandle
- getStateSize() - Method in class org.apache.flink.runtime.state.filemerging.DirectoryStreamStateHandle
-
This handle usually used to track the life cycle of the directory, therefore a fake size is provided.
- getStateSize() - Method in class org.apache.flink.runtime.state.filemerging.SegmentFileStateHandle
- getStateSize() - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
-
Returns the file size in bytes.
- getStateSize() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle.HandleAndLocalPath
- getStateSize() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
- getStateSize() - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
- getStateSize() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
- getStateSize() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
- getStateSize() - Method in class org.apache.flink.runtime.state.OperatorStreamStateHandle
- getStateSize() - Method in class org.apache.flink.runtime.state.PlaceholderStreamStateHandle
- getStateSize() - Method in class org.apache.flink.runtime.state.RetrievableStreamStateHandle
- getStateSize() - Method in class org.apache.flink.runtime.state.SharedStateRegistryImpl.EmptyDiscardStateObjectForRegister
- getStateSize() - Method in class org.apache.flink.runtime.state.SnapshotResult
- getStateSize() - Method in interface org.apache.flink.runtime.state.StateObject
-
Returns the size of the state in bytes.
- getStateSize(StateObject) - Static method in class org.apache.flink.runtime.state.StateUtil
-
Returns the size of a state object.
- getStateSizeStats() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummary
-
Returns the summary stats for the state size of completed checkpoints.
- getStateSizeStats() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummarySnapshot
- getStateSizeStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
- getStateSnapshotTransformFactory() - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
- getStateTable() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
This should only be used for testing.
- getStateTimestamp(ExecutionState) - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
Returns the timestamp for the given
ExecutionState. - getStateTimestamp(ExecutionState) - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
Returns the timestamp for the given
ExecutionState. - getStateTimestamp(ExecutionState) - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
- getStateTimestamp(ExecutionState) - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
- getStateTimestamp(ExecutionState) - Method in class org.apache.flink.runtime.executiongraph.Execution
- getStateTimestamp(ExecutionState) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getStateTimestamps() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
Returns the timestamps for every
ExecutionState. - getStateTimestamps() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
- getStateTimestamps() - Method in class org.apache.flink.runtime.executiongraph.Execution
- getStateType() - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
- getStateType() - Method in class org.apache.flink.runtime.state.v2.RegisteredKeyValueStateBackendMetaInfo
- getStateValueSerializer() - Method in class org.apache.flink.runtime.query.KvStateInfo
- getStateWindow(W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
-
Returns the state window for the given in-flight
Window. - getStatistic() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
- getStatistics() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogram
- getStats() - Method in class org.apache.flink.runtime.state.StateObject.StateObjectSizeStatsCollector
- getStatsFuture() - Method in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator.PendingStatsRequest
-
A Future, which will either complete successfully if all of the samples from individual tasks are collected or exceptionally, if at least one of the task responses fails.
- getStatus() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the status of this checkpoint.
- getStatus() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
- getStatus() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
- getStatus() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
- getStatus() - Method in class org.apache.flink.runtime.checkpoint.SubTaskInitializationMetrics
- getStatus() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
- getStatus() - Method in class org.apache.flink.runtime.rest.handler.async.OperationResult
- getStatus() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- getStatus() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
- getStatus() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- getStatus() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
- getStatus() - Method in class org.apache.flink.runtime.rest.messages.ProfilingInfo
- getStatus() - Method in class org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
- getStatusDuration() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- getStatusDuration(ExecutionState) - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- getStatusTimestamp(JobStatus) - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the timestamp for the given
JobStatus. - getStatusTimestamp(JobStatus) - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
- getStatusTimestamp(JobStatus) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getStatusTimestamp(JobStatus) - Method in interface org.apache.flink.runtime.executiongraph.JobStatusProvider
-
Returns the timestamp for the given
JobStatus. - getStatusTimestamp(JobStatus) - Method in class org.apache.flink.runtime.scheduler.JobStatusStore
- getStdDev() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
- getStopMode() - Method in class org.apache.flink.runtime.io.network.api.EndOfData
- getStorageDir() - Method in class org.apache.flink.runtime.blob.AbstractBlobCache
- getStorageDir() - Method in class org.apache.flink.runtime.blob.BlobServer
- getStorageIdentifier() - Method in interface org.apache.flink.runtime.state.changelog.ChangelogStateHandle
-
Get the storage identifier related to a specific
StateChangelogStorage. - getStorageIdentifier() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateHandleStreamImpl
- getStorageIdentifier() - Method in class org.apache.flink.runtime.state.changelog.inmemory.InMemoryChangelogStateHandle
- getStorageLocation(JobID, BlobKey) - Method in class org.apache.flink.runtime.blob.BlobServer
-
Returns a file handle to the file associated with the given blob key on the blob server.
- getStorageLocation(JobID, BlobKey) - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
-
Returns a file handle to the file associated with the given blob key on the blob server.
- getStorageLocation(JobID, BlobKey) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
-
Returns a file handle to the file associated with the given blob key on the blob server.
- getStoredJobsOverview() - Method in interface org.apache.flink.runtime.dispatcher.ExecutionGraphInfoStore
-
Return the
JobsOverviewfor all stored/past jobs. - getStoredJobsOverview() - Method in class org.apache.flink.runtime.dispatcher.FileExecutionGraphInfoStore
- getStoredJobsOverview() - Method in class org.apache.flink.runtime.dispatcher.MemoryExecutionGraphInfoStore
- getStream() - Method in class org.apache.flink.runtime.state.StatePartitionStreamProvider
-
Returns a stream with the data of one state partition.
- getStreamCompressionDecorator() - Method in interface org.apache.flink.runtime.state.FullSnapshotResources
-
Returns the
StreamCompressionDecoratorthat should be used for writing. - getStreamConfig() - Method in class org.apache.flink.streaming.api.operators.StreamOperatorParameters
- getStreamEdges(int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getStreamEdges(int, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getStreamEdgesOrThrow(int, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Deprecated.
- getStreamGraph() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Getter of the
StreamGraphof the streaming job. - getStreamGraph() - Method in interface org.apache.flink.streaming.api.graph.TransformationTranslator.Context
-
Returns the
StreamGraphbeing created as the transformations of a pipeline are translated to their runtime implementations. - getStreamGraph(boolean) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Getter of the
StreamGraphof the streaming job with the option to clear previously registeredtransformations. - getStreamingPlanAsJSON() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getStreamNode(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getStreamNodeIds(Transformation<?>) - Method in interface org.apache.flink.streaming.api.graph.TransformationTranslator.Context
-
Returns the ids of the nodes in the
StreamGraphcorresponding to the provided transformation. - getStreamNodes() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getStreamOperator() - Method in class org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper
- getStreamOperator(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
- getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
- getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.streaming.api.operators.SourceOperatorFactory
- getStreamOperatorClass(ClassLoader) - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
-
Returns the runtime class of the stream operator.
- getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.streaming.runtime.operators.sink.CommitterOperatorFactory
- getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.streaming.runtime.operators.sink.SinkWriterOperatorFactory
- getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperatorFactory
- getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorFactory
- getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorFactory
- getStreamOperatorFactory(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getStreamOperatorFactoryClass(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getStreamOutputs() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- getStreamRecord() - Method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
-
Creates a
StreamRecordfrom this TimestampedValue. - getStreamStateHandleID() - Method in class org.apache.flink.runtime.state.filemerging.DirectoryStreamStateHandle
- getStreamStateHandleID() - Method in class org.apache.flink.runtime.state.filemerging.SegmentFileStateHandle
- getStreamStateHandleID() - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
- getStreamStateHandleID() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
- getStreamStateHandleID() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
- getStreamStateHandleID() - Method in class org.apache.flink.runtime.state.OperatorStreamStateHandle
- getStreamStateHandleID() - Method in class org.apache.flink.runtime.state.PlaceholderStreamStateHandle
- getStreamStateHandleID() - Method in class org.apache.flink.runtime.state.RetrievableStreamStateHandle
- getStreamStateHandleID() - Method in class org.apache.flink.runtime.state.SharedStateRegistryImpl.EmptyDiscardStateObjectForRegister
- getStreamStateHandleID() - Method in interface org.apache.flink.runtime.state.StreamStateHandle
- getStrictObjectMapper() - Static method in class org.apache.flink.runtime.rest.util.RestMapperUtils
-
Returns a preconfigured strict
ObjectMapper. - getStringifiedThreadInfo() - Method in class org.apache.flink.runtime.rest.messages.ThreadDumpInfo.ThreadInfo
- getStringWithMetadata() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceID
- getStub() - Method in class org.apache.flink.runtime.operators.BatchTask
- getStub() - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
- getStub() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
- getStub() - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
- getStub() - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
- getStub() - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
- getStub() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
- getStub() - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
- getStub() - Method in interface org.apache.flink.runtime.operators.TaskContext
- getStubParameter(String, String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getStubParameters() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getStubType() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
- getStubType() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
- getStubType() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
- getStubType() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
- getStubType() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
- getStubType() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
- getStubType() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
- getStubType() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
- getStubType() - Method in class org.apache.flink.runtime.operators.CrossDriver
- getStubType() - Method in interface org.apache.flink.runtime.operators.Driver
-
Gets the class of the stub type that is run by this task.
- getStubType() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
- getStubType() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
- getStubType() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
- getStubType() - Method in class org.apache.flink.runtime.operators.JoinDriver
- getStubType() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
- getStubType() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
- getStubType() - Method in class org.apache.flink.runtime.operators.MapDriver
- getStubType() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
- getStubType() - Method in class org.apache.flink.runtime.operators.NoOpDriver
- getStubType() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
- getStubType() - Method in class org.apache.flink.runtime.operators.ReduceDriver
- getStubType() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
- getStubWrapper(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getSubmissionResourceStabilizationTimeout() - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler.Settings
- getSubmissionResourceWaitTimeout() - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler.Settings
- getSubpartitionBytes() - Method in class org.apache.flink.runtime.executiongraph.ResultPartitionBytes
- getSubpartitionId() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageSubpartitionId
- getSubpartitionId() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.PartitionFileWriter.SubpartitionBufferContext
- getSubpartitionId() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyPayload
- getSubpartitionIds() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageConsumerSpec
- getSubPartitionIdx() - Method in class org.apache.flink.runtime.checkpoint.channel.ResultSubpartitionInfo
- getSubpartitionIndex() - Method in class org.apache.flink.runtime.io.network.partition.BufferWithSubpartition
- getSubpartitionIndex() - Method in class org.apache.flink.streaming.api.watermark.InternalWatermark
- getSubPartitionIndex() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
- getSubpartitionIndexRange() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertexInputInfo
-
Get the subpartition range this subtask should consume.
- getSubpartitionInfo() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
- getSubpartitionNums() - Method in class org.apache.flink.runtime.shuffle.TaskInputsOutputsDescriptor
- getSubpartitionPath(String, TieredStoragePartitionId, int) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.SegmentPartitionFile
- getSubpartitionStatus(int) - Method in class org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve
- getSubsetForKeyGroup(int) - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueSet
- getSubsetForKeyGroup(int) - Method in class org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
- getSubsetForKeyGroup(int) - Method in interface org.apache.flink.runtime.state.KeyGroupedInternalPriorityQueue
-
Returns the subset of elements in the priority queue that belongs to the given key-group, within the operator's key-group range.
- getSubtask() - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator.SubtaskGateway
-
Gets the subtask index of the parallel operator instance this gateway communicates with.
- getSubtask() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
- getSubtask() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
- getSubtaskAttemptMetricStore(String, String, int, int) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
- getSubtaskCheckpointStatistics() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails
- getSubtaskId() - Method in class org.apache.flink.runtime.jobgraph.OperatorInstanceID
- getSubtaskId() - Method in interface org.apache.flink.streaming.api.connector.sink2.CommittableMessage
-
The subtask that created this committable.
- getSubtaskId() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableSummary
- getSubtaskId() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableWithLineage
- getSubtaskIndex() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
- getSubtaskIndex() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Returns the task's index in the subtask group.
- getSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.ExecutionAttemptID
- getSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertexInputInfo
-
Get the index of this subtask.
- getSubtaskIndex() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- getSubtaskIndex() - Method in class org.apache.flink.runtime.scheduler.strategy.ExecutionVertexID
- getSubtaskIndex() - Method in class org.apache.flink.runtime.state.AbstractChannelStateHandle
- getSubtaskIndex() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
- getSubtaskJobManagerRestoredState(OperatorID) - Method in interface org.apache.flink.runtime.state.TaskStateManager
-
Get the restored state from jobManager which belongs to an operator running in the owning task.
- getSubtaskJobManagerRestoredState(OperatorID) - Method in class org.apache.flink.runtime.state.TaskStateManagerImpl
- getSubtaskKey() - Method in class org.apache.flink.runtime.checkpoint.filemerging.LogicalFile
- getSubtaskMetricStore(int) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.TaskMetricStore
- getSubtaskMetricStore(String, String, int) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
Returns the
MetricStore.ComponentMetricStorefor the given job/task ID and subtask index. - getSubtasks() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
- getSubtasks() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
- getSubtasks() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
- getSubtaskState() - Method in class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
- getSubtaskStateByOperatorID(OperatorID) - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
-
Returns the subtask state for the given operator id (or null if not contained).
- getSubtaskStateMappings() - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
-
Returns the set of all mappings from operator id to the corresponding subtask state.
- getSubtaskStates() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- getSubtaskStates() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
-
Returns the stats for all subtasks.
- getSuccessfulCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
- getSum() - Method in class org.apache.flink.runtime.checkpoint.StatsSummary
-
Returns the sum of all seen values.
- getSum() - Method in class org.apache.flink.runtime.checkpoint.StatsSummarySnapshot
-
Returns the sum of all seen values.
- getSum() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
- getSummary() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
- getSummary() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails
- getSummary(int, int) - Method in interface org.apache.flink.streaming.runtime.operators.sink.committables.CheckpointCommittableManager
-
Returns a summary of the current commit progress for the emitting subtask identified by the parameters.
- getSummaryStats() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
-
Returns the snapshotted completed checkpoint summary stats.
- getSummaryStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
- getSuperstep() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
- getSupportedAPIVersions() - Method in class org.apache.flink.runtime.rest.handler.legacy.files.WebContentHandlerSpecification
- getSupportedAPIVersions() - Method in interface org.apache.flink.runtime.rest.handler.RestHandlerSpecification
-
Returns the supported API versions that this request supports.
- getSupportedAPIVersions() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerProfilingHeaders
- getSupportedAPIVersions() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerProfilingListHeaders
- getSupportedAPIVersions() - Method in class org.apache.flink.runtime.rest.messages.CustomHeadersDecorator
- getSupportedAPIVersions() - Method in interface org.apache.flink.runtime.rest.messages.RuntimeMessageHeaders
- getSupportedAPIVersions() - Method in interface org.apache.flink.runtime.rest.messages.RuntimeUntypedResponseMessageHeaders
- getSupportedAPIVersions() - Method in class org.apache.flink.runtime.rest.messages.YarnCancelJobTerminationHeaders
-
Deprecated.
- getSupportedAPIVersions() - Method in class org.apache.flink.runtime.rest.messages.YarnStopJobTerminationHeaders
-
Deprecated.
- getSyncCheckpointDuration() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
- getSyncCheckpointDurationStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
- getSyncDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
- getSyncDurationMillis() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
- getSyncDurationMillis() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetricsBuilder
- getSynchronousDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
- getSystemPageSize() - Static method in class org.apache.flink.runtime.io.network.partition.PageSizeUtil
-
Tries to get the system page size.
- getSystemPageSizeOrConservativeMultiple() - Static method in class org.apache.flink.runtime.io.network.partition.PageSizeUtil
-
Tries to get the system page size.
- getSystemPageSizeOrDefault() - Static method in class org.apache.flink.runtime.io.network.partition.PageSizeUtil
-
Tries to get the system page size.
- getSystemResourceMetricsProbingInterval() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
- getTailOperator() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- getTarget() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Returns the vertex connected to this edge.
- getTarget() - Method in class org.apache.flink.runtime.scheduler.adaptive.JobSchedulingPlan.SlotAssignment
- getTargetAddress() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
- getTargetAddress() - Method in class org.apache.flink.runtime.slots.ResourceRequirements
- getTargetAs(Class<T>) - Method in class org.apache.flink.runtime.scheduler.adaptive.JobSchedulingPlan.SlotAssignment
- getTargetDirectory() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerRequestBody
- getTargetDirectory() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointRequestBody
- getTargetGateway() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
Gets the RegisteredGateway.
- getTargetId() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
- getTargetLeaderId() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
- getTargetLocation() - Method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
-
Returns the target location for the checkpoint.
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.handler.legacy.files.WebContentHandlerSpecification
- getTargetRestEndpointURL() - Method in interface org.apache.flink.runtime.rest.handler.RestHandlerSpecification
-
Returns the generalized endpoint url that this request should be sent to, for example
/job/:jobid. - getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatusHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointTriggerHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerCustomLogHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerLogFileHeader
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerLogListHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerProfilingFileHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerProfilingHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerProfilingListHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerStdoutFileHeader
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerThreadDumpHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.CustomHeadersDecorator
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteStatusHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteTriggerHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetListHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.coordination.ClientCoordinationHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.JobManagerJobConfigurationHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.JobManagerJobEnvironmentHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.JobResourceRequirementsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.JobResourcesRequirementsUpdateHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.JobStatusInfoHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedJobMetricsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedSubtaskMetricsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedTaskManagerMetricsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerOperatorMetricsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexMetricsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexWatermarksHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointTriggerHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobCancellationHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobClientHeartbeatHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobManagerEnvironmentHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobManagerLogUrlHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobVertexFlameGraphHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerCustomLogHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingFileHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingListHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerStdoutFileHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerThreadDumpHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.TaskManagerLogUrlHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.YarnCancelJobTerminationHeaders
-
Deprecated.
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.YarnStopJobTerminationHeaders
-
Deprecated.
- getTargetTotalTime() - Method in class org.apache.flink.runtime.throughput.BufferDebloatConfiguration
- getTargetVertex(StreamEdge) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getTask(ExecutionAttemptID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Get the task for the given execution attempt id.
- getTask(ExecutionAttemptID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- getTaskConfig() - Method in class org.apache.flink.runtime.operators.BatchTask
- getTaskConfig() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
- getTaskConfig() - Method in interface org.apache.flink.runtime.operators.TaskContext
- getTaskConfiguration() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the task-wide configuration object, originally attached to the job vertex.
- getTaskConfiguration() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
- getTaskConfiguration() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the task configuration object which was attached to the original
JobVertex. - getTaskConfiguration() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getTaskConfiguration() - Method in class org.apache.flink.runtime.taskmanager.Task
- getTaskDeploymentDescriptorFactory() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getTaskDeploymentDescriptorFactory() - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
- getTaskEventDispatcher() - Method in interface org.apache.flink.runtime.execution.Environment
- getTaskEventDispatcher() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
- getTaskEventDispatcher() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getTaskExecutionId() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
- getTaskExecutorAddress() - Method in class org.apache.flink.runtime.resourcemanager.TaskExecutorRegistration
- getTaskExecutorConnection() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerRegistration
- getTaskExecutorConnection() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerInfo
-
Get the taskExecutorConnection.
- getTaskExecutorGateway() - Method in class org.apache.flink.runtime.resourcemanager.registration.TaskExecutorConnection
- getTaskExecutorProcessSpec() - Method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
- getTaskExecutorResourceId() - Method in class org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
- getTaskExecutorResourceSpec() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
- getTaskExecutorUtilization(SlotInfo) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultFreeSlotTracker
- getTaskExecutorUtilization(SlotInfo) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.FreeSlotTracker
-
Get task executor utilization of this slot.
- getTaskFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
- getTaskHeap() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
-
Returns the configured heap size used by the tasks.
- getTaskHeap() - Method in class org.apache.flink.runtime.util.config.memory.taskmanager.TaskExecutorFlinkMemory
- getTaskHeapMB() - Method in class org.apache.flink.runtime.rest.messages.ResourceProfileInfo
- getTaskHeapMemory() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the task heap memory needed.
- getTaskHeapSize() - Method in class org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
- getTaskHeapSize() - Method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec
- getTaskHeapSize() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorResourceSpec
- getTaskInfo() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the
TaskInfoobject associated with this subtask. - getTaskInfo() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
- getTaskInfo() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getTaskInfo() - Method in class org.apache.flink.runtime.taskmanager.Task
- getTaskInformation() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Return the sub task's task information.
- getTaskInformation() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- getTaskInformationCache() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
- getTaskInformationOrBlobKey() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- getTaskInitializationDuration() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
Returns the duration of time required for a task's restoring/initialization, which reaches its maximum when the task begins running and remains constant throughout the task's running.
- getTaskIOMetricGroup() - Method in class org.apache.flink.runtime.metrics.groups.InternalOperatorMetricGroup
- getTaskKvStateRegistry() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the registry for
InternalKvStateinstances. - getTaskKvStateRegistry() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getTaskLocalSnapshot() - Method in class org.apache.flink.runtime.state.SnapshotResult
- getTaskLocalState() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFinalizer
- getTaskManagerActions() - Method in interface org.apache.flink.runtime.execution.Environment
- getTaskManagerActions() - Method in interface org.apache.flink.runtime.taskexecutor.JobTable.Connection
- getTaskManagerActions() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getTaskManagerBindAddress() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
- getTaskManagerBindAddress() - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
-
Gets the bind address of the Taskmanager.
- getTaskManagerChangelogManager() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
- getTaskManagerChannelStateManager() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
- getTaskManagerConnection() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerSlot
- getTaskManagerConnection() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerSlotInformation
- getTaskManagerExternalAddress() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
- getTaskManagerExternalAddress() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
- getTaskManagerExternalAddress() - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
-
Gets the external address of the TaskManager.
- getTaskManagerExternalPortRange() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
- getTaskManagerFileMergingManager() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
- getTaskManagerFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
- getTaskManagerGateway() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Return the TaskManager gateway to talk to the TaskManager.
- getTaskManagerGateway() - Method in interface org.apache.flink.runtime.jobmaster.SlotContext
-
Gets the actor gateway that can be used to send messages to the TaskManager.
- getTaskManagerGateway() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
- getTaskmanagerId() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- getTaskManagerId() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.ExceptionInfo
- getTaskManagerIdleSince(InstanceID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedSlotManager
- getTaskManagerInfo() - Method in interface org.apache.flink.runtime.execution.Environment
-
Gets the task manager info, with configuration and hostname.
- getTaskManagerInfo() - Method in class org.apache.flink.runtime.operators.BatchTask
- getTaskManagerInfo() - Method in interface org.apache.flink.runtime.operators.TaskContext
- getTaskManagerInfo() - Method in class org.apache.flink.runtime.resourcemanager.TaskManagerInfoWithSlots
- getTaskManagerInfo() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getTaskManagerInfos() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersInfo
- getTaskManagerJobFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
- getTaskManagerLoadBalanceMode() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
- getTaskManagerLocation() - Method in class org.apache.flink.runtime.jobmaster.event.ExecutionVertexFinishedEvent
- getTaskManagerLocation() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Return the TaskManager location of this slot.
- getTaskManagerLocation() - Method in interface org.apache.flink.runtime.jobmaster.SlotInfo
-
Gets the location info of the TaskManager that offers this slot.
- getTaskManagerLocation() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
- getTaskManagerLocation() - Method in class org.apache.flink.runtime.scheduler.exceptionhistory.ExceptionHistoryEntry
- getTaskManagerLocation(ExecutionVertexID) - Method in class org.apache.flink.runtime.scheduler.ExecutionGraphToInputsLocationsRetrieverAdapter
- getTaskManagerLocation(ExecutionVertexID) - Method in interface org.apache.flink.runtime.scheduler.InputsLocationsRetriever
-
Get the task manager location future for an execution vertex.
- getTaskManagerLocationFuture() - Method in class org.apache.flink.runtime.executiongraph.Execution
- getTaskManagerLogDir() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
- getTaskManagerLogPath() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
- getTaskManagerMetricsInfo() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsInfo
- getTaskManagerMetricStore(String) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
Returns the
MetricStore.TaskManagerMetricStorefor the given taskmanager ID. - getTaskManagerRequestTimeout() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
- getTaskManagerRpcAddress() - Method in class org.apache.flink.runtime.jobmaster.TaskManagerRegistrationInformation
- getTaskManagerRuntimeInfo() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Returns the task manager runtime info of the task manager running this stream task.
- getTaskManagers() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
- getTaskManagerSession() - Method in class org.apache.flink.runtime.jobmaster.TaskManagerRegistrationInformation
- getTaskManagerStateStore() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
- getTaskManagerStdoutPath() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
- getTaskManagersToRelease() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceReconcileResult
- getTaskManagersWithAllocatedSlotsForJob(JobID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- getTaskManagerTimeout() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
- getTaskMemoryManager(AllocationID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Get the memory manager of the slot allocated for the task.
- getTaskMemoryManager(AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- getTaskMetricGroup() - Method in class org.apache.flink.runtime.metrics.groups.InternalOperatorMetricGroup
- getTaskMetricStore(String, String) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
Returns the
MetricStore.ComponentMetricStorefor the given job/task ID. - getTaskName() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getTaskName() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
- getTaskName() - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
- getTaskName() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
- getTaskName() - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
- getTaskName() - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
- getTaskName() - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
- getTaskName() - Method in exception org.apache.flink.runtime.operators.chaining.ExceptionInChainedStubException
- getTaskName() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
- getTaskName() - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
- getTaskName() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getTaskName() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.ExceptionInfo
- getTaskNameWithSubtaskIndex() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
Returns the name of this execution vertex in the format "myTask (2/7)".
- getTaskNameWithSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
- getTaskNameWithSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
Creates a simple name representation in the style 'taskname (x/y)', where 'taskname' is the name as returned by
ExecutionVertex.getTaskName(), 'x' is the parallel subtask index as returned byExecutionVertex.getParallelSubtaskIndex()+ 1, and 'y' is the total number of tasks, as returned byExecutionVertex.getTotalNumberOfParallelSubtasks(). - getTaskOffHeap() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
-
Returns the configured off-heap size used by the tasks.
- getTaskOffHeap() - Method in class org.apache.flink.runtime.util.config.memory.taskmanager.TaskExecutorFlinkMemory
- getTaskOffHeapMB() - Method in class org.apache.flink.runtime.rest.messages.ResourceProfileInfo
- getTaskOffHeapMemory() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the task off-heap memory needed.
- getTaskOffHeapSize() - Method in class org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
- getTaskOffHeapSize() - Method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec
- getTaskOffHeapSize() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorResourceSpec
- getTaskOwnedDirHandle() - Method in class org.apache.flink.runtime.state.filemerging.FileMergingOperatorStreamStateHandle
- getTaskOwnedStateDirectory() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
- getTaskResourceProfile() - Method in class org.apache.flink.runtime.clusterframework.types.SlotProfile
-
Returns the desired resource profile for the task slot.
- getTaskRestore() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
- getTaskRestore() - Method in class org.apache.flink.runtime.executiongraph.Execution
- getTasks() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
Get all tasks running in this task slot.
- getTasks(JobID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Return an iterator over all tasks for a given job.
- getTasks(JobID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- getTaskSlotTable() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
- getTasksNeedingRestart(ExecutionVertexID, boolean) - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.BatchJobRecoveryContext
-
Retrieves a set of vertices that need to be restarted.
- getTasksNeedingRestart(ExecutionVertexID, Throwable) - Method in interface org.apache.flink.runtime.executiongraph.failover.FailoverStrategy
-
Returns a set of IDs corresponding to the set of vertices that should be restarted.
- getTasksNeedingRestart(ExecutionVertexID, Throwable) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartAllFailoverStrategy
-
Returns all vertices on any task failure.
- getTasksNeedingRestart(ExecutionVertexID, Throwable) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionFailoverStrategy
-
Returns a set of IDs corresponding to the set of vertices that should be restarted.
- getTasksPerState() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
- getTasksPerState() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- getTaskStateManager() - Method in interface org.apache.flink.runtime.execution.Environment
- getTaskStateManager() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getTaskStateSnapshot() - Method in class org.apache.flink.runtime.checkpoint.JobManagerTaskRestore
- getTaskStateStats(JobVertexID) - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the task state stats for the given job vertex ID or
nullif no task with such an ID is available. - getTasksToCommitTo() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointPlan
-
Returns tasks that are still running when taking the checkpoint, these need to be sent a message when the checkpoint is confirmed.
- getTasksToCommitTo() - Method in class org.apache.flink.runtime.checkpoint.DefaultCheckpointPlan
- getTasksToTrigger() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointPlan
-
Returns the tasks who need to be sent a message when a checkpoint is started.
- getTasksToTrigger() - Method in class org.apache.flink.runtime.checkpoint.DefaultCheckpointPlan
- getTasksToWaitFor() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointPlan
-
Returns tasks who need to acknowledge a checkpoint before it succeeds.
- getTasksToWaitFor() - Method in class org.apache.flink.runtime.checkpoint.DefaultCheckpointPlan
- getTaskVertices() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
Returns all execution vertices for this job vertex.
- getTaskVertices() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
- getTaskVertices() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- getTcpKeepCount() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
- getTcpKeepIdleInSeconds() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
- getTcpKeepInternalInSeconds() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
- getTempDirs() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- getTemporaryFileDirectory() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Gets the directory for temporary files, as returned by the JVM system property "java.io.tmpdir".
- getTerminalStateFuture() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Gets a future that completes once the task execution reaches a terminal state.
- getTerminalStateFuture() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot.Payload
-
Gets the terminal state future which is completed once the payload has reached a terminal state.
- getTerminationFuture() - Method in interface org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess.DispatcherGatewayService
- getTerminationFuture() - Method in class org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherGatewayService
- getTerminationFuture() - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
- getTerminationFuture() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getTerminationFuture() - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Returns the termination future of this
ExecutionGraph. - getTerminationFuture() - Method in interface org.apache.flink.runtime.jobmaster.JobMasterService
-
Get the termination future of this job master service.
- getTerminationFuture() - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerService
-
Return termination future of the service.
- getTerminationFuture() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerServiceImpl
- getTerminationFuture() - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotPayload
- getTerminationFuture() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorToServiceAdapter
- getTerminationFuture() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
- getTerminationFuture() - Method in interface org.apache.flink.runtime.taskexecutor.TaskManagerRunner.TaskExecutorService
- getTerminationFuture() - Method in class org.apache.flink.runtime.taskmanager.Task
- getTgtRenewalPeriod() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
- getThreadInfos() - Method in class org.apache.flink.runtime.rest.messages.ThreadDumpInfo
- getThreadName() - Method in class org.apache.flink.runtime.rest.messages.ThreadDumpInfo.ThreadInfo
- getThreadState() - Method in class org.apache.flink.runtime.messages.ThreadInfoSample
- getThrowable() - Method in class org.apache.flink.runtime.rest.handler.async.OperationResult
- getThrowableType(Throwable) - Static method in class org.apache.flink.runtime.throwable.ThrowableClassifier
-
Classify the exceptions by extracting the
ThrowableTypefrom a potentialThrowableAnnotation. - getTieredStorageConfiguration() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartitionFactory
- getTieredStorageConfiguration() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- getTieredStorageNettyService() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartitionFactory
- getTieredStoragePath(String) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.SegmentPartitionFile
- getTieredStorageResourceRegistry() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartitionFactory
- getTierFactories() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageConfiguration
- getTierShuffleDescriptors() - Method in class org.apache.flink.runtime.shuffle.NettyShuffleDescriptor
- getTimeout() - Method in class org.apache.flink.runtime.rest.handler.LeaderRetrievalHandler
- getTimeout() - Method in class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
- getTimerDelay(Clock, CheckpointBarrier) - Static method in class org.apache.flink.streaming.runtime.io.checkpointing.BarrierAlignmentUtil
- getTimerServiceProvider() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getTimerServiceProvider(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getTimeServiceManager() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- getTimeServiceManager() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- getTimestamp() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetaData
- getTimestamp() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
- getTimestamp() - Method in class org.apache.flink.runtime.executiongraph.ErrorInfo
-
Returns the timestamp for the contained exception.
- getTimestamp() - Method in class org.apache.flink.runtime.executiongraph.failover.FailureHandlingResult
-
Returns the time of the failure.
- getTimestamp() - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
- getTimestamp() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.ExceptionInfo
- getTimestamp() - Method in class org.apache.flink.runtime.scheduler.exceptionhistory.FailureHandlingResultSnapshot
-
The time the failure occurred.
- getTimestamp() - Method in class org.apache.flink.streaming.api.functions.co.ProcessJoinFunction.Context
- getTimestamp() - Method in interface org.apache.flink.streaming.api.operators.InternalTimer
-
Returns the timestamp of the timer.
- getTimestamp() - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
- getTimestamp() - Method in class org.apache.flink.streaming.api.watermark.Watermark
-
Returns the timestamp associated with this
Watermarkin milliseconds. - getTimestamp() - Method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
- getTimestamp() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Returns the timestamp associated with this stream value in milliseconds.
- getTimestamps() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getTimestamps() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
- getTimeZoneName() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
- getTimeZoneOffset() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
- getTmpDirectories() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
- getTmpDirectories() - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
-
Gets the list of temporary file directories.
- getTmpDirectory() - Method in class org.apache.flink.runtime.entrypoint.WorkingDirectory
- getTmpDirectory() - Method in class org.apache.flink.runtime.jobmaster.JobMasterConfiguration
- getTmpDirPaths() - Method in class org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
- getTmpDirPaths() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
- getTmpWorkingDirectory() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
- getTmpWorkingDirectory() - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
-
Gets the temporary working directory of the TaskManager instance.
- getTo() - Method in class org.apache.flink.runtime.state.changelog.inmemory.InMemoryChangelogStateHandle
- getTokens() - Method in class org.apache.flink.runtime.security.token.DelegationTokenContainer
- getTolerableCheckpointFailureNumber() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
- getTolerableCheckpointFailureNumber() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Get the defined number of consecutive checkpoint failures that will be tolerated, before the whole job is failed over.
- getTotalBudget() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceBudgetManager
- getTotalBytesPersisted() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
- getTotalFields() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
- getTotalFields() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
- getTotalFlinkMemory() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
-
Returns the amount of memory configured to be used by Flink excluding things like JVM Metaspace and other JVM overhead.
- getTotalFlinkMemorySize() - Method in class org.apache.flink.runtime.util.config.memory.CommonProcessMemorySpec
- getTotalFlinkMemorySize() - Method in interface org.apache.flink.runtime.util.config.memory.FlinkMemory
- getTotalFlinkMemorySize() - Method in class org.apache.flink.runtime.util.config.memory.jobmanager.JobManagerFlinkMemory
- getTotalFlinkMemorySize() - Method in interface org.apache.flink.runtime.util.config.memory.ProcessMemorySpec
- getTotalFlinkMemorySize() - Method in class org.apache.flink.runtime.util.config.memory.taskmanager.TaskExecutorFlinkMemory
- getTotalMemory() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the total memory needed.
- getTotalMemory() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
- getTotalMemSize() - Method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec
- getTotalNumberCheckpoints() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
- getTotalNumberOfBuffersUnsafe() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartition
- getTotalNumberOfBuffersUnsafe() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
Gets the total numbers of buffers (data buffers plus events).
- getTotalNumberOfBytesUnsafe() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartition
- getTotalNumberOfBytesUnsafe() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
- getTotalNumberOfCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
-
Returns the total number of checkpoints (in progress, completed, failed).
- getTotalNumberOfMemorySegments() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
- getTotalNumberOfParallelSubtasks() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- getTotalNumberOfPartitions() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
- getTotalNumberOfPartitions() - Method in class org.apache.flink.runtime.shuffle.PartitionDescriptor
- getTotalProcessMemory() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
-
Returns the total amount of memory configured to be used by the JVM including all the different memory pools.
- getTotalProcessMemorySize() - Method in class org.apache.flink.runtime.util.config.memory.CommonProcessMemorySpec
- getTotalProcessMemorySize() - Method in interface org.apache.flink.runtime.util.config.memory.ProcessMemorySpec
- getTotalResource() - Method in class org.apache.flink.runtime.resourcemanager.ResourceOverview
- getTotalResource() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerRegistration
- getTotalResource() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerInfo
-
Get the total resource.
- getTotalResource() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- getTotalResource() - Method in class org.apache.flink.runtime.util.ResourceCounter
-
Computes the total resources in this counter.
- getTotalResourceCount() - Method in class org.apache.flink.runtime.util.ResourceCounter
-
Computes the total number of resources in this counter.
- getTotalResourceProfile() - Method in class org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
- getTotalResourceProfile() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingTaskManager
- getTotalResourceProfile() - Method in class org.apache.flink.runtime.resourcemanager.TaskExecutorRegistration
- getTotalResourceProfile() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
- getTotalTime() - Method in class org.apache.flink.runtime.scheduler.metrics.DeploymentStateTimeMetrics
- getTotalTime() - Method in interface org.apache.flink.runtime.scheduler.metrics.StateTimeMetric
-
Returns the total time, in milliseconds, that we have spent in the targeted state.
- getTotalTimeMetricName(String) - Static method in interface org.apache.flink.runtime.scheduler.metrics.StateTimeMetric
- getTrackedPartitions(K) - Method in class org.apache.flink.runtime.taskexecutor.partition.PartitionTable
- getTrackedPartitionsFor(JobID) - Method in interface org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTracker
-
Get all partitions tracked for the given job.
- getTrackedPartitionsFor(JobID) - Method in class org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTrackerImpl
- getTransformation() - Method in class org.apache.flink.streaming.api.datastream.BroadcastStream
- getTransformation() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Returns the
Transformationthat represents the operation that logically creates thisDataStream. - getTransformation() - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Returns the transformation that contains the actual sink operator of this sink.
- getTransformations() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
- getTransformationToCache() - Method in class org.apache.flink.streaming.api.transformations.CacheTransformation
- getTransformationUID() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getTransientBlobService() - Method in class org.apache.flink.runtime.blob.BlobCacheService
- getTransientBlobService() - Method in class org.apache.flink.runtime.blob.BlobServer
- getTransientBlobService() - Method in interface org.apache.flink.runtime.blob.BlobService
-
Returns a BLOB service for accessing transient BLOBs.
- getTransitiveChainedTaskConfigs(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getTransitiveChainedTaskConfigsWithSelf(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getTransitivePredecessorsInternal() - Method in class org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
- getTransitivePredecessorsInternal() - Method in class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
- getTransitivePredecessorsInternal() - Method in class org.apache.flink.streaming.api.transformations.CacheTransformation
- getTransitivePredecessorsInternal() - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
- getTransitivePredecessorsInternal() - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
- getTransitivePredecessorsInternal() - Method in class org.apache.flink.streaming.api.transformations.LegacySinkTransformation
- getTransitivePredecessorsInternal() - Method in class org.apache.flink.streaming.api.transformations.LegacySourceTransformation
- getTransitivePredecessorsInternal() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
- getTransitivePredecessorsInternal() - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
- getTransitivePredecessorsInternal() - Method in class org.apache.flink.streaming.api.transformations.ReduceTransformation
- getTransitivePredecessorsInternal() - Method in class org.apache.flink.streaming.api.transformations.SideOutputTransformation
- getTransitivePredecessorsInternal() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
- getTransitivePredecessorsInternal() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
- getTransitivePredecessorsInternal() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformationWrapper
- getTransitivePredecessorsInternal() - Method in class org.apache.flink.streaming.api.transformations.TimestampsAndWatermarksTransformation
- getTransitivePredecessorsInternal() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
- getTransitivePredecessorsInternal() - Method in class org.apache.flink.streaming.api.transformations.UnionTransformation
- getTrigger() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
- getTrigger() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorFactory
- getTriggeredCheckpointStatus(AsynchronousJobOperationKey) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- getTriggeredCheckpointStatus(AsynchronousJobOperationKey) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Get the status of a checkpoint triggered under the specified operation key.
- getTriggeredSavepointStatus(AsynchronousJobOperationKey) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- getTriggeredSavepointStatus(AsynchronousJobOperationKey) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Get the status of a savepoint triggered under the specified operation key.
- getTriggerId() - Method in class org.apache.flink.runtime.rest.handler.async.OperationKey
-
Get the trigger id for the given operation key.
- getTriggerId() - Method in class org.apache.flink.runtime.rest.handler.async.TriggerResponse
- getTriggerId() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointTriggerRequestBody
- getTriggerId() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerRequestBody
- getTriggerId() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointRequestBody
- getTriggerTime() - Method in class org.apache.flink.runtime.rest.messages.ProfilingInfo
- getTriggerTimestamp() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the timestamp when the checkpoint was triggered.
- getTriggerTimestamp() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- getTtlConfig() - Method in class org.apache.flink.runtime.state.v2.StateDescriptor
- getTtlTimeProvider() - Method in class org.apache.flink.runtime.state.KeyedStateBackendParametersImpl
- getTtlTimeProvider() - Method in interface org.apache.flink.runtime.state.StateBackend.KeyedStateBackendParameters
- getTwo() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
- getType() - Method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
- getType() - Method in exception org.apache.flink.runtime.broadcast.InitializationTypeConflictException
- getType() - Method in interface org.apache.flink.runtime.jobmaster.event.JobEvent
-
Retrieves the type id of this job event.
- getType() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
- getType() - Method in class org.apache.flink.runtime.state.v2.AggregatingStateDescriptor
- getType() - Method in class org.apache.flink.runtime.state.v2.ListStateDescriptor
- getType() - Method in class org.apache.flink.runtime.state.v2.MapStateDescriptor
- getType() - Method in class org.apache.flink.runtime.state.v2.ReducingStateDescriptor
- getType() - Method in class org.apache.flink.runtime.state.v2.StateDescriptor
-
Return the specific
Typeof described state. - getType() - Method in class org.apache.flink.runtime.state.v2.ValueStateDescriptor
- getType() - Method in class org.apache.flink.streaming.api.datastream.BroadcastStream
- getType() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Gets the type of the stream.
- getType1() - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
Gets the type of the first input.
- getType1() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Gets the type of the first input.
- getType2() - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
Gets the type of the second input.
- getType2() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Gets the type of the second input.
- getTypeClass() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
- getTypeClass() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
- getTypeID(Class<? extends JobEvent>) - Static method in class org.apache.flink.runtime.jobmaster.event.JobEvents
- getTypeNumber() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
- getTypeSerializer() - Method in class org.apache.flink.streaming.api.graph.StreamConfig.NetworkInputConfig
- getTypeSerializer(String) - Method in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
-
TODO this method should be removed once the serializer map is removed.
- getTypeSerializerIn(int, ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getTypeSerializerIn1(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
Deprecated.
- getTypeSerializerIn2(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
Deprecated.
- getTypeSerializerOut() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getTypeSerializerOut(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getTypeSerializerSideOut(OutputTag<?>, ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getTypeSerializersIn() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getTypeSerializerSnapshot(String) - Method in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
- getTypeSerializerSnapshot(StateMetaInfoSnapshot.CommonSerializerKeys) - Method in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
- getUdfRuntimeContext() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
- getUnalignedCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
- getUnalignedCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
- getUnalignedCheckpoint() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
- getUnannouncedCredit() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
Gets the currently unannounced credit.
- getUnavailableToResetAvailable() - Method in class org.apache.flink.runtime.io.AvailabilityProvider.AvailabilityHelper
-
Returns the previously not completed future and resets the constant completed
AvailabilityProvider.AVAILABLEas the current state. - getUnavailableToResetUnavailable() - Method in class org.apache.flink.runtime.io.AvailabilityProvider.AvailabilityHelper
-
Creates a new uncompleted future as the current state and returns the previous uncompleted one.
- getUnconsumedBuffer() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
-
Gets the unconsumed buffer which needs to be persisted in unaligned checkpoint scenario.
- getUnconsumedBuffer() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
- getUnfinishedChannels() - Method in class org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate
-
Returns the list of channels that have not received EndOfPartitionEvent.
- getUnfinishedChannels() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- getUnfinishedChannels() - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
- getUnfulfillableJobs() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceAllocationResult
- getUnionListState(ListStateDescriptor<S>) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
- getUniqueInputFormat() - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
- getUniqueOutputFormat() - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
- getUnmodifiedExecutionVertices(Set<ExecutionVertexVersion>) - Method in class org.apache.flink.runtime.scheduler.ExecutionVertexVersioner
- getUnreleasedPartitions() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatusHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointTriggerHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerCustomLogHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerLogFileHeader
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerLogListHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerProfilingFileHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerProfilingHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerProfilingListHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerStdoutFileHeader
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.cluster.JobManagerThreadDumpHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.CustomHeadersDecorator
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteStatusHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteTriggerHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetListHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.coordination.ClientCoordinationHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.JobManagerJobConfigurationHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.JobManagerJobEnvironmentHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.JobResourceRequirementsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.JobResourcesRequirementsUpdateHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.JobStatusInfoHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedJobMetricsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedSubtaskMetricsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedTaskManagerMetricsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerOperatorMetricsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexMetricsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexWatermarksHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointTriggerHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobCancellationHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobClientHeartbeatHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobManagerEnvironmentHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobManagerLogUrlHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobVertexFlameGraphHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerCustomLogHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingFileHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingListHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerStdoutFileHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerThreadDumpHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.TaskManagerLogUrlHeaders
- getUnresolvedMessageParameters() - Method in interface org.apache.flink.runtime.rest.messages.UntypedResponseMessageHeaders
-
Returns a new
MessageParametersobject. - getUnresolvedTaskManagerLocation() - Method in class org.apache.flink.runtime.jobmaster.TaskManagerRegistrationInformation
- getUnresolvedTaskManagerLocation() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
- getUnusedResource() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingTaskManager
- getUnWantedTaskManager() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- getUnwantedWorkers() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceDeclaration
- getUploadDir() - Method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
-
Returns the directory used to temporarily store multipart/form-data uploads.
- getUploadedFiles() - Method in class org.apache.flink.runtime.rest.handler.FileUploads
- getUploadedFiles() - Method in class org.apache.flink.runtime.rest.handler.HandlerRequest
- getUpperBound() - Method in class org.apache.flink.runtime.jobgraph.JobVertexResourceRequirements.Parallelism
- getUpstreamSubtaskStateMapper() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Gets the channel state rescaler used for rescaling persisted data on upstream side of this JobEdge.
- getUpstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
- getUpstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
- getUpstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
- getUpstreamSubtaskStateMapper() - Method in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
-
Defines the behavior of this partitioner, when upstream rescaled during recovery of in-flight data.
- getURLVersionPrefix() - Method in interface org.apache.flink.runtime.rest.versioning.RestAPIVersion
-
Returns the URL version prefix (e.g.
- getURLVersionPrefix() - Method in enum org.apache.flink.runtime.rest.versioning.RuntimeRestAPIVersion
-
Returns the URL version prefix (e.g.
- getUsedMemory() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
- getUseLargeRecordHandler() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getUserAccumulators() - Method in class org.apache.flink.runtime.executiongraph.Execution
- getUserAccumulators() - Method in class org.apache.flink.runtime.jobmaster.event.ExecutionVertexFinishedEvent
- getUserAccumulators() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
- getUserAccumulatorsStringified() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
Returns the user-defined accumulators as strings.
- getUserAccumulatorsStringified() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
- getUserAccumulatorsStringified() - Method in class org.apache.flink.runtime.executiongraph.Execution
- getUserArtifacts() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Gets the list of assigned user jar paths.
- getUserArtifacts() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getUserClassloader() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
- getUserClassLoader() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getUserClassLoader() - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
- getUserClassLoader() - Method in class org.apache.flink.runtime.failure.DefaultFailureEnricherContext
- getUserClassLoader() - Method in class org.apache.flink.runtime.query.KvStateEntry
- getUserClassPaths() - Method in class org.apache.flink.runtime.entrypoint.component.AbstractUserClassPathJobGraphRetriever
- getUserCodeClassloader() - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator.Context
-
Gets the classloader that contains the additional dependencies, which are not part of the JVM's classpath.
- getUserCodeClassloader() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- getUserCodeClassloader() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- getUserCodeClassLoader() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the user code class loader.
- getUserCodeClassLoader() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the user code class loader of this invokable.
- getUserCodeClassLoader() - Method in interface org.apache.flink.runtime.operators.TaskContext
- getUserCodeClassLoader() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getUserCodeClassLoader() - Method in interface org.apache.flink.streaming.runtime.tasks.ContainingTaskDetails
- getUserDefinedOperatorID() - Method in class org.apache.flink.runtime.OperatorIDPair
- getUserDefinedOperatorName() - Method in class org.apache.flink.runtime.OperatorIDPair
- getUserDefinedOperatorUid() - Method in class org.apache.flink.runtime.OperatorIDPair
- getUserFunction() - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateUdfStreamOperator
-
Gets the user function executed in this operator.
- getUserFunction() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
Gets the user function executed in this operator.
- getUserFunction() - Method in class org.apache.flink.streaming.api.operators.SimpleUdfStreamOperatorFactory
- getUserFunction() - Method in interface org.apache.flink.streaming.api.operators.UdfStreamOperatorFactory
- getUserFunction() - Method in interface org.apache.flink.streaming.api.operators.UserFunctionProvider
- getUserFunction() - Method in class org.apache.flink.streaming.api.transformations.BroadcastStateTransformation
- getUserFunction() - Method in class org.apache.flink.streaming.api.transformations.KeyedBroadcastStateTransformation
- getUserFunctionClassName() - Method in class org.apache.flink.streaming.api.operators.SimpleUdfStreamOperatorFactory
- getUserFunctionClassName() - Method in interface org.apache.flink.streaming.api.operators.UdfStreamOperatorFactory
- getUserFunctionParameters() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
Since the streaming API does not implement any parametrization of functions via a configuration, the config returned here is actually empty.
- getUserHash() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- getUserJarBlobKeys() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns a set of BLOB keys referring to the JAR files required to run this job.
- getUserJars() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Gets the list of assigned user jar paths.
- getUserKeySerializer() - Method in class org.apache.flink.runtime.state.v2.MapStateDescriptor
- getUserMap() - Method in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
-
Gets the map for user-defined accumulators.
- getUserValue() - Method in class org.apache.flink.runtime.state.ttl.TtlValue
- getValue() - Method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
- getValue() - Method in class org.apache.flink.runtime.executiongraph.metrics.DownTimeGauge
- getValue() - Method in class org.apache.flink.runtime.executiongraph.metrics.UpTimeGauge
- getValue() - Method in class org.apache.flink.runtime.io.network.metrics.AbstractBuffersUsageGauge
- getValue() - Method in class org.apache.flink.runtime.io.network.metrics.InputBuffersGauge
- getValue() - Method in class org.apache.flink.runtime.io.network.metrics.InputBuffersSizeGauge
- getValue() - Method in class org.apache.flink.runtime.io.network.metrics.OutputBufferPoolUsageGauge
- getValue() - Method in class org.apache.flink.runtime.io.network.metrics.OutputBuffersGauge
- getValue() - Method in class org.apache.flink.runtime.io.network.metrics.OutputBuffersSizeGauge
- getValue() - Method in class org.apache.flink.runtime.io.network.metrics.TimeToConsumeGauge
- getValue() - Method in class org.apache.flink.runtime.metrics.TimerGauge
- getValue() - Method in class org.apache.flink.runtime.persistence.IntegerResourceVersion
- getValue() - Method in class org.apache.flink.runtime.persistence.StringResourceVersion
- getValue() - Method in class org.apache.flink.runtime.rest.HttpHeader
-
Returns the value of this HTTP header.
- getValue() - Method in class org.apache.flink.runtime.rest.messages.ConfigurationInfoEntry
- getValue() - Method in class org.apache.flink.runtime.rest.messages.job.FailureLabelFilterParameter.FailureLabel
- getValue() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.Metric
- getValue() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
- getValue() - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Returns the resolved value of this parameter, or
nullif it isn't resolved yet. - getValue() - Method in class org.apache.flink.runtime.state.restore.KeyGroupEntry
- getValue() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
- getValue() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperVersionedValue
- getValue() - Method in class org.apache.flink.streaming.runtime.metrics.MinWatermarkGauge
- getValue() - Method in class org.apache.flink.streaming.runtime.metrics.WatermarkGauge
- getValue() - Method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
- getValue() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Returns the value wrapped in this stream value.
- getValueByKeyA(A) - Method in class org.apache.flink.runtime.util.DualKeyLinkedMap
- getValueByKeyB(B) - Method in class org.apache.flink.runtime.util.DualKeyLinkedMap
- getValueClass() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationStatusMessageHeaders
-
Returns the class of the value wrapped in the
AsynchronousOperationResult. - getValueClass() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
- getValueClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatusHeaders
- getValueClass() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteStatusHeaders
- getValueClass() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
- getValueClass() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
- getValues() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
- getValues() - Method in interface org.apache.flink.runtime.util.KeyGroupedIterator
- getValues() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator
-
Returns an iterator over all values that belong to the current key.
- getValues() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator
-
Returns an iterator over all values that belong to the current key.
- getValues1() - Method in class org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
- getValues1() - Method in class org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
- getValues1() - Method in interface org.apache.flink.runtime.operators.util.CoGroupTaskIterator
-
Returns an iterable over the left input values for the current key.
- getValues2() - Method in class org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
- getValues2() - Method in class org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
- getValues2() - Method in interface org.apache.flink.runtime.operators.util.CoGroupTaskIterator
-
Returns an iterable over the left input values for the current key.
- getValueSerializer() - Method in interface org.apache.flink.runtime.state.internal.InternalKvState
-
Returns the
TypeSerializerfor the type of value this state holds. - getValueSerializer() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
- getValueSerializer() - Method in class org.apache.flink.runtime.state.v2.AbstractKeyedState
-
Return related value serializer.
- getValueState(ValueStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.v2.DefaultKeyedStateStoreV2
- getValueState(ValueStateDescriptor<T>) - Method in interface org.apache.flink.runtime.state.v2.KeyedStateStoreV2
-
Gets a handle to the system's
ValueState. - getValueState(ValueStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
- getVariable() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
- getVariable(BroadcastVariableInitializer<T, C>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
- getVersion() - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV1Serializer
- getVersion() - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV2Serializer
- getVersion() - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV3Serializer
- getVersion() - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV4Serializer
- getVersion() - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV5Serializer
- getVersion() - Method in class org.apache.flink.runtime.jobmaster.event.GenericJobEventSerializer
- getVersion() - Method in class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
- getVersion() - Method in class org.apache.flink.runtime.scheduler.ExecutionVertexVersion
- getVersion() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
- getVersion() - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
- getVersion() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Returns the version of the code as String.
- getVersion() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageSerializer
- getVersion() - Method in class org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
- getVersion() - Method in class org.apache.flink.streaming.api.operators.collect.CollectCoordinationRequest
- getVersion() - Method in class org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
- getVersion() - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
- getVersion() - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollectorSerializer
- getVersionedValue() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
- getVertex() - Method in class org.apache.flink.runtime.executiongraph.Execution
- getVertex(JobVertexID) - Method in class org.apache.flink.runtime.jobgraph.topology.DefaultLogicalPipelinedRegion
- getVertex(JobVertexID) - Method in class org.apache.flink.runtime.jobgraph.topology.DefaultLogicalTopology
- getVertex(ExecutionVertexID) - Method in class org.apache.flink.runtime.scheduler.adapter.DefaultExecutionTopology
- getVertex(ExecutionVertexID) - Method in class org.apache.flink.runtime.scheduler.adapter.DefaultSchedulingPipelinedRegion
- getVertex(ExecutionVertexID) - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingTopology
-
Looks up the
SchedulingExecutionVertexfor the givenExecutionVertexID. - getVertex(VID) - Method in interface org.apache.flink.runtime.topology.PipelinedRegion
-
Returns the vertex with the specified vertex id.
- getVertexDescriptionMode() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getVertexId() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
- getVertexID() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getVertexIds() - Method in interface org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
-
Returns the IDs of the
JobVertexinstances participating in this group. - getVertexIds() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroupImpl
- getVertexIDs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- getVertexInformation(JobVertexID) - Method in interface org.apache.flink.runtime.scheduler.adaptive.allocator.JobInformation
- getVertexInformation(JobVertexID) - Method in class org.apache.flink.runtime.scheduler.adaptive.JobGraphJobInformation
- getVertexNonChainedOutputs(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- getVertexParallelism() - Method in class org.apache.flink.runtime.scheduler.adaptive.JobSchedulingPlan
- getVertexParallelismStore() - Method in class org.apache.flink.runtime.scheduler.adaptive.JobGraphJobInformation
- getVertexWithAttempt() - Method in class org.apache.flink.runtime.executiongraph.Execution
- getVertices() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns an Iterable to iterate all vertices registered with the job graph.
- getVertices() - Method in class org.apache.flink.runtime.jobgraph.topology.DefaultLogicalPipelinedRegion
- getVertices() - Method in class org.apache.flink.runtime.jobgraph.topology.DefaultLogicalTopology
- getVertices() - Method in class org.apache.flink.runtime.scheduler.adapter.DefaultExecutionTopology
- getVertices() - Method in class org.apache.flink.runtime.scheduler.adapter.DefaultSchedulingPipelinedRegion
- getVertices() - Method in interface org.apache.flink.runtime.scheduler.adaptive.allocator.JobInformation
- getVertices() - Method in class org.apache.flink.runtime.scheduler.adaptive.allocator.VertexParallelism
- getVertices() - Method in class org.apache.flink.runtime.scheduler.adaptive.JobGraphJobInformation
- getVertices() - Method in interface org.apache.flink.runtime.topology.BaseTopology
-
Returns an iterable over all vertices, topologically sorted.
- getVertices() - Method in interface org.apache.flink.runtime.topology.PipelinedRegion
-
Returns vertices that are in this pipelined region.
- getVerticesAsArray() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns an array of all job vertices that are registered with the job graph.
- getVerticesSortedTopologicallyFromSources() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
- getVerticesTopologically() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns an iterable containing all job vertices for this execution graph in the order they were created.
- getVerticesTopologically() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
- getVerticesTopologically() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- getVerticesTopologically() - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- getVerticesToRestart() - Method in class org.apache.flink.runtime.executiongraph.failover.FailureHandlingResult
-
Returns the tasks to restart.
- getViewReader() - Method in class org.apache.flink.runtime.io.network.netty.NettyPartitionRequestListener
- getViewReader() - Method in interface org.apache.flink.runtime.io.network.partition.PartitionRequestListener
-
Get the view reader of the notifier.
- getWaitForSolutionSetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- getWaitTime() - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
-
Returns the wait time.
- getWaitTime() - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
-
Returns the wait time.
- getWatermark() - Method in class org.apache.flink.runtime.source.event.ReportedWatermarkEvent
- getWatermarkGauge() - Method in class org.apache.flink.streaming.api.operators.CountingOutput
- getWatermarkGauge() - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
- getWatermarkGauge() - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreMainOperatorOutput
- getWatermarkGauge() - Method in interface org.apache.flink.streaming.runtime.tasks.WatermarkGaugeExposingOutput
- getWatermarkStrategy() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
- getWatermarkStrategy() - Method in class org.apache.flink.streaming.api.transformations.TimestampsAndWatermarksTransformation
-
Returns the
WatermarkStrategyto use. - getWebInterfaceUrl() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerProcessContext
- getWebMonitorAddress(Configuration, AddressResolution) - Static method in class org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
-
Get address of web monitor from configuration.
- getWebMonitorLeaderElection() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Deprecated.
- getWebMonitorLeaderRetriever() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Deprecated.just use
HighAvailabilityServices.getClusterRestEndpointLeaderRetriever()instead of this method. - getWebUiDir() - Method in class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
- getWindowAssigner() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
- getWindowAssigner() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorFactory
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
-
Returns a
TypeSerializerfor serializing windows that are assigned by thisWindowAssigner. - getWindowStartWithOffset(long, long, long) - Static method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
Method to get the window start for a timestamp.
- getWorker() - Method in class org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
- getWorkerByInstanceId(InstanceID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- getWorkerIndex() - Method in class org.apache.flink.runtime.iterative.event.WorkerDoneEvent
- getWorkerNodeIfAcceptRegistration(ResourceID) - Method in class org.apache.flink.runtime.resourcemanager.active.ActiveResourceManager
- getWorkerNodeIfAcceptRegistration(ResourceID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
Get worker node if the worker resource is accepted.
- getWorkerNodeIfAcceptRegistration(ResourceID) - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
- getWrappedDelegate() - Method in class org.apache.flink.runtime.dispatcher.OnMainThreadJobManagerRunnerRegistry
-
Returns the delegated
JobManagerRunnerRegistry. - getWrappedException() - Method in exception org.apache.flink.runtime.operators.chaining.ExceptionInChainedStubException
- getWrappedMetricGroup() - Method in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
- getWritableBytes() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
- getWriteBufferSize() - Method in class org.apache.flink.runtime.state.storage.FileSystemCheckpointStorage
-
Gets the write buffer size for created checkpoint stream.
- getWriteEnd() - Method in class org.apache.flink.runtime.iterative.concurrent.BlockingBackChannel
-
Called by iteration tail to save the output of the current superstep.
- getWriteOffset() - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
- getWriter() - Static method in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshotReadersWriters
-
Returns the writer for
StateMetaInfoSnapshot. - getWriter(int) - Method in interface org.apache.flink.runtime.execution.Environment
- getWriter(int) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- getWriteResult(long) - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriterImpl
- getWriteResultSerializer() - Method in interface org.apache.flink.streaming.api.connector.sink2.SupportsPreCommitTopology
-
Returns the serializer of the WriteResult type.
- getWriterForVersion(int, InternalTimersSnapshot<K, N>, TypeSerializer<K>, TypeSerializer<N>) - Static method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters
- getWriters() - Method in class org.apache.flink.runtime.operators.shipping.OutputCollector
-
List of writers that are associated with this output collector
- getWriterUidHash() - Method in class org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes
- getWrittenBytes() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
- getZooKeeperEnsemble(Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Returns the configured ZooKeeper quorum (and removes whitespace, because ZooKeeper does not tolerate it).
- getZooKeeperLoginContextName() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
- getZooKeeperServiceName() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
- global() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStreamso that the output values all go to the first instance of the next processing operator. - GLOBAL_COMMITTER_TRANSFORMATION_NAME - Static variable in class org.apache.flink.streaming.api.connector.sink2.StandardSinkTopologies
- GlobalAggregateManager - Interface in org.apache.flink.runtime.taskexecutor
-
This interface gives access to transient, named, global aggregates.
- globalCleanupAsync(JobID, Executor) - Method in class org.apache.flink.runtime.blob.BlobServer
-
Removes all BLOBs from local and HA store belonging to the given
JobID. - globalCleanupAsync(JobID, Executor) - Method in interface org.apache.flink.runtime.dispatcher.cleanup.GloballyCleanableResource
-
globalCleanupAsyncis expected to be called from the main thread. - globalCleanupAsync(JobID, Executor) - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
- globalCleanupAsync(JobID, Executor) - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
- globalCleanupAsync(JobID, Executor) - Method in class org.apache.flink.runtime.jobmanager.DefaultJobGraphStore
- globalCleanupAsync(JobID, Executor) - Method in interface org.apache.flink.runtime.jobmanager.JobGraphWriter
- GlobalFailureHandler - Interface in org.apache.flink.runtime.scheduler
-
An interface for handling global failures.
- GloballyCleanableResource - Interface in org.apache.flink.runtime.dispatcher.cleanup
-
GloballyCleanableResourceis supposed to be implemented by any class that provides artifacts for a given job that need to be cleaned up after the job reached a global terminal state. - GlobalPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that sends all elements to the downstream operator with subtask ID=0.
- GlobalPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
- globalState() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyAllWindowContext
- globalState() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
- globalState() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
-
State accessor for per-key global state.
- globalState() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
-
State accessor for per-key global state.
- globalState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessAllWindowContext
- globalState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
- globalState() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
- globalState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
- GlobalStreamExchangeMode - Enum in org.apache.flink.streaming.api.graph
-
This mode decides the default
ResultPartitionTypeof job edges. - GlobalWindow - Class in org.apache.flink.streaming.api.windowing.windows
-
The default window into which all data is placed (via
GlobalWindows). - GlobalWindow.Serializer - Class in org.apache.flink.streaming.api.windowing.windows
-
A
TypeSerializerforGlobalWindow. - GlobalWindow.Serializer.GlobalWindowSerializerSnapshot - Class in org.apache.flink.streaming.api.windowing.windows
-
Serializer configuration snapshot for compatibility and format evolution.
- GlobalWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssignerthat assigns all elements to the sameGlobalWindow. - GlobalWindows.EndOfStreamTrigger - Class in org.apache.flink.streaming.api.windowing.assigners
-
A trigger that fires iff the input stream reaches EndOfStream.
- GlobalWindows.NeverTrigger - Class in org.apache.flink.streaming.api.windowing.assigners
-
A trigger that never fires, as default Trigger for GlobalWindows.
- GlobalWindowSerializerSnapshot() - Constructor for class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer.GlobalWindowSerializerSnapshot
- goToCanceling(ExecutionGraph, ExecutionGraphHandler, OperatorCoordinatorHandler, List<ExceptionHistoryEntry>) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- goToCanceling(ExecutionGraph, ExecutionGraphHandler, OperatorCoordinatorHandler, List<ExceptionHistoryEntry>) - Method in interface org.apache.flink.runtime.scheduler.adaptive.StateTransitions.ToCancelling
-
Transitions into the
Cancelingstate. - goToCreatingExecutionGraph(ExecutionGraph) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- goToCreatingExecutionGraph(ExecutionGraph) - Method in interface org.apache.flink.runtime.scheduler.adaptive.StateTransitions.ToCreatingExecutionGraph
-
Transitions into the
CreatingExecutionGraphstate. - goToExecuting(ExecutionGraph, ExecutionGraphHandler, OperatorCoordinatorHandler, List<ExceptionHistoryEntry>) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- goToExecuting(ExecutionGraph, ExecutionGraphHandler, OperatorCoordinatorHandler, List<ExceptionHistoryEntry>) - Method in interface org.apache.flink.runtime.scheduler.adaptive.StateTransitions.ToExecuting
-
Transitions into the
Executingstate. - goToFailing(ExecutionGraph, ExecutionGraphHandler, OperatorCoordinatorHandler, Throwable, List<ExceptionHistoryEntry>) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- goToFailing(ExecutionGraph, ExecutionGraphHandler, OperatorCoordinatorHandler, Throwable, List<ExceptionHistoryEntry>) - Method in interface org.apache.flink.runtime.scheduler.adaptive.StateTransitions.ToFailing
-
Transitions into the
Failingstate. - goToFinished(ArchivedExecutionGraph) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- goToFinished(ArchivedExecutionGraph) - Method in interface org.apache.flink.runtime.scheduler.adaptive.StateTransitions.ToFinished
-
Transitions into the
Finishedstate. - goToRestarting(ExecutionGraph, ExecutionGraphHandler, OperatorCoordinatorHandler, Duration, boolean, List<ExceptionHistoryEntry>) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- goToRestarting(ExecutionGraph, ExecutionGraphHandler, OperatorCoordinatorHandler, Duration, boolean, List<ExceptionHistoryEntry>) - Method in interface org.apache.flink.runtime.scheduler.adaptive.StateTransitions.ToRestarting
-
Transitions into the
Restartingstate. - goToStopWithSavepoint(ExecutionGraph, ExecutionGraphHandler, OperatorCoordinatorHandler, CheckpointScheduling, CompletableFuture<String>, List<ExceptionHistoryEntry>) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- goToStopWithSavepoint(ExecutionGraph, ExecutionGraphHandler, OperatorCoordinatorHandler, CheckpointScheduling, CompletableFuture<String>, List<ExceptionHistoryEntry>) - Method in interface org.apache.flink.runtime.scheduler.adaptive.StateTransitions.ToStopWithSavepoint
-
Transitions into the
StopWithSavepointstate. - goToWaitingForResources(ExecutionGraph) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- goToWaitingForResources(ExecutionGraph) - Method in interface org.apache.flink.runtime.scheduler.adaptive.StateTransitions.ToWaitingForResources
-
Transitions into the
WaitingForResourcesstate. - GRACEFUL_SHUTDOWN - org.apache.flink.runtime.entrypoint.ClusterEntrypoint.ShutdownBehaviour
- grantDispatcherLeadership() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServicesWithLeadershipControl
- grantDispatcherLeadership() - Method in interface org.apache.flink.runtime.highavailability.nonha.embedded.HaLeadershipControl
- grantJobMasterLeadership(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServicesWithLeadershipControl
- grantJobMasterLeadership(JobID) - Method in interface org.apache.flink.runtime.highavailability.nonha.embedded.HaLeadershipControl
- grantLeadership(UUID) - Method in class org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherRunner
- grantLeadership(UUID) - Method in class org.apache.flink.runtime.jobmaster.JobMasterServiceLeadershipRunner
- grantLeadership(UUID) - Method in interface org.apache.flink.runtime.leaderelection.LeaderContender
-
Callback method which is called by the
LeaderElectionServiceupon selecting this instance as the new leader. - grantLeadership(UUID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerServiceImpl
- grantLeadership(UUID) - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
- grantResourceManagerLeadership() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServicesWithLeadershipControl
- grantResourceManagerLeadership() - Method in interface org.apache.flink.runtime.highavailability.nonha.embedded.HaLeadershipControl
- GroupCache<G,K,V> - Interface in org.apache.flink.runtime.util
-
This
GroupCachecan cache group, key and value. - GroupReduceCombineDriver<IN,OUT> - Class in org.apache.flink.runtime.operators
-
Non-chained combine driver which is used for a CombineGroup transformation or a GroupReduce transformation where the user supplied a RichGroupReduceFunction with a combine method.
- GroupReduceCombineDriver() - Constructor for class org.apache.flink.runtime.operators.GroupReduceCombineDriver
- GroupReduceDriver<IT,OT> - Class in org.apache.flink.runtime.operators
-
GroupReduce task which is executed by a Task Manager.
- GroupReduceDriver() - Constructor for class org.apache.flink.runtime.operators.GroupReduceDriver
H
- HA_STORAGE_COMPLETED_CHECKPOINT - Static variable in class org.apache.flink.runtime.util.ZooKeeperUtils
-
The prefix of the completed checkpoint file.
- HA_STORAGE_SUBMITTED_JOBGRAPH_PREFIX - Static variable in class org.apache.flink.runtime.util.ZooKeeperUtils
-
The prefix of the submitted job graph file.
- HadoopDelegationTokenConverter - Class in org.apache.flink.runtime.security.token.hadoop
-
Delegation token serializer and deserializer functionality.
- HadoopDelegationTokenConverter() - Constructor for class org.apache.flink.runtime.security.token.hadoop.HadoopDelegationTokenConverter
- HadoopDelegationTokenReceiver - Class in org.apache.flink.runtime.security.token.hadoop
-
Hadoop delegation token receiver base class.
- HadoopDelegationTokenReceiver() - Constructor for class org.apache.flink.runtime.security.token.hadoop.HadoopDelegationTokenReceiver
- HadoopDependency - Class in org.apache.flink.runtime.hadoop
-
Responsible telling if specific Hadoop dependencies are on classpath.
- HadoopDependency() - Constructor for class org.apache.flink.runtime.hadoop.HadoopDependency
- HadoopFSDelegationTokenProvider - Class in org.apache.flink.runtime.security.token.hadoop
-
Delegation token provider for Hadoop filesystems.
- HadoopFSDelegationTokenProvider() - Constructor for class org.apache.flink.runtime.security.token.hadoop.HadoopFSDelegationTokenProvider
- HadoopFSDelegationTokenReceiver - Class in org.apache.flink.runtime.security.token.hadoop
-
Delegation token receiver for Hadoop filesystems.
- HadoopFSDelegationTokenReceiver() - Constructor for class org.apache.flink.runtime.security.token.hadoop.HadoopFSDelegationTokenReceiver
- HadoopModule - Class in org.apache.flink.runtime.security.modules
-
Responsible for installing a Hadoop login user.
- HadoopModule(SecurityConfiguration, Configuration) - Constructor for class org.apache.flink.runtime.security.modules.HadoopModule
- HadoopModuleFactory - Class in org.apache.flink.runtime.security.modules
- HadoopModuleFactory() - Constructor for class org.apache.flink.runtime.security.modules.HadoopModuleFactory
- HadoopSecurityContext - Class in org.apache.flink.runtime.security.contexts
-
Hadoop security context which runs a Callable with the previously initialized UGI and appropriate security credentials.
- HadoopSecurityContext(UserGroupInformation) - Constructor for class org.apache.flink.runtime.security.contexts.HadoopSecurityContext
- HadoopSecurityContextFactory - Class in org.apache.flink.runtime.security.contexts
-
Default security context factory that instantiates
SecurityContextbased on installed modules, it would instantiateHadoopSecurityContextif aHadoopModuleFactoryis included. - HadoopSecurityContextFactory() - Constructor for class org.apache.flink.runtime.security.contexts.HadoopSecurityContextFactory
- HadoopUserUtils - Class in org.apache.flink.runtime.hadoop
-
Utility class for working with Hadoop user related classes.
- HadoopUserUtils() - Constructor for class org.apache.flink.runtime.hadoop.HadoopUserUtils
- HaLeadershipControl - Interface in org.apache.flink.runtime.highavailability.nonha.embedded
-
Interface to grant and revoke leadership of HA components.
- handIn(String, V) - Method in class org.apache.flink.runtime.iterative.concurrent.Broker
-
Hand in the object to share.
- handleAsyncException(String, Throwable) - Method in interface org.apache.flink.runtime.taskmanager.AsyncExceptionHandler
-
Handles an exception thrown by another thread (e.g. a TriggerTask), other than the one executing the main task.
- handleAsyncException(String, Throwable) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Handles an exception thrown by another thread (e.g. a TriggerTask), other than the one executing the main task by failing the task entirely.
- handleCheckpointException(PendingCheckpoint, CheckpointProperties, CheckpointException, ExecutionAttemptID, JobID, PendingCheckpointStats, CheckpointStatsTracker) - Method in class org.apache.flink.runtime.checkpoint.CheckpointFailureManager
-
Failures on JM: all checkpoints - go against failure counter.
- handleCheckpointRequest(HandlerRequest<EmptyRequestBody>, AbstractCheckpointStats) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.AbstractCheckpointHandler
-
Called for each request with the corresponding
AbstractCheckpointStatsinstance. - handleCheckpointRequest(HandlerRequest<EmptyRequestBody>, AbstractCheckpointStats) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointStatisticDetailsHandler
- handleCheckpointRequest(HandlerRequest<EmptyRequestBody>, AbstractCheckpointStats) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.TaskCheckpointStatisticDetailsHandler
- handleCheckpointStatsRequest(HandlerRequest<EmptyRequestBody>, CheckpointStatsSnapshot) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.AbstractCheckpointHandler
- handleCheckpointStatsRequest(HandlerRequest<EmptyRequestBody>, CheckpointStatsSnapshot) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.AbstractCheckpointStatsHandler
- handleCheckpointStatsRequest(HandlerRequest<EmptyRequestBody>, CheckpointStatsSnapshot) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointingStatisticsHandler
- handleCheckpointSuccess(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointFailureManager
-
Handle checkpoint success.
- handleCoordinationRequest(CoordinationRequest) - Method in interface org.apache.flink.runtime.operators.coordination.CoordinationRequestHandler
-
Called when receiving a request from the client or operator.
- handleCoordinationRequest(CoordinationRequest) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
- handleEndOfRecovery(InputChannelInfo) - Method in interface org.apache.flink.streaming.runtime.io.checkpointing.UpstreamRecoveryTracker
- handleError(Exception) - Method in class org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherRunner
- handleError(Exception) - Method in class org.apache.flink.runtime.jobmaster.JobMasterServiceLeadershipRunner
- handleError(Exception) - Method in interface org.apache.flink.runtime.leaderelection.LeaderContender
-
Callback method which is called by
LeaderElectionServicein case of an error in the service thread. - handleError(Exception) - Method in interface org.apache.flink.runtime.leaderretrieval.LeaderRetrievalListener
-
This method is called by the
LeaderRetrievalServicein case of an exception. - handleError(Exception) - Method in class org.apache.flink.runtime.net.ConnectionUtils.LeaderConnectingAddressListener
- handleError(Exception) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerServiceImpl
- handleError(Exception) - Method in class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderInformationListener
- handleError(Exception) - Method in class org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
- handleError(Exception) - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
- handleError(Throwable) - Method in interface org.apache.flink.runtime.resourcemanager.JobLeaderIdActions
-
Callback to report occurring errors.
- handleError(Throwable) - Method in interface org.apache.flink.runtime.taskexecutor.JobLeaderListener
-
Callback for errors which might occur in the
JobLeaderService. - handleEvent(AbstractEvent) - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
-
Handles the event and returns whether the reader reached an end-of-stream event (either the end of the whole stream or the end of an superstep).
- handleEventFromOperator(int, int, OperatorEvent) - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator
-
Hands an OperatorEvent coming from a parallel Operator instance (one attempt of the parallel subtasks).
- handleEventFromOperator(int, int, OperatorEvent) - Method in class org.apache.flink.runtime.operators.coordination.OperatorCoordinatorHolder
- handleEventFromOperator(int, int, OperatorEvent) - Method in class org.apache.flink.runtime.operators.coordination.RecreateOnResetOperatorCoordinator
- handleEventFromOperator(int, int, OperatorEvent) - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinator
- handleEventFromOperator(int, int, OperatorEvent) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
- handleException(E) - Method in interface org.apache.flink.runtime.operators.sort.ExceptionHandler
-
This method is called when the handler should deal with an exception.
- handleException(ChannelHandlerContext, HttpRequest, Throwable, ResourceID) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.AbstractTaskManagerFileHandler
- handleException(ChannelHandlerContext, HttpRequest, Throwable, ResourceID) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerStdoutFileHandler
- handleExecutionsTermination(Collection<ExecutionState>) - Method in interface org.apache.flink.runtime.scheduler.stopwithsavepoint.StopWithSavepointTerminationHandler
-
Handles the termination of the job based on the passed terminated
ExecutionStates. stop-with-savepoint expects theterminatedExecutionStatesto only containExecutionState.FINISHEDto succeed. - handleExecutionsTermination(Collection<ExecutionState>) - Method in class org.apache.flink.runtime.scheduler.stopwithsavepoint.StopWithSavepointTerminationHandlerImpl
- handleFailedResponse(int, Throwable) - Method in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator
-
Handles the failed stats response by canceling the corresponding unfinished pending request.
- handleGlobalFailure(Throwable) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- handleGlobalFailure(Throwable) - Method in class org.apache.flink.runtime.scheduler.DefaultScheduler
- handleGlobalFailure(Throwable) - Method in interface org.apache.flink.runtime.scheduler.GlobalFailureHandler
-
Handles a global failure.
- handleGlobalFailure(Throwable, CompletableFuture<Map<String, String>>) - Method in interface org.apache.flink.runtime.scheduler.adaptive.LabeledGlobalFailureHandler
-
An adapted version of
GlobalFailureHandlerthat handles and associates global failures with enricher labels. - handleMissingThrowable(Throwable) - Static method in class org.apache.flink.runtime.executiongraph.ErrorInfo
-
Utility method to cover FLINK-21376.
- handleOperatorEvent(OperatorEvent) - Method in interface org.apache.flink.runtime.operators.coordination.OperatorEventHandler
- handleOperatorEvent(OperatorEvent) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperator
- handleOperatorEvent(OperatorEvent) - Method in class org.apache.flink.streaming.api.operators.SourceOperator
- handleProcessedBuffer(T, IOException) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
Handles a processed Buffer.
- handleRequest(State, StateRequestType, IN) - Method in class org.apache.flink.runtime.asyncprocessing.AsyncExecutionController
-
Submit a
StateRequestto this AsyncExecutionController and trigger it if needed. - handleRequest(State, StateRequestType, IN) - Method in interface org.apache.flink.runtime.asyncprocessing.StateRequestHandler
-
Submit a
StateRequestto this StateRequestHandler. - handleRequest(StateRequestType, IN) - Method in class org.apache.flink.runtime.state.v2.AbstractKeyedState
-
Submit a state request to AEC.
- handleRequest(HandlerRequest<B>, T) - Method in class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.TriggerHandler
- handleRequest(HandlerRequest<CheckpointTriggerRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointHandlers.CheckpointTriggerHandler
- handleRequest(HandlerRequest<ProfilingRequestBody>, ResourceManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerProfilingHandler
- handleRequest(HandlerRequest<ProfilingRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.cluster.JobManagerProfilingHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, AccessExecution) - Method in class org.apache.flink.runtime.rest.handler.job.AbstractSubtaskAttemptHandler
-
Called for each request after the corresponding
AccessExecutionhas been retrieved from theAccessExecutionVertex. - handleRequest(HandlerRequest<EmptyRequestBody>, AccessExecution) - Method in class org.apache.flink.runtime.rest.handler.job.SubtaskExecutionAttemptAccumulatorsHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, AccessExecution) - Method in class org.apache.flink.runtime.rest.handler.job.SubtaskExecutionAttemptDetailsHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.AbstractAccessExecutionGraphHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.AbstractJobVertexHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointConfigHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobAccumulatorsHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobConfigHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobDetailsHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobPlanHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobVertexDetailsHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobVertexTaskManagersHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, AccessExecutionJobVertex) - Method in class org.apache.flink.runtime.rest.handler.job.AbstractJobVertexHandler
-
Called for each request after the corresponding
AccessExecutionJobVertexhas been retrieved from theAccessExecutionGraph. - handleRequest(HandlerRequest<EmptyRequestBody>, AccessExecutionJobVertex) - Method in class org.apache.flink.runtime.rest.handler.job.AbstractSubtaskHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, AccessExecutionJobVertex) - Method in class org.apache.flink.runtime.rest.handler.job.JobVertexAccumulatorsHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, AccessExecutionJobVertex) - Method in class org.apache.flink.runtime.rest.handler.job.JobVertexFlameGraphHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, AccessExecutionJobVertex) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.JobVertexWatermarksHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, AccessExecutionJobVertex) - Method in class org.apache.flink.runtime.rest.handler.job.SubtasksAllAccumulatorsHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, AccessExecutionJobVertex) - Method in class org.apache.flink.runtime.rest.handler.job.SubtasksTimesHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, AccessExecutionVertex) - Method in class org.apache.flink.runtime.rest.handler.job.AbstractSubtaskAttemptHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, AccessExecutionVertex) - Method in class org.apache.flink.runtime.rest.handler.job.AbstractSubtaskHandler
-
Called for each request after the corresponding
AccessExecutionVertexhas been retrieved from theAccessExecutionJobVertex. - handleRequest(HandlerRequest<EmptyRequestBody>, AccessExecutionVertex) - Method in class org.apache.flink.runtime.rest.handler.job.SubtaskCurrentAttemptDetailsHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, ResourceManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.dataset.ClusterDataSetListHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, ResourceManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerDetailsHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, ResourceManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerLogListHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, ResourceManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerProfilingListHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, ResourceManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagersHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, ResourceManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerThreadDumpHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, ExecutionGraphInfo) - Method in class org.apache.flink.runtime.rest.handler.job.AbstractAccessExecutionGraphHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, ExecutionGraphInfo) - Method in class org.apache.flink.runtime.rest.handler.job.AbstractExecutionGraphHandler
-
Called for each request after the corresponding
ExecutionGraphInfohas been retrieved from theExecutionGraphCache. - handleRequest(HandlerRequest<EmptyRequestBody>, ExecutionGraphInfo) - Method in class org.apache.flink.runtime.rest.handler.job.JobExceptionsHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.cluster.ClusterConfigHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.cluster.ClusterOverviewHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.cluster.DashboardConfigHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.cluster.JobManagerEnvironmentHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.cluster.JobManagerLogListHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.cluster.JobManagerProfilingListHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.cluster.JobManagerThreadDumpHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.cluster.ShutdownHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.AbstractExecutionGraphHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.AbstractCheckpointStatsHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointHandlers.CheckpointStatusHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.JobCancellationHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.JobExecutionResultHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.JobIdsHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.JobManagerJobConfigurationHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.JobManagerJobEnvironmentHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.JobResourceRequirementsHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.JobsOverviewHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.JobStatusHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.JobVertexBackPressureHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.AbstractAggregatingMetricsHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.AbstractMetricsHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingStatusHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingTriggerHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointStatusHandler
- handleRequest(HandlerRequest<EmptyRequestBody>, T) - Method in class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.StatusHandler
- handleRequest(HandlerRequest<ClientCoordinationRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.coordination.ClientCoordinationHandler
- handleRequest(HandlerRequest<JobResourceRequirementsBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.JobResourceRequirementsUpdateHandler
- handleRequest(HandlerRequest<JobSubmitRequestBody>, DispatcherGateway) - Method in class org.apache.flink.runtime.rest.handler.job.JobSubmitHandler
- handleRequest(HandlerRequest<JobClientHeartbeatRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.JobClientHeartbeatHandler
- handleRequest(HandlerRequest<R>, ResourceManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.resourcemanager.AbstractResourceManagerHandler
- handleRequest(HandlerRequest<R>, T) - Method in class org.apache.flink.runtime.rest.handler.AbstractRestHandler
-
This method is called for every incoming request and returns a
CompletableFuturecontaining a the response. - handleRequest(HandlerRequest<R>, T) - Method in class org.apache.flink.runtime.rest.handler.resourcemanager.AbstractResourceManagerHandler
- handleRequestSync(State, StateRequestType, IN) - Method in class org.apache.flink.runtime.asyncprocessing.AsyncExecutionController
- handleRequestSync(State, StateRequestType, IN) - Method in interface org.apache.flink.runtime.asyncprocessing.StateRequestHandler
-
Submit a
StateRequestto this StateRequestHandler, and wait for the response synchronously. - handleRequestSync(StateRequestType, IN) - Method in class org.apache.flink.runtime.state.v2.AbstractKeyedState
- HandlerRedirectUtils - Class in org.apache.flink.runtime.rest.handler.util
-
Utilities to extract a redirect address.
- HandlerRedirectUtils() - Constructor for class org.apache.flink.runtime.rest.handler.util.HandlerRedirectUtils
- HandlerRequest<R extends RequestBody> - Class in org.apache.flink.runtime.rest.handler
-
Simple container for the request to a handler, that contains the
RequestBodyand path/query parameters. - HandlerRequestException - Exception in org.apache.flink.runtime.rest.handler
-
Base class for all
HandlerRequestrelated exceptions. - HandlerRequestException(String) - Constructor for exception org.apache.flink.runtime.rest.handler.HandlerRequestException
- HandlerRequestException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rest.handler.HandlerRequestException
- HandlerRequestException(Throwable) - Constructor for exception org.apache.flink.runtime.rest.handler.HandlerRequestException
- HandlerRequestUtils - Class in org.apache.flink.runtime.rest.handler.util
-
Utils for getting query parameters from
HandlerRequest. - HandlerRequestUtils() - Constructor for class org.apache.flink.runtime.rest.handler.util.HandlerRequestUtils
- HandlerUtils - Class in org.apache.flink.runtime.rest.handler.util
-
Utilities for the REST handlers.
- HandlerUtils() - Constructor for class org.apache.flink.runtime.rest.handler.util.HandlerUtils
- handleSavepointCreation(CompletedCheckpoint, Throwable) - Method in interface org.apache.flink.runtime.scheduler.stopwithsavepoint.StopWithSavepointTerminationHandler
-
Handles the result of a
CompletableFutureholding aCompletedCheckpoint. - handleSavepointCreation(CompletedCheckpoint, Throwable) - Method in class org.apache.flink.runtime.scheduler.stopwithsavepoint.StopWithSavepointTerminationHandlerImpl
- handleSuccessfulResponse(int, ImmutableSet<ExecutionAttemptID>, T) - Method in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator
-
Handles the successfully returned tasks stats response by collecting the corresponding subtask samples.
- handleTaskFailure(Execution, Throwable) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.AdaptiveBatchScheduler
- handleTaskFailure(Execution, Throwable) - Method in class org.apache.flink.runtime.scheduler.DefaultScheduler
- handleTaskFailure(Execution, Throwable, BiConsumer<Execution, Throwable>) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DefaultSpeculativeExecutionHandler
- handleTaskFailure(Execution, Throwable, BiConsumer<Execution, Throwable>) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DummySpeculativeExecutionHandler
- handleTaskFailure(Execution, Throwable, BiConsumer<Execution, Throwable>) - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.SpeculativeExecutionHandler
-
Handles a task failure.
- Hardware - Class in org.apache.flink.runtime.util
-
Convenience class to extract hardware specifics of the computer executing the running JVM.
- HardwareDescription - Class in org.apache.flink.runtime.instance
-
A hardware description describes the resources available to a task manager.
- HardwareDescription(int, long, long, long) - Constructor for class org.apache.flink.runtime.instance.HardwareDescription
-
Constructs a new hardware description object.
- hasAllocatedSlot() - Method in class org.apache.flink.runtime.taskexecutor.SlotReport
- hasAllocatedSlots(JobID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Check whether the job has allocated (not active) slots.
- hasAllocatedSlots(JobID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- hasArray() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- hasBarrierReceived() - Method in class org.apache.flink.runtime.io.network.partition.consumer.ChannelStatePersister
- hasBeenJoined() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntry
- hasBroadcastVariable(String) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
- hasBroadcastVariable(String) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
- hasChannelError() - Method in interface org.apache.flink.runtime.io.network.NetworkClientHandler
-
Return whether there is channel error.
- hasCleanJobResultEntryAsync(JobID) - Method in class org.apache.flink.runtime.highavailability.AbstractThreadsafeJobResultStore
- hasCleanJobResultEntryAsync(JobID) - Method in interface org.apache.flink.runtime.highavailability.JobResultStore
-
Returns the future of whether the store contains a
cleanentry for the givenJobID. - hasCleanJobResultEntryInternal(JobID) - Method in class org.apache.flink.runtime.highavailability.AbstractThreadsafeJobResultStore
- hasCleanJobResultEntryInternal(JobID) - Method in class org.apache.flink.runtime.highavailability.FileSystemJobResultStore
- hasCleanJobResultEntryInternal(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedJobResultStore
- hasData() - Method in class org.apache.flink.runtime.operators.sort.LargeRecordHandler
- hasDataAllProduced() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
- hasDefaultSavepointLocation() - Method in interface org.apache.flink.runtime.state.CheckpointStorageCoordinatorView
-
Checks whether the storage has a default savepoint location configured.
- hasDefaultSavepointLocation() - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorageAccess
- hasDesiredResources() - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- hasDesiredResources() - Method in interface org.apache.flink.runtime.scheduler.adaptive.StateTransitionManager.Context
-
Returns
trueif the available resources meet the desired resources for the job; otherwisefalse. - hasDirtyJobResultEntryAsync(JobID) - Method in class org.apache.flink.runtime.highavailability.AbstractThreadsafeJobResultStore
- hasDirtyJobResultEntryAsync(JobID) - Method in interface org.apache.flink.runtime.highavailability.JobResultStore
-
Returns the future of whether the store contains a
dirtyentry for the givenJobID. - hasDirtyJobResultEntryInternal(JobID) - Method in class org.apache.flink.runtime.highavailability.AbstractThreadsafeJobResultStore
- hasDirtyJobResultEntryInternal(JobID) - Method in class org.apache.flink.runtime.highavailability.FileSystemJobResultStore
- hasDirtyJobResultEntryInternal(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedJobResultStore
- HaServicesJobPersistenceComponentFactory - Class in org.apache.flink.runtime.jobmanager
-
JobPersistenceComponentFactoryimplementation which creates aJobGraphStoreusing the providedHighAvailabilityServices. - HaServicesJobPersistenceComponentFactory(HighAvailabilityServices) - Constructor for class org.apache.flink.runtime.jobmanager.HaServicesJobPersistenceComponentFactory
- hasFineGrainedResource() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- hasFinishedTasks() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointPlanCalculatorContext
-
Detects whether there are already some tasks finished.
- hasFinishedTasks() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraphCheckpointPlanCalculatorContext
- hasFurtherInput() - Method in class org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
-
Checks, whether the input that is blocked by this iterator, has further elements available.
- hasFurtherInput() - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
-
Checks, whether the input that is blocked by this iterator, has further elements available.
- hash(int, int) - Static method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The level parameter is needed so that we can have different hash functions when we recursively apply the partitioning, so that the working set eventually fits into memory.
- hash(Tuple2<byte[], INPUT>) - Method in class org.apache.flink.streaming.api.operators.sortpartition.FixedLengthByteKeyAndValueComparator
- hash(Tuple2<byte[], INPUT>) - Method in class org.apache.flink.streaming.api.operators.sortpartition.VariableLengthByteKeyAndValueComparator
- HashBasedDataBuffer - Class in org.apache.flink.runtime.io.network.partition
-
* A
DataBufferimplementation which sorts all appended records only by subpartition index. - HashBasedDataBuffer(LinkedList<MemorySegment>, BufferRecycler, int, int, int, int[]) - Constructor for class org.apache.flink.runtime.io.network.partition.HashBasedDataBuffer
- HashBufferAccumulator - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage
-
The hash implementation of the
BufferAccumulator. - HashBufferAccumulator(int, int, TieredStorageMemoryManager, boolean) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.HashBufferAccumulator
- hashCode - Variable in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageBytesBasedDataIdentifier
- hashCode() - Method in class org.apache.flink.runtime.asyncprocessing.RecordContext
- hashCode() - Method in class org.apache.flink.runtime.blob.BlobKey
- hashCode() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
- hashCode() - Method in class org.apache.flink.runtime.checkpoint.channel.InputChannelInfo
- hashCode() - Method in class org.apache.flink.runtime.checkpoint.channel.ResultSubpartitionInfo
- hashCode() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetaData
- hashCode() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
- hashCode() - Method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
- hashCode() - Method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
- hashCode() - Method in class org.apache.flink.runtime.checkpoint.CheckpointType
- hashCode() - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager.SubtaskKey
- hashCode() - Method in class org.apache.flink.runtime.checkpoint.filemerging.LogicalFile
- hashCode() - Method in class org.apache.flink.runtime.checkpoint.FinishedOperatorSubtaskState
- hashCode() - Method in class org.apache.flink.runtime.checkpoint.FullyFinishedOperatorState
- hashCode() - Method in class org.apache.flink.runtime.checkpoint.InflightDataRescalingDescriptor
- hashCode() - Method in class org.apache.flink.runtime.checkpoint.InflightDataRescalingDescriptor.InflightDataGateOrPartitionRescalingDescriptor
- hashCode() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- hashCode() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
- hashCode() - Method in class org.apache.flink.runtime.checkpoint.RescaleMappings
- hashCode() - Method in class org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
- hashCode() - Method in class org.apache.flink.runtime.checkpoint.SavepointType
- hashCode() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- hashCode() - Method in class org.apache.flink.runtime.checkpoint.SubTaskInitializationMetrics
- hashCode() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
Deprecated.
- hashCode() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- hashCode() - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
- hashCode() - Method in class org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
- hashCode() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceID
- hashCode() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
- hashCode() - Method in class org.apache.flink.runtime.clusterframework.types.SlotID
- hashCode() - Method in class org.apache.flink.runtime.executiongraph.ExecutionAttemptID
- hashCode() - Method in class org.apache.flink.runtime.executiongraph.IndexRange
- hashCode() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
- hashCode() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
- hashCode() - Method in class org.apache.flink.runtime.instance.HardwareDescription
- hashCode() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
- hashCode() - Method in class org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
- hashCode() - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
- hashCode() - Method in class org.apache.flink.runtime.io.network.api.EndOfData
- hashCode() - Method in class org.apache.flink.runtime.io.network.api.EndOfPartitionEvent
- hashCode() - Method in class org.apache.flink.runtime.io.network.api.EndOfSegmentEvent
- hashCode() - Method in class org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
- hashCode() - Method in class org.apache.flink.runtime.io.network.api.EventAnnouncement
- hashCode() - Method in class org.apache.flink.runtime.io.network.api.RecoveryMetadata
- hashCode() - Method in class org.apache.flink.runtime.io.network.api.SubtaskConnectionDescriptor
- hashCode() - Method in class org.apache.flink.runtime.io.network.ConnectionID
- hashCode() - Method in class org.apache.flink.runtime.io.network.partition.consumer.EndOfChannelStateEvent
- hashCode() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGateID
- hashCode() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageBytesBasedDataIdentifier
- hashCode() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageInputChannelId
- hashCode() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStoragePartitionId
- hashCode() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageSubpartitionId
- hashCode() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyConnectionId
- hashCode() - Method in class org.apache.flink.runtime.io.network.partition.PrioritizedDeque
- hashCode() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionID
- hashCode() - Method in class org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionInfo
- hashCode() - Method in class org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
- hashCode() - Method in class org.apache.flink.runtime.jobgraph.JobResourceRequirements
- hashCode() - Method in class org.apache.flink.runtime.jobgraph.JobVertexResourceRequirements
- hashCode() - Method in class org.apache.flink.runtime.jobgraph.JobVertexResourceRequirements.Parallelism
- hashCode() - Method in class org.apache.flink.runtime.jobgraph.OperatorInstanceID
- hashCode() - Method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
- hashCode() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
- hashCode() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
- hashCode() - Method in exception org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
- hashCode() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunnerResult
- hashCode() - Method in class org.apache.flink.runtime.jobmaster.ResourceManagerAddress
- hashCode() - Method in class org.apache.flink.runtime.leaderelection.LeaderInformation
- hashCode() - Method in class org.apache.flink.runtime.messages.Acknowledge
- hashCode() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
- hashCode() - Method in class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
- hashCode() - Method in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
- hashCode() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
- hashCode() - Method in class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview
- hashCode() - Method in class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview.JobIdWithStatus
- hashCode() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
- hashCode() - Method in class org.apache.flink.runtime.messages.webmonitor.JobStatusInfo
- hashCode() - Method in class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
- hashCode() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
- hashCode() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobsOverview
- hashCode() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobsWithIDsOverview
- hashCode() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestStatusOverview
- hashCode() - Method in class org.apache.flink.runtime.persistence.IntegerResourceVersion
- hashCode() - Method in class org.apache.flink.runtime.persistence.StringResourceVersion
- hashCode() - Method in class org.apache.flink.runtime.query.KvStateInfo
- hashCode() - Method in class org.apache.flink.runtime.query.KvStateLocation
- hashCode() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceDeclaration
- hashCode() - Method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec
- hashCode() - Method in class org.apache.flink.runtime.rest.handler.async.OperationKey
- hashCode() - Method in class org.apache.flink.runtime.rest.handler.job.AsynchronousJobOperationKey
- hashCode() - Method in class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
- hashCode() - Method in class org.apache.flink.runtime.rest.HttpHeader
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.AggregatedTaskDetailsInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ExternalizedCheckpointInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.CompletedCheckpointStatistics
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.FailedCheckpointStatistics
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.PendingCheckpointStatistics
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.StatsSummaryDto
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.ConfigurationInfoEntry
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration.Features
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.EnvironmentInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.job.JobResourceRequirementsBody
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody.DistributedCacheFile
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitResponseBody
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.job.UserAccumulator
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.JobConfigInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.ExceptionInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.JobExceptionHistory
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.RootExceptionInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.JobPlanInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.LogInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.LogListInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.LogUrlResponse
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.ProfilingInfoList
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.ResourceProfileInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.SlotInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo.GarbageCollectorInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.ThreadDumpInfo.ThreadInfo
- hashCode() - Method in class org.apache.flink.runtime.scheduler.strategy.ExecutionVertexID
- hashCode() - Method in class org.apache.flink.runtime.slots.ResourceRequirement
- hashCode() - Method in class org.apache.flink.runtime.slots.ResourceRequirements
- hashCode() - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinator.WatermarkElement
- hashCode() - Method in class org.apache.flink.runtime.source.event.IsProcessingBacklogEvent
- hashCode() - Method in class org.apache.flink.runtime.source.event.ReportedWatermarkEvent
- hashCode() - Method in class org.apache.flink.runtime.source.event.RequestSplitEvent
- hashCode() - Method in class org.apache.flink.runtime.source.event.WatermarkAlignmentEvent
- hashCode() - Method in class org.apache.flink.runtime.state.AbstractChannelStateHandle
- hashCode() - Method in class org.apache.flink.runtime.state.AbstractIncrementalStateHandle
- hashCode() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
- hashCode() - Method in class org.apache.flink.runtime.state.ChainedStateHandle
- hashCode() - Method in class org.apache.flink.runtime.state.changelog.SequenceNumber.GenericSequenceNumber
- hashCode() - Method in class org.apache.flink.runtime.state.CheckpointStorageLocationReference
- hashCode() - Method in class org.apache.flink.runtime.state.DirectoryStateHandle
- hashCode() - Method in class org.apache.flink.runtime.state.filemerging.DirectoryStreamStateHandle
- hashCode() - Method in class org.apache.flink.runtime.state.filemerging.FileMergingOperatorStreamStateHandle
- hashCode() - Method in class org.apache.flink.runtime.state.filemerging.SegmentFileStateHandle
- hashCode() - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
- hashCode() - Method in class org.apache.flink.runtime.state.filesystem.RelativeFileStateHandle
- hashCode() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap.StateMapEntry
- hashCode() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle.HandleAndLocalPath
- hashCode() - Method in class org.apache.flink.runtime.state.KeyGroupRange
- hashCode() - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
- hashCode() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
- hashCode() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
- hashCode() - Method in class org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
- hashCode() - Method in class org.apache.flink.runtime.state.OperatorStreamStateHandle
- hashCode() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
- hashCode() - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
- hashCode() - Method in class org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
- hashCode() - Method in class org.apache.flink.runtime.state.RegisteredStateMetaInfoBase.Key
- hashCode() - Method in class org.apache.flink.runtime.state.SharedStateRegistryImpl.EmptyDiscardStateObjectForRegister
- hashCode() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
- hashCode() - Method in class org.apache.flink.runtime.state.storage.FileSystemCheckpointStorage
- hashCode() - Method in class org.apache.flink.runtime.state.v2.RegisteredKeyValueStateBackendMetaInfo
- hashCode() - Method in class org.apache.flink.runtime.state.v2.StateDescriptor
- hashCode() - Method in class org.apache.flink.runtime.state.VoidNamespace
- hashCode() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
- hashCode() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotAllocationSnapshot
- hashCode() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotOffer
- hashCode() - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
- hashCode() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
- hashCode() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- hashCode() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
- hashCode() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
- hashCode() - Method in class org.apache.flink.runtime.util.config.memory.CommonProcessMemorySpec
- hashCode() - Method in class org.apache.flink.runtime.util.config.memory.jobmanager.JobManagerFlinkMemory
- hashCode() - Method in class org.apache.flink.runtime.util.config.memory.JvmMetaspaceAndOverhead
- hashCode() - Method in class org.apache.flink.runtime.util.config.memory.taskmanager.TaskExecutorFlinkMemory
- hashCode() - Method in class org.apache.flink.runtime.util.OperatorSubtaskDescriptionText
- hashCode() - Method in class org.apache.flink.runtime.util.ResourceCounter
- hashCode() - Method in class org.apache.flink.runtime.webmonitor.history.ArchivedJson
- hashCode() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
- hashCode() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableSummary
- hashCode() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableWithLineage
- hashCode() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
- hashCode() - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
- hashCode() - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
- hashCode() - Method in class org.apache.flink.streaming.api.graph.StreamConfig.SourceInputConfig
- hashCode() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
- hashCode() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- hashCode() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
- hashCode() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
- hashCode() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
- hashCode() - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
- hashCode() - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
- hashCode() - Method in class org.apache.flink.streaming.api.watermark.InternalWatermark
- hashCode() - Method in class org.apache.flink.streaming.api.watermark.Watermark
- hashCode() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow
- hashCode() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
- hashCode() - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
- hashCode() - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
- hashCode() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
- hashCode() - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
- hashCode() - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
- hashCode() - Method in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
- hashCode() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
- hashCode() - Method in class org.apache.flink.streaming.runtime.streamrecord.RecordAttributes
- hashCode() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
- hashCode() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
- hashCode() - Method in class org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
- HASHED_PARTIAL_REDUCE - org.apache.flink.runtime.operators.DriverStrategy
- hashJoin - Variable in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
- hashJoin - Variable in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
- hashJoin - Variable in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
- hashJoin - Variable in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
- HashJoinIteratorBase - Class in org.apache.flink.runtime.operators.hash
-
Common methods for all Hash Join Iterators.
- HashJoinIteratorBase() - Constructor for class org.apache.flink.runtime.operators.hash.HashJoinIteratorBase
- HASHMAP_STATE_BACKEND_NAME - Static variable in class org.apache.flink.runtime.state.StateBackendLoader
-
The shortcut configuration name of the HashMap state backend.
- HashMapStateBackend - Class in org.apache.flink.runtime.state.hashmap
-
This state backend holds the working state in the memory (JVM heap) of the TaskManagers and checkpoints based on the configured
CheckpointStorage. - HashMapStateBackend() - Constructor for class org.apache.flink.runtime.state.hashmap.HashMapStateBackend
-
Creates a new state backend.
- HashMapStateBackendFactory - Class in org.apache.flink.runtime.state.hashmap
-
A factory that creates an
HashMapStateBackendfrom a configuration. - HashMapStateBackendFactory() - Constructor for class org.apache.flink.runtime.state.hashmap.HashMapStateBackendFactory
- HashPartition<BT,PT> - Class in org.apache.flink.runtime.operators.hash
- HashPartition.BuildSideBuffer - Class in org.apache.flink.runtime.operators.hash
- HashPartitionIterator<BT,PT> - Class in org.apache.flink.runtime.iterative.io
-
Iteratorover the build side entries of aHashPartition. - HashPartitionIterator(Iterator<HashPartition<BT, PT>>, TypeSerializer<BT>) - Constructor for class org.apache.flink.runtime.iterative.io.HashPartitionIterator
- HashSubpartitionBufferAccumulator - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage
-
HashSubpartitionBufferAccumulatoraccumulates the records in a subpartition. - HashSubpartitionBufferAccumulator(TieredStorageSubpartitionId, int, HashSubpartitionBufferAccumulatorContext, boolean) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.HashSubpartitionBufferAccumulator
- HashSubpartitionBufferAccumulatorContext - Interface in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage
-
This interface is used by
HashSubpartitionBufferAccumulatorto operateHashBufferAccumulator. - HashTableProber(TypeComparator<PT>, TypePairComparator<PT, T>) - Constructor for class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
- hasJobEvents() - Method in class org.apache.flink.runtime.jobmaster.event.JobEventManager
-
Returns whether the store is empty.
- hasJobResultEntryAsync(JobID) - Method in class org.apache.flink.runtime.highavailability.AbstractThreadsafeJobResultStore
- hasJobResultEntryAsync(JobID) - Method in interface org.apache.flink.runtime.highavailability.JobResultStore
-
Returns the future of whether the store already contains an entry for a job.
- hasKeyContext() - Method in interface org.apache.flink.streaming.api.operators.KeyContextHandler
-
Whether the
Inputhas "KeyContext". - hasKeyContext1() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- hasKeyContext1() - Method in interface org.apache.flink.streaming.api.operators.KeyContextHandler
-
Whether the first input of
StreamOperatorhas "KeyContext". - hasKeyContext2() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- hasKeyContext2() - Method in interface org.apache.flink.streaming.api.operators.KeyContextHandler
-
Whether the second input of
StreamOperatorhas "KeyContext". - hasLeaderInformation(String) - Method in class org.apache.flink.runtime.leaderelection.LeaderInformationRegister
-
Checks whether the register holds non-empty
LeaderInformationfor the passedcomponentId. - hasLeadership() - Method in interface org.apache.flink.runtime.leaderelection.LeaderElectionDriver
-
Returns whether the driver has currently leadership.
- hasLeadership() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionDriver
- hasLeadership(String, UUID) - Method in class org.apache.flink.runtime.leaderelection.DefaultLeaderElectionService
- hasLeadership(UUID) - Method in interface org.apache.flink.runtime.leaderelection.LeaderElection
-
Returns
trueif the service'sLeaderContenderhas the leadership under the given leader session ID acquired. - hasLeadership(UUID) - Method in class org.apache.flink.runtime.leaderelection.StandaloneLeaderElection
- hasMail() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
- hasMail() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
Returns
trueif the mailbox contains mail. - hasMail() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
- hasMail() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- hasMemoryAddress() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- hasMetaDataFollowsFlag(byte[]) - Static method in class org.apache.flink.runtime.state.FullSnapshotUtil
- hasNext() - Method in class org.apache.flink.runtime.asyncprocessing.AbstractStateIterator
-
Return whether this iterator has more elements to load besides current cache.
- hasNext() - Method in class org.apache.flink.runtime.io.disk.FileBasedBufferIterator
- hasNext() - Method in interface org.apache.flink.runtime.io.network.api.reader.Reader
- hasNext() - Method in class org.apache.flink.runtime.io.network.api.reader.RecordReader
- hasNext() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable.SimpleIterator
- hasNext() - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
- hasNext() - Method in class org.apache.flink.runtime.operators.resettable.ReusingBlockResettableIterator
- hasNext() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
- hasNext() - Method in class org.apache.flink.runtime.operators.util.metrics.CountingIterator
- hasNext() - Method in interface org.apache.flink.runtime.state.internal.InternalKvState.StateIncrementalVisitor
-
Whether the visitor potentially has some next entries to return from
nextEntries(). - hasNext() - Method in interface org.apache.flink.runtime.state.restore.ThrowingIterator
-
Returns
trueif the iteration has more elements. - hasNext() - Method in class org.apache.flink.runtime.state.v2.SyncIteratorWrapper
- hasNext() - Method in class org.apache.flink.runtime.util.EmptyIterator
-
Always returns false, since this iterator is empty.
- hasNext() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator.ValuesIterator
- hasNext() - Method in class org.apache.flink.runtime.util.NonReusingMutableToRegularIteratorWrapper
- hasNext() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator.ValuesIterator
- hasNext() - Method in class org.apache.flink.runtime.util.ReusingMutableToRegularIteratorWrapper
- hasNext() - Method in class org.apache.flink.runtime.util.SingleElementIterator
- hasNext() - Method in class org.apache.flink.streaming.api.operators.collect.CollectResultIterator
- hasNext() - Method in class org.apache.flink.streaming.api.operators.MapPartitionIterator
- hasNoConnectedInputs() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- hasNoLeaderInformation() - Method in class org.apache.flink.runtime.leaderelection.LeaderInformationRegister
-
Checks that no non-empty
LeaderInformationis stored. - hasOperatorCoordinatorAndShuffleMasterSnapshots() - Method in class org.apache.flink.runtime.jobmaster.event.ExecutionVertexFinishedEvent
- hasPriority() - Method in enum org.apache.flink.runtime.io.network.buffer.Buffer.DataType
- hasPriority() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
- hasPriority() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel.BufferAndAvailability
- hasReachedEndOfFile() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileReader
- hasReachedEndOfFile() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileSegmentReader
- hasReachedEndOfFile() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileReader
- hasReachedEndOfFile() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileSegmentReader
- hasReachedEndOfFile() - Method in class org.apache.flink.runtime.io.disk.iomanager.SynchronousBufferFileReader
- hasReachedEndOfSuperstep() - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
- hasReachedEndOfSuperstep() - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
- hasReceivedEndOfData() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- hasReceivedEndOfData() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
- hasReceivedEndOfData() - Method in interface org.apache.flink.runtime.io.PullingAsyncDataInput
-
Tells if we consumed all available data.
- hasReceivedEndOfData() - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
- hasReceivedEndOfData() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
- hasRemaining() - Method in interface org.apache.flink.runtime.io.network.partition.DataBuffer
-
Returns true if not all data appended to this
DataBufferis consumed. - hasRemaining() - Method in class org.apache.flink.runtime.io.network.partition.HashBasedDataBuffer
- hasRemaining() - Method in class org.apache.flink.runtime.io.network.partition.SortBuffer
- hasState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
- hasState() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
Returns true if this contains at least one
StateObject. - hasState() - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
-
Returns true if at least one
OperatorSubtaskStatein subtaskStatesByOperatorID has state. - hasStubWrapper() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- hasSubtaskStates() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- hasSufficientResources() - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- hasSufficientResources() - Method in interface org.apache.flink.runtime.scheduler.adaptive.StateTransitionManager.Context
-
Returns
trueif the available resources are sufficient enough for a state transition; otherwisefalse. - hasTimestamp() - Method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
-
Checks whether this record has a timestamp.
- hasTimestamp() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Checks whether this record has a timestamp.
- hasTokens() - Method in class org.apache.flink.runtime.security.token.DelegationTokenContainer
- hasTrackedPartitions(K) - Method in class org.apache.flink.runtime.taskexecutor.partition.PartitionTable
-
Returns whether any partitions are being tracked for the given key.
- hasUsercodeJarFiles() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Checks whether the JobGraph has user code JAR files attached.
- hasUserKerberosAuthMethod(UserGroupInformation) - Static method in class org.apache.flink.runtime.hadoop.HadoopUserUtils
- hasValidDirtyJobResultStoreEntryExtension(String) - Static method in class org.apache.flink.runtime.highavailability.FileSystemJobResultStore
- hasValidJobResultStoreEntryExtension(String) - Static method in class org.apache.flink.runtime.highavailability.FileSystemJobResultStore
- HBaseDelegationTokenProvider - Class in org.apache.flink.runtime.security.token.hadoop
-
Delegation token provider implementation for HBase.
- HBaseDelegationTokenProvider() - Constructor for class org.apache.flink.runtime.security.token.hadoop.HBaseDelegationTokenProvider
- HBaseDelegationTokenReceiver - Class in org.apache.flink.runtime.security.token.hadoop
-
Delegation token receiver implementation for HBase.
- HBaseDelegationTokenReceiver() - Constructor for class org.apache.flink.runtime.security.token.hadoop.HBaseDelegationTokenReceiver
- HEAD - org.apache.flink.streaming.api.operators.ChainingStrategy
-
The operator will not be chained to the predecessor, but successors may chain to this operator.
- HEAD_BLOCK_LENGTH_OFFSET - Static variable in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
The offset to the header field indicating the number of bytes in the block
- HEAD_WITH_SOURCES - org.apache.flink.streaming.api.operators.ChainingStrategy
-
This operator will run at the head of a chain (similar as in
ChainingStrategy.HEAD, but it will additionally try to chain source inputs if possible. - HEADER_FLAGS_OFFSET - Static variable in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
The offset to the flags in the header;
- HEADER_LENGTH - Static variable in class org.apache.flink.runtime.io.compression.CompressorUtils
-
We put two integers before each compressed block, the first integer represents the compressed length of the block, and the second one represents the original length of the block.
- HEADER_LENGTH - Static variable in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
The length of the header put into the blocks.
- HEADER_LENGTH - Static variable in class org.apache.flink.runtime.io.network.partition.BufferReaderWriterUtil
- HEADER_MAGIC_NUMBER - Static variable in class org.apache.flink.runtime.checkpoint.Checkpoints
-
Magic number at the beginning of every checkpoint metadata file, for sanity checks.
- HEADER_MAGIC_NUMBER - Static variable in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
The magic number that identifies blocks as blocks from a ChannelWriterOutputView.
- headerLength - Variable in class org.apache.flink.runtime.memory.AbstractPagedInputView
- headerLength - Variable in class org.apache.flink.runtime.memory.AbstractPagedOutputView
- HeaderlessChannelReaderInputView - Class in org.apache.flink.runtime.io.disk.iomanager
-
A
DataInputViewthat is backed by aBlockChannelReader, making it effectively a data input stream. - HeaderlessChannelReaderInputView(BlockChannelReader<MemorySegment>, List<MemorySegment>, int, int, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.HeaderlessChannelReaderInputView
-
Creates a new channel reader that reads from the given channel, expecting a specified number of blocks in the channel, and returns only a specified number of bytes from the last block.
- HeaderlessChannelReaderInputView(BlockChannelReader<MemorySegment>, List<MemorySegment>, int, int, boolean, long) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.HeaderlessChannelReaderInputView
- HeapBroadcastState<K,V> - Class in org.apache.flink.runtime.state
-
A
Broadcast Statebacked a heap-basedMap. - heapBuffer() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
- heapBuffer(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
- heapBuffer(int, int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
- HeapKeyedStateBackend<K> - Class in org.apache.flink.runtime.state.heap
-
A
AbstractKeyedStateBackendthat keeps state on the Java Heap and will serialize state to streams provided by aCheckpointStreamFactoryupon checkpointing. - HeapKeyedStateBackend(TaskKvStateRegistry, TypeSerializer<K>, ClassLoader, ExecutionConfig, TtlTimeProvider, LatencyTrackingStateConfig, CloseableRegistry, StreamCompressionDecorator, Map<String, StateTable<K, ?, ?>>, Map<String, HeapPriorityQueueSnapshotRestoreWrapper<?>>, LocalRecoveryConfig, HeapPriorityQueueSetFactory, HeapSnapshotStrategy<K>, SnapshotExecutionType, StateTableFactory<K>, InternalKeyContext<K>) - Constructor for class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
- HeapKeyedStateBackendBuilder<K> - Class in org.apache.flink.runtime.state.heap
-
Builder class for
HeapKeyedStateBackendwhich handles all necessary initializations and clean ups. - HeapKeyedStateBackendBuilder(TaskKvStateRegistry, TypeSerializer<K>, ClassLoader, int, KeyGroupRange, ExecutionConfig, TtlTimeProvider, LatencyTrackingStateConfig, Collection<KeyedStateHandle>, StreamCompressionDecorator, LocalRecoveryConfig, HeapPriorityQueueSetFactory, boolean, CloseableRegistry) - Constructor for class org.apache.flink.runtime.state.heap.HeapKeyedStateBackendBuilder
- HeapKeyValueStateIterator - Class in org.apache.flink.runtime.state.heap
-
A
KeyValueStateIteratorover Heap backend snapshot resources. - HeapKeyValueStateIterator(KeyGroupRange, TypeSerializer<?>, int, Map<StateUID, Integer>, Map<StateUID, StateSnapshot>) - Constructor for class org.apache.flink.runtime.state.heap.HeapKeyValueStateIterator
- HeapPriorityQueue<T extends HeapPriorityQueueElement> - Class in org.apache.flink.runtime.state.heap
-
Basic heap-based priority queue for
HeapPriorityQueueElementobjects. - HeapPriorityQueue<T extends org.apache.flink.streaming.runtime.watermarkstatus.HeapPriorityQueue.HeapPriorityQueueElement> - Class in org.apache.flink.streaming.runtime.watermarkstatus
-
This class has similar functions with
HeapPriorityQueue. - HeapPriorityQueue(PriorityComparator<T>, int) - Constructor for class org.apache.flink.runtime.state.heap.HeapPriorityQueue
-
Creates an empty
HeapPriorityQueuewith the requested initial capacity. - HeapPriorityQueue(HeapPriorityQueue.PriorityComparator<T>, int) - Constructor for class org.apache.flink.streaming.runtime.watermarkstatus.HeapPriorityQueue
-
Creates an empty
HeapPriorityQueuewith the requested initial capacity. - HeapPriorityQueueElement - Interface in org.apache.flink.runtime.state.heap
-
Interface for objects that can be managed by a
HeapPriorityQueue. - HeapPriorityQueueSet<T extends HeapPriorityQueueElement> - Class in org.apache.flink.runtime.state.heap
-
A heap-based priority queue with set semantics, based on
HeapPriorityQueue. - HeapPriorityQueueSet(PriorityComparator<T>, KeyExtractorFunction<T>, int, KeyGroupRange, int) - Constructor for class org.apache.flink.runtime.state.heap.HeapPriorityQueueSet
-
Creates an empty
HeapPriorityQueueSetwith the requested initial capacity. - HeapPriorityQueueSetFactory - Class in org.apache.flink.runtime.state.heap
-
Factory for
HeapPriorityQueueSet. - HeapPriorityQueueSetFactory(KeyGroupRange, int, int) - Constructor for class org.apache.flink.runtime.state.heap.HeapPriorityQueueSetFactory
- HeapPriorityQueuesManager - Class in org.apache.flink.runtime.state
-
Manages creating heap priority queues along with their counterpart meta info.
- HeapPriorityQueuesManager(Map<String, HeapPriorityQueueSnapshotRestoreWrapper<?>>, HeapPriorityQueueSetFactory, KeyGroupRange, int) - Constructor for class org.apache.flink.runtime.state.HeapPriorityQueuesManager
- HeapPriorityQueueSnapshotRestoreWrapper<T extends HeapPriorityQueueElement> - Class in org.apache.flink.runtime.state.heap
-
This wrapper combines a HeapPriorityQueue with backend meta data.
- HeapPriorityQueueSnapshotRestoreWrapper(HeapPriorityQueueSet<T>, RegisteredPriorityQueueStateBackendMetaInfo<T>, KeyExtractorFunction<T>, KeyGroupRange, int) - Constructor for class org.apache.flink.runtime.state.heap.HeapPriorityQueueSnapshotRestoreWrapper
- HeapPriorityQueueStateSnapshot<T> - Class in org.apache.flink.runtime.state.heap
-
This class represents the snapshot of an
HeapPriorityQueueSet. - HeapRestoreOperation<K> - Class in org.apache.flink.runtime.state.heap
-
Implementation of heap restore operation.
- HeapSavepointRestoreOperation<K> - Class in org.apache.flink.runtime.state.heap
-
Implementation of heap savepoint restore operation.
- HeapSort - Class in org.apache.flink.runtime.operators.sort
- HeapSort() - Constructor for class org.apache.flink.runtime.operators.sort.HeapSort
- heartbeatFromJobManager(ResourceID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- heartbeatFromJobManager(ResourceID) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Sends the heartbeat to resource manager from job manager.
- heartbeatFromJobManager(ResourceID, AllocatedSlotReport) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- heartbeatFromJobManager(ResourceID, AllocatedSlotReport) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Heartbeat request from the job manager.
- heartbeatFromJobManager(ResourceID, AllocatedSlotReport) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- heartbeatFromResourceManager(ResourceID) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- heartbeatFromResourceManager(ResourceID) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Sends heartbeat request from the resource manager.
- heartbeatFromResourceManager(ResourceID) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- heartbeatFromResourceManager(ResourceID) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Heartbeat request from the resource manager.
- heartbeatFromResourceManager(ResourceID) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- heartbeatFromTaskManager(ResourceID, TaskExecutorHeartbeatPayload) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- heartbeatFromTaskManager(ResourceID, TaskExecutorHeartbeatPayload) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Sends the heartbeat to resource manager from task manager.
- heartbeatFromTaskManager(ResourceID, TaskExecutorToJobManagerHeartbeatPayload) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- heartbeatFromTaskManager(ResourceID, TaskExecutorToJobManagerHeartbeatPayload) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Sends the heartbeat to job manager from task manager.
- HeartbeatListener<I,O> - Interface in org.apache.flink.runtime.heartbeat
-
Interface for the interaction with the
HeartbeatManager. - HeartbeatManager<I,O> - Interface in org.apache.flink.runtime.heartbeat
-
A heartbeat manager has to be able to start/stop monitoring a
HeartbeatTarget, and report heartbeat timeouts for this target. - HeartbeatMonitor<O> - Interface in org.apache.flink.runtime.heartbeat
-
Heartbeat monitor which manages the heartbeat state of the associated heartbeat target.
- HeartbeatMonitor.Factory<O> - Interface in org.apache.flink.runtime.heartbeat
-
This factory provides an indirection way to create
HeartbeatMonitor. - HeartbeatReceiver<I> - Class in org.apache.flink.runtime.heartbeat
-
The receiver implementation of
HeartbeatTarget, which mutes theHeartbeatTarget#requestHeartbeat(ResourceID, I). - HeartbeatReceiver() - Constructor for class org.apache.flink.runtime.heartbeat.HeartbeatReceiver
- HeartbeatSender<I> - Class in org.apache.flink.runtime.heartbeat
-
The sender implementation of
HeartbeatTarget, which mutes theHeartbeatTarget#receiveHeartbeat(ResourceID, I). - HeartbeatSender() - Constructor for class org.apache.flink.runtime.heartbeat.HeartbeatSender
- HeartbeatServices - Interface in org.apache.flink.runtime.heartbeat
-
HeartbeatServices gives access to all services needed for heartbeating.
- HeartbeatServicesImpl - Class in org.apache.flink.runtime.heartbeat
-
A default
HeartbeatServicesimplementation. - HeartbeatServicesImpl(long, long) - Constructor for class org.apache.flink.runtime.heartbeat.HeartbeatServicesImpl
- HeartbeatServicesImpl(long, long, int) - Constructor for class org.apache.flink.runtime.heartbeat.HeartbeatServicesImpl
- HeartbeatTarget<I> - Interface in org.apache.flink.runtime.heartbeat
-
Interface for components which can be sent heartbeats and from which one can request a heartbeat response.
- HIGH - org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureLevel
- HighAvailabilityMode - Enum in org.apache.flink.runtime.jobmanager
-
High availability mode for Flink's cluster execution.
- HighAvailabilityServices - Interface in org.apache.flink.runtime.highavailability
-
The HighAvailabilityServices give access to all services needed for a highly-available setup.
- HighAvailabilityServicesFactory - Interface in org.apache.flink.runtime.highavailability
-
Factory interface for
HighAvailabilityServices. - HighAvailabilityServicesUtils - Class in org.apache.flink.runtime.highavailability
-
Utils class to instantiate
HighAvailabilityServicesimplementations. - HighAvailabilityServicesUtils() - Constructor for class org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
- histogram(String, H) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
- histogram(String, H) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
- HistogramDump(QueryScopeInfo, String, long, long, double, double, double, double, double, double, double, double, double) - Constructor for class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
- HistoryServerArchivist - Interface in org.apache.flink.runtime.dispatcher
-
Writer for an
ExecutionGraphInfo. - HistoryServerUtils - Enum in org.apache.flink.runtime.webmonitor.history
-
Utility class for the HistoryServer.
- HIT_COUNT - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- hitCounter(Counter) - Method in class org.apache.flink.runtime.metrics.groups.InternalCacheMetricGroup
- HOST_LOCAL - org.apache.flink.runtime.jobmanager.scheduler.Locality
-
The task was scheduled onto the same host as requested
- hostname() - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
- hostname() - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
- hostName() - Method in class org.apache.flink.runtime.source.event.RequestSplitEvent
- howToHandleFailure(Throwable, CompletableFuture<Map<String, String>>) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- HTTP_ATTRIBUTE_REQUEST - Static variable in class org.apache.flink.runtime.rest.FileUploadHandler
- HTTP_DATE_FORMAT - Static variable in class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
-
Date format for HTTP.
- HttpHeader - Class in org.apache.flink.runtime.rest
-
Represents an HTTP header with a name and a value.
- HttpHeader(String, String) - Constructor for class org.apache.flink.runtime.rest.HttpHeader
-
Constructs an
HttpHeaderobject with the specified name and value. - HttpMethodWrapper - Enum in org.apache.flink.runtime.rest
-
This class wraps netty's
HttpMethods into an enum, allowing us to use them in switches. - HYBRID_FULL - org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
Hybrid partitions with a bounded (local) buffer pool to support downstream task to simultaneous reading and writing shuffle data.
- HYBRID_FULL - org.apache.flink.streaming.api.transformations.StreamExchangeMode
-
The consumer can start consuming data anytime as long as the producer has started producing.
- HYBRID_SELECTIVE - org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
HYBRID_SELECTIVE partitions are similar to
ResultPartitionType.HYBRID_FULLpartitions, but it is not re-consumable. - HYBRID_SELECTIVE - org.apache.flink.streaming.api.transformations.StreamExchangeMode
-
The consumer can start consuming data anytime as long as the producer has started producing.
- HYBRIDHASH_BUILD_FIRST - org.apache.flink.runtime.operators.DriverStrategy
- HYBRIDHASH_BUILD_FIRST_CACHED - org.apache.flink.runtime.operators.DriverStrategy
- HYBRIDHASH_BUILD_SECOND - org.apache.flink.runtime.operators.DriverStrategy
- HYBRIDHASH_BUILD_SECOND_CACHED - org.apache.flink.runtime.operators.DriverStrategy
I
- id - Variable in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
-
The ID of the underlying channel.
- ID - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
- ID(File, int, Random) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
- IDENTIFIER - Static variable in class org.apache.flink.runtime.state.changelog.inmemory.InMemoryStateChangelogStorageFactory
- identity(int, int) - Static method in class org.apache.flink.runtime.checkpoint.RescaleMappings
- IDENTITY - org.apache.flink.runtime.checkpoint.InflightDataRescalingDescriptor.InflightDataGateOrPartitionRescalingDescriptor.MappingType
- IdentityStreamOperator() - Constructor for class org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator.IdentityStreamOperator
- IDLE - Static variable in class org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
- IDLE_STATUS - Static variable in class org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
- idlingStarted() - Method in class org.apache.flink.runtime.metrics.groups.InternalSourceReaderMetricGroup
- IGNORE - org.apache.flink.runtime.rest.handler.RestHandlerException.LoggingBehavior
- IGNORED - org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager.RegistrationResult
- IllegalExecutionStateException - Exception in org.apache.flink.runtime.executiongraph
-
A special
IllegalStateExceptionindicating a mismatch in the expected and actualExecutionStateof anExecution. - IllegalExecutionStateException(ExecutionState, ExecutionState) - Constructor for exception org.apache.flink.runtime.executiongraph.IllegalExecutionStateException
-
Creates a new IllegalExecutionStateException with the error message indicating the expected and actual state.
- IllegalExecutionStateException(Execution, ExecutionState, ExecutionState) - Constructor for exception org.apache.flink.runtime.executiongraph.IllegalExecutionStateException
-
Creates a new IllegalExecutionStateException with the error message indicating the expected and actual state.
- IMMEDIATE - Static variable in interface org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
- immutableEntries() - Method in class org.apache.flink.runtime.state.HeapBroadcastState
- IN_PROGRESS - org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
-
Checkpoint that is still in progress.
- IN_PROGRESS - org.apache.flink.runtime.rest.handler.async.OperationResultStatus
- IN_PROGRESS - org.apache.flink.runtime.rest.messages.queue.QueueStatus.Id
- InboundChannelHandlerFactory - Interface in org.apache.flink.runtime.io.network.netty
-
Custom netty inbound handler factory in order to make custom changes on netty inbound data.
- inc(int, long) - Method in class org.apache.flink.runtime.io.network.metrics.ResultPartitionBytesCounter
- incAll(long) - Method in class org.apache.flink.runtime.io.network.metrics.ResultPartitionBytesCounter
- includeSerializedAccumulatorsParameter - Variable in class org.apache.flink.runtime.rest.messages.JobAccumulatorsMessageParameters
- incomingDataSize(long) - Method in class org.apache.flink.runtime.throughput.ThroughputCalculator
- IncompleteFuturesTracker - Class in org.apache.flink.runtime.operators.coordination.util
-
This tracker remembers CompletableFutures as long as they are incomplete and allows us to fail them later.
- IncompleteFuturesTracker() - Constructor for class org.apache.flink.runtime.operators.coordination.util.IncompleteFuturesTracker
- increaseBackoff() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Increases the current backoff and returns whether the operation was successful.
- increaseBackoff() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
The remote task manager creates partition request listener and returns
PartitionNotFoundExceptionuntil the listener is timeout, so the backoff should add the timeout milliseconds if it exists. - increaseResourceRequirementsBy(ResourceCounter) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPool
-
Increases the resource requirements by increment.
- increaseResourceRequirementsBy(ResourceCounter) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultDeclarativeSlotPool
- IncrementalKeyedStateHandle - Interface in org.apache.flink.runtime.state
-
Common interface to all incremental
KeyedStateHandle. - IncrementalKeyedStateHandle.HandleAndLocalPath - Class in org.apache.flink.runtime.state
-
A Holder of StreamStateHandle and the corresponding localPath.
- IncrementalLocalKeyedStateHandle - Class in org.apache.flink.runtime.state
-
State handle for local copies of
IncrementalRemoteKeyedStateHandle. - IncrementalLocalKeyedStateHandle(UUID, long, DirectoryStateHandle, KeyGroupRange, StreamStateHandle, List<IncrementalKeyedStateHandle.HandleAndLocalPath>) - Constructor for class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
- IncrementalRemoteKeyedStateHandle - Class in org.apache.flink.runtime.state
-
The handle to states of an incremental snapshot.
- IncrementalRemoteKeyedStateHandle(UUID, KeyGroupRange, long, List<IncrementalKeyedStateHandle.HandleAndLocalPath>, List<IncrementalKeyedStateHandle.HandleAndLocalPath>, StreamStateHandle) - Constructor for class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
- IncrementalRemoteKeyedStateHandle(UUID, KeyGroupRange, long, List<IncrementalKeyedStateHandle.HandleAndLocalPath>, List<IncrementalKeyedStateHandle.HandleAndLocalPath>, StreamStateHandle, long) - Constructor for class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
- IncrementalRemoteKeyedStateHandle(UUID, KeyGroupRange, long, List<IncrementalKeyedStateHandle.HandleAndLocalPath>, List<IncrementalKeyedStateHandle.HandleAndLocalPath>, StreamStateHandle, long, StateHandleID) - Constructor for class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
- incrementIterationCounter() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
- incrementRestarts() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- incrementRestarts() - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- INDEX_ENTRY_SIZE - Static variable in class org.apache.flink.runtime.io.network.partition.PartitionedFile
-
Size of each index entry in the index file: 8 bytes for file offset and 8 bytes for data size in bytes.
- INDEX_ENTRY_SIZE - Static variable in class org.apache.flink.runtime.io.network.partition.SortBuffer
-
Size of an index entry: 4 bytes for record length, 4 bytes for data type and 8 bytes for pointer to next entry.
- INDEX_FILE_SUFFIX - Static variable in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.ProducerMergedPartitionFile
- INDEX_FILE_SUFFIX - Static variable in class org.apache.flink.runtime.io.network.partition.PartitionedFile
- IndexedInputGate - Class in org.apache.flink.runtime.io.network.partition.consumer
-
An
InputGatewith a specific index. - IndexedInputGate() - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate
- IndexedSortable - Interface in org.apache.flink.runtime.operators.sort
- IndexedSorter - Interface in org.apache.flink.runtime.operators.sort
- IndexRange - Class in org.apache.flink.runtime.executiongraph
-
This class represents the range of index.
- IndexRange(int, int) - Constructor for class org.apache.flink.runtime.executiongraph.IndexRange
- inEventTime() - Method in class org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoin
-
Sets the time characteristic to event time.
- inferSourceParallelismAsync(int, long) - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinator
- inFirstIteration() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
- InflightDataGateOrPartitionRescalingDescriptor(int[], RescaleMappings, Set<Integer>, InflightDataRescalingDescriptor.InflightDataGateOrPartitionRescalingDescriptor.MappingType) - Constructor for class org.apache.flink.runtime.checkpoint.InflightDataRescalingDescriptor.InflightDataGateOrPartitionRescalingDescriptor
- InflightDataRescalingDescriptor - Class in org.apache.flink.runtime.checkpoint
-
Captures ambiguous mappings of old channels to new channels for a particular gate or partition.
- InflightDataRescalingDescriptor(InflightDataRescalingDescriptor.InflightDataGateOrPartitionRescalingDescriptor[]) - Constructor for class org.apache.flink.runtime.checkpoint.InflightDataRescalingDescriptor
- InflightDataRescalingDescriptor.InflightDataGateOrPartitionRescalingDescriptor - Class in org.apache.flink.runtime.checkpoint
-
Captures ambiguous mappings of old channels to new channels.
- InflightDataRescalingDescriptor.InflightDataGateOrPartitionRescalingDescriptor.MappingType - Enum in org.apache.flink.runtime.checkpoint
-
Type of mapping which should be used for this in-flight data.
- INFO_CATEGORY_JM - Static variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
-
Categories to be returned by
QueryScopeInfo.getCategory()to avoid instanceof checks. - INFO_CATEGORY_JM_OPERATOR - Static variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
- INFO_CATEGORY_JOB - Static variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
- INFO_CATEGORY_OPERATOR - Static variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
- INFO_CATEGORY_TASK - Static variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
- INFO_CATEGORY_TM - Static variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
- InfoMessage - Interface in org.apache.flink.runtime.messages.webmonitor
-
Abstract base interface of all info messages exchanged between the JobManager an for example the runtime monitor.
- init() - Method in class org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
- init() - Method in class org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
- init() - Method in class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
- init() - Method in class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask
- init() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
Deprecated.
- init() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
- init() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationTail
- init() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- init(Configuration) - Method in class org.apache.flink.runtime.security.token.hadoop.HadoopDelegationTokenReceiver
- init(Configuration) - Method in class org.apache.flink.runtime.security.token.hadoop.HadoopFSDelegationTokenProvider
- init(Configuration) - Method in class org.apache.flink.runtime.security.token.hadoop.HBaseDelegationTokenProvider
- init(ExecutionGraph, ComponentMainThreadExecutor, MetricGroup) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DefaultSpeculativeExecutionHandler
- init(ExecutionGraph, ComponentMainThreadExecutor, MetricGroup) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DummySpeculativeExecutionHandler
- init(ExecutionGraph, ComponentMainThreadExecutor, MetricGroup) - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.SpeculativeExecutionHandler
-
Initial speculative execution handler.
- initBroadcastInputReaders() - Method in class org.apache.flink.runtime.operators.BatchTask
-
Creates the record readers for the extra broadcast inputs as configured by
TaskConfig.getNumBroadcastInputs(). - initBroadcastInputsSerializers(int) - Method in class org.apache.flink.runtime.operators.BatchTask
-
Creates all the serializers and iterators for the broadcast inputs.
- initFailureCause(Throwable, long) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- initFailureCause(Throwable, long) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- initFileSystem(FileSystem, Path, Path, Path, int) - Method in interface org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager
-
Initialize the file system, recording the checkpoint path the manager should work with.
- initFileSystem(FileSystem, Path, Path, Path, int) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
- INITIAL_CHECKPOINT_ID - Static variable in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
- initialBackoff - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
The initial backoff (in ms).
- INITIALIZATION_TIME - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- InitializationStatus - Enum in org.apache.flink.runtime.checkpoint
-
Status of the initialization.
- InitializationTypeConflictException - Exception in org.apache.flink.runtime.broadcast
-
Indicates that a broadcast variable was initialized with a
DefaultBroadcastVariableInitializeras a non-Listtype, and later accessed usingRuntimeContext.getBroadcastVariable(String)which may only return lists. - InitializationTypeConflictException(Class<?>) - Constructor for exception org.apache.flink.runtime.broadcast.InitializationTypeConflictException
- initialize() - Method in class org.apache.flink.runtime.io.disk.BatchShuffleReadBufferPool
-
Initializes this buffer pool which allocates all the buffers.
- initialize() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
- initialize() - Method in class org.apache.flink.runtime.iterative.task.IterationIntermediateTask
- initialize() - Method in class org.apache.flink.runtime.iterative.task.IterationTailTask
- initialize() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
- initialize() - Method in class org.apache.flink.runtime.operators.BatchTask
- initialize() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
- initialize() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
- initialize() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
- initialize() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
- initialize() - Method in interface org.apache.flink.runtime.operators.ResettableDriver
- initialize() - Method in class org.apache.flink.runtime.resourcemanager.active.ActiveResourceManager
- initialize() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
Initializes the framework specific components.
- initialize() - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
- initialize(int, Duration, long, SubtaskAttemptNumberStore) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- initialize(PluginManager) - Static method in class org.apache.flink.runtime.state.changelog.StateChangelogStorageLoader
- initialize(ResourceEventHandler<WorkerType>, ScheduledExecutor, Executor, BlockedNodeRetriever) - Method in class org.apache.flink.runtime.resourcemanager.active.AbstractResourceManagerDriver
- initialize(ResourceEventHandler<WorkerType>, ScheduledExecutor, Executor, BlockedNodeRetriever) - Method in interface org.apache.flink.runtime.resourcemanager.active.ResourceManagerDriver
-
Initialize the deployment specific components.
- initialize(TaskManagerTracker, ResourceTracker, ResourceManagerId, Executor) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.DefaultSlotStatusSyncer
- initialize(TaskManagerTracker, ResourceTracker, ResourceManagerId, Executor) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotStatusSyncer
-
Initialize this syncer.
- initialize(BatchJobRecoveryContext) - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.BatchJobRecoveryHandler
-
Initializes the recovery handler with the batch job recovery context.
- initialize(BatchJobRecoveryContext) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DefaultBatchJobRecoveryHandler
- initialize(BatchJobRecoveryContext) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DummyBatchJobRecoveryHandler
- INITIALIZE_STATE_DURATION - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- initializeBaseLocationsForCheckpoint() - Method in interface org.apache.flink.runtime.state.CheckpointStorageCoordinatorView
-
Initializes the necessary prerequisites for storage locations of checkpoints.
- initializeBaseLocationsForCheckpoint() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageAccess
- initializeBaseLocationsForCheckpoint() - Method in class org.apache.flink.runtime.state.filesystem.FsMergingCheckpointStorageAccess
- initializeBaseLocationsForCheckpoint() - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorageAccess
- initializeBroadcastVariable(Iterable<T>) - Method in class org.apache.flink.runtime.broadcast.DefaultBroadcastVariableInitializer
- initializeContextEnvironment(StreamExecutionEnvironmentFactory) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
- initializeHandlers(CompletableFuture<String>) - Method in class org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint
- initializeHandlers(CompletableFuture<String>) - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
-
This method is called at the beginning of
RestServerEndpoint.start()to setup all handlers that the REST server endpoint implementation requires. - initializeHandlers(CompletableFuture<String>) - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
- initializeInternal() - Method in class org.apache.flink.runtime.resourcemanager.active.AbstractResourceManagerDriver
-
Initialize the deployment specific components.
- initializeJobVertex(ExecutionJobVertex, int, Map<IntermediateDataSetID, JobVertexInputInfo>, long) - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.BatchJobRecoveryContext
-
Initializes a given job vertex with the specified parallelism and input information.
- initializeJobVertex(ExecutionJobVertex, long) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- initializeJobVertex(ExecutionJobVertex, long, Map<IntermediateDataSetID, JobVertexInputInfo>) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- initializeJobVertex(ExecutionJobVertex, long, Map<IntermediateDataSetID, JobVertexInputInfo>) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Initialize the given execution job vertex, mainly includes creating execution vertices according to the parallelism, and connecting to the predecessors.
- initializeLocationForCheckpoint(long) - Method in interface org.apache.flink.runtime.state.CheckpointStorageCoordinatorView
-
Initializes a storage location for new checkpoint with the given ID.
- initializeLocationForCheckpoint(long) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageAccess
- initializeLocationForCheckpoint(long) - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorageAccess
- initializeLocationForSavepoint(long, String) - Method in interface org.apache.flink.runtime.state.CheckpointStorageCoordinatorView
-
Initializes a storage location for new savepoint with the given ID.
- initializeLocationForSavepoint(long, String) - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorageAccess
-
Creates a file system based storage location for a savepoint.
- initializeOnMaster(JobVertex.InitializeOnMasterContext) - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatVertex
- initializeOnMaster(JobVertex.InitializeOnMasterContext) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
A hook that can be overwritten by sub classes to implement logic that is called by the master when the job starts.
- initializeOperatorCoordinators(ComponentMainThreadExecutor) - Method in class org.apache.flink.runtime.scheduler.DefaultOperatorCoordinatorHandler
- initializeOperatorCoordinators(ComponentMainThreadExecutor) - Method in interface org.apache.flink.runtime.scheduler.OperatorCoordinatorHandler
-
Initialize operator coordinators.
- initializeOperatorState(StreamOperatorStateHandler.CheckpointedStreamOperator) - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
- initializeServices(Configuration, PluginManager) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
- initializeState(FunctionInitializationContext) - Method in interface org.apache.flink.streaming.api.checkpoint.CheckpointedFunction
-
This method is called when the parallel function instance is created during distributed execution.
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.legacy.ContinuousFileMonitoringFunction
-
Deprecated.
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.legacy.FromElementsFunction
-
Deprecated.
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.legacy.StatefulSequenceSource
-
Deprecated.
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
- initializeState(StateInitializationContext) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateUdfStreamOperator
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Stream operators with state which can be restored need to override this hook method.
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
Stream operators with state which can be restored need to override this hook method.
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
- initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.SourceOperator
- initializeState(StateInitializationContext) - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator
- initializeState(StreamTaskStateInitializer) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperator
-
Initialize necessary state components for
AbstractStreamOperator. - initializeState(StreamTaskStateInitializer) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperatorV2
-
Initialize necessary state components for
AbstractStreamOperatorV2. - initializeState(StreamTaskStateInitializer) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- initializeState(StreamTaskStateInitializer) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- initializeState(StreamTaskStateInitializer) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
Provides a context to initialize all state in the operator.
- initializeStateAndOpenOperators(StreamTaskStateInitializer) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
- initializeStateAndOpenOperators(StreamTaskStateInitializer) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
Initialize state and open all operators in the chain from tail to heads, contrary to
StreamOperator.close()which happens heads to tail (seeOperatorChain.finishOperators(StreamTaskActionExecutor, StopMode)). - initializeStateAndOpenOperators(StreamTaskStateInitializer) - Method in class org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
- initializeTierFactories(Configuration) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TierFactoryInitializer
-
Initializes and returns a list of
TierFactoryinstances according to the specifiedTieredStorageConfiguration's persistent level. - initializeVerticesIfPossible() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.AdaptiveBatchScheduler
- initializeWebSubmissionHandlers(CompletableFuture<String>) - Method in class org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint
- initializeWebSubmissionHandlers(CompletableFuture<String>) - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
- INITIALIZING - org.apache.flink.runtime.execution.ExecutionState
-
Restoring last possible valid state of the task if it has it.
- initialPartitionBuffersCount - Variable in class org.apache.flink.runtime.operators.hash.ReOpenableHashPartition
- initialSequenceNumber() - Method in interface org.apache.flink.runtime.state.changelog.StateChangelogWriter
-
Get the initial
SequenceNumberthat is used for the first element. - initInputReaders() - Method in class org.apache.flink.runtime.operators.BatchTask
-
Creates the record readers for the number of inputs as defined by
BatchTask.getNumTaskInputs(). - initInputsCheckpoint(long, CheckpointOptions) - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
-
Initialize new checkpoint.
- initInputsSerializersAndComparators(int, int) - Method in class org.apache.flink.runtime.operators.BatchTask
-
Creates all the serializers and comparators.
- initLocalStrategies(int) - Method in class org.apache.flink.runtime.operators.BatchTask
-
NOTE: This method must be invoked after the invocation of
#initInputReaders()and#initInputSerializersAndComparators(int)! - initOutputs() - Method in class org.apache.flink.runtime.iterative.task.IterationHeadTask
- initOutputs() - Method in class org.apache.flink.runtime.operators.BatchTask
-
Creates a writer for each output.
- initOutputs(AbstractInvokable, UserCodeClassLoader, TaskConfig, List<ChainedDriver<?, ?>>, List<RecordWriter<?>>, ExecutionConfig, Map<String, Accumulator<?, ?>>) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Creates a writer for each output.
- initReader() - Method in class org.apache.flink.streaming.api.operators.SourceOperator
-
Initializes the reader.
- initSourceMetricGroup() - Method in class org.apache.flink.streaming.api.operators.SourceOperator
- initStub(Class<? super S>) - Method in class org.apache.flink.runtime.operators.BatchTask
- initTable(int, byte) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
- InMemoryChangelogStateHandle - Class in org.apache.flink.runtime.state.changelog.inmemory
-
In-memory
ChangelogStateHandle. - InMemoryChangelogStateHandle(List<StateChange>, SequenceNumber, SequenceNumber, KeyGroupRange) - Constructor for class org.apache.flink.runtime.state.changelog.inmemory.InMemoryChangelogStateHandle
- InMemoryPartition<T> - Class in org.apache.flink.runtime.operators.hash
-
In-memory partition with overflow buckets for
CompactingHashTable - InMemoryPartition(TypeSerializer<T>, int, ListMemorySegmentSource, int, int) - Constructor for class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
Creates a new partition, in memory, with one buffer.
- InMemorySorter<T> - Interface in org.apache.flink.runtime.operators.sort
- InMemorySorterFactory<T> - Interface in org.apache.flink.runtime.operators.sort
-
Factory for
InMemorySorter. - InMemoryStateChangelogStorage - Class in org.apache.flink.runtime.state.changelog.inmemory
-
An in-memory (non-production) implementation of
StateChangelogStorage. - InMemoryStateChangelogStorage() - Constructor for class org.apache.flink.runtime.state.changelog.inmemory.InMemoryStateChangelogStorage
- InMemoryStateChangelogStorageFactory - Class in org.apache.flink.runtime.state.changelog.inmemory
-
An
StateChangelogStorageFactoryfor creatingInMemoryStateChangelogStorage. - InMemoryStateChangelogStorageFactory() - Constructor for class org.apache.flink.runtime.state.changelog.inmemory.InMemoryStateChangelogStorageFactory
- INNER_MERGE - org.apache.flink.runtime.operators.DriverStrategy
- InPlaceMutableHashTable<T> - Class in org.apache.flink.runtime.operators.hash
-
This hash table supports updating elements.
- InPlaceMutableHashTable(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
- InPlaceMutableHashTable.EntryIterator - Class in org.apache.flink.runtime.operators.hash
-
WARNING: Doing any other operation on the table invalidates the iterator!
- InPlaceMutableHashTable.HashTableProber<PT> - Class in org.apache.flink.runtime.operators.hash
-
A prober for accessing the table.
- InPlaceMutableHashTable.ReduceFacade - Class in org.apache.flink.runtime.operators.hash
-
A facade for doing such operations on the hash table that are needed for a reduce operator driver.
- inProcessingTime() - Method in class org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoin
-
Sets the time characteristic to processing time.
- inProgress() - Static method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationResult
- inProgress() - Static method in class org.apache.flink.runtime.rest.handler.async.OperationResult
- inProgress() - Static method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
- inProgress() - Static method in class org.apache.flink.runtime.rest.messages.queue.QueueStatus
- input - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputGate.InputWithData
- input - Variable in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
- input - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
- input - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
- Input<IN> - Interface in org.apache.flink.streaming.api.operators
-
Inputinterface used inMultipleInputStreamOperator. - input1WatermarkGauge - Variable in class org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
- input2WatermarkGauge - Variable in class org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
- InputBuffersGauge - Class in org.apache.flink.runtime.io.network.metrics
-
Gauge metric measuring the number of queued input buffers for
SingleInputGates. - InputBuffersGauge(SingleInputGate[]) - Constructor for class org.apache.flink.runtime.io.network.metrics.InputBuffersGauge
- InputBuffersSizeGauge - Class in org.apache.flink.runtime.io.network.metrics
-
Gauge metric measuring the size in bytes of queued input buffers for
SingleInputGates. - InputBuffersSizeGauge(SingleInputGate[]) - Constructor for class org.apache.flink.runtime.io.network.metrics.InputBuffersSizeGauge
- InputChannel - Class in org.apache.flink.runtime.io.network.partition.consumer
-
An input channel consumes a single
ResultSubpartitionView. - InputChannel(SingleInputGate, int, ResultPartitionID, ResultSubpartitionIndexSet, int, int, Counter, Counter) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
- InputChannel.BufferAndAvailability - Class in org.apache.flink.runtime.io.network.partition.consumer
-
A combination of a
Bufferand a flag indicating availability of further buffers, and the backlog length indicating how many non-event buffers are available in the subpartitions. - InputChannelID - Class in org.apache.flink.runtime.io.network.partition.consumer
-
Identifier for input channels.
- InputChannelID() - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
- InputChannelID(long, long) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
- InputChannelID(AbstractID) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
- InputChannelInfo - Class in org.apache.flink.runtime.checkpoint.channel
-
Identifies
InputChannelin a given subtask. - InputChannelInfo(int, int) - Constructor for class org.apache.flink.runtime.checkpoint.channel.InputChannelInfo
- InputChannelMetrics - Class in org.apache.flink.runtime.io.network.metrics
-
Collects metrics for
RemoteInputChannelandLocalInputChannel. - InputChannelMetrics(MetricGroup...) - Constructor for class org.apache.flink.runtime.io.network.metrics.InputChannelMetrics
- inputChannels() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- InputChannelStateHandle - Class in org.apache.flink.runtime.state
-
Handleto anInputChannelstate. - InputChannelStateHandle(int, InputChannelInfo, StreamStateHandle, List<Long>, long) - Constructor for class org.apache.flink.runtime.state.InputChannelStateHandle
- InputChannelStateHandle(int, InputChannelInfo, StreamStateHandle, AbstractChannelStateHandle.StateContentMetaInfo) - Constructor for class org.apache.flink.runtime.state.InputChannelStateHandle
- InputChannelStateHandle(InputChannelInfo, StreamStateHandle, List<Long>) - Constructor for class org.apache.flink.runtime.state.InputChannelStateHandle
- inputComparators - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The comparators for the central driver.
- InputConsumableDecider - Interface in org.apache.flink.runtime.scheduler.strategy
-
InputConsumableDecideris responsible for determining whether the input of an executionVertex or a consumed partition group is consumable. - InputConsumableDecider.Factory - Interface in org.apache.flink.runtime.scheduler.strategy
-
Factory for
InputConsumableDecider. - InputFormatOperatorFactory<OUT> - Interface in org.apache.flink.streaming.api.operators
-
Input format source operator factory.
- InputFormatSourceFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source.legacy
-
Deprecated.This class is based on the
SourceFunctionAPI, which is due to be removed. Use the newSourceAPI instead. - InputFormatSourceFunction(InputFormat<OUT, ?>, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.functions.source.legacy.InputFormatSourceFunction
-
Deprecated.
- inputGate - Variable in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
-
The input gate to read from.
- inputGate - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
- InputGate - Class in org.apache.flink.runtime.io.network.partition.consumer
-
An input gate consumes one or more partitions of a single produced intermediate result.
- InputGate() - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputGate
- InputGate.InputWithData<INPUT,DATA> - Class in org.apache.flink.runtime.io.network.partition.consumer
-
Simple pojo for INPUT, DATA and moreAvailable.
- InputGateDeploymentDescriptor - Class in org.apache.flink.runtime.deployment
-
Deployment descriptor for a single input gate instance.
- InputGateDeploymentDescriptor(IntermediateDataSetID, ResultPartitionType, int, TaskDeploymentDescriptorFactory.ShuffleDescriptorAndIndex[]) - Constructor for class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
- InputGateDeploymentDescriptor(IntermediateDataSetID, ResultPartitionType, IndexRange, int, List<TaskDeploymentDescriptor.MaybeOffloaded<TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup>>) - Constructor for class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
- InputGateID - Class in org.apache.flink.runtime.io.network.partition.consumer
-
Runtime identifier of a consumed
IntermediateResult. - InputGateID(IntermediateDataSetID, ExecutionAttemptID) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputGateID
- InputGateMetrics - Class in org.apache.flink.runtime.io.network.metrics
-
Collects metrics of an input gate.
- inputGates - Variable in class org.apache.flink.runtime.io.network.metrics.AbstractBuffersUsageGauge
- InputGateSpecUtils - Class in org.apache.flink.runtime.io.network.partition.consumer
-
Utils to manage the specs of the
InputGate, for example,GateBuffersSpec. - InputGateSpecUtils() - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputGateSpecUtils
- InputGateUtil - Class in org.apache.flink.streaming.runtime.io
-
Utility for dealing with input gates.
- InputGateWithMetrics - Class in org.apache.flink.runtime.taskmanager
-
This class wraps
InputGateprovided by shuffle service and it is mainly used for increasing general input metrics fromTaskIOMetricGroup. - InputGateWithMetrics(IndexedInputGate, Counter) - Constructor for class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
- inputIndex - Variable in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
- inputIterators - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The inputs reader, wrapped in an iterator.
- InputOutputFormatContainer - Class in org.apache.flink.runtime.jobgraph
-
A container for
InputFormatsandOutputFormats, along with theirConfiguration. - InputOutputFormatContainer(ClassLoader) - Constructor for class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
- InputOutputFormatContainer(TaskConfig, ClassLoader) - Constructor for class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
- InputOutputFormatContainer.FormatUserCodeTable - Class in org.apache.flink.runtime.jobgraph
-
Container for multiple wrappers containing
InputFormatandOutputFormatcode. - InputOutputFormatVertex - Class in org.apache.flink.runtime.jobgraph
-
A task vertex that runs an initialization and a finalization on the master.
- InputOutputFormatVertex(String) - Constructor for class org.apache.flink.runtime.jobgraph.InputOutputFormatVertex
- InputOutputFormatVertex(String, JobVertexID, List<OperatorIDPair>) - Constructor for class org.apache.flink.runtime.jobgraph.InputOutputFormatVertex
- inputProcessor - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
The input processor.
- InputProcessorUtil - Class in org.apache.flink.streaming.runtime.io.checkpointing
-
Utility for creating
CheckpointedInputGatebased on checkpoint mode forStreamOneInputProcessor. - InputProcessorUtil() - Constructor for class org.apache.flink.streaming.runtime.io.checkpointing.InputProcessorUtil
- inputReaders - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The input readers of this task.
- inputRecordAttributes(RecordAttributes, int, PushingAsyncDataInput.DataOutput<?>) - Method in class org.apache.flink.streaming.runtime.io.RecordAttributesCombiner
- inputs - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The inputs to the operator.
- inputs - Variable in class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
- InputSelectable - Interface in org.apache.flink.streaming.api.operators
-
Interface for stream operators that can select the input to get
StreamRecord. - InputSelection - Class in org.apache.flink.streaming.api.operators
-
Describe the input selection that stream operators want to read records.
- InputSelection.Builder - Class in org.apache.flink.streaming.api.operators
-
Utility class for creating
InputSelection. - inputSerializer - Variable in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
- inputSerializers - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The serializers for the input data type.
- inputsLocationsRetriever - Variable in class org.apache.flink.runtime.scheduler.SchedulerBase
- InputsLocationsRetriever - Interface in org.apache.flink.runtime.scheduler
-
Component to retrieve the inputs locations of an
ExecutionVertex. - InputSplitProvider - Interface in org.apache.flink.runtime.jobgraph.tasks
-
An input split provider can be successively queried to provide a series of
InputSplitobjects a task is supposed to consume in the course of its execution. - InputSplitProviderException - Exception in org.apache.flink.runtime.jobgraph.tasks
- InputSplitProviderException(String) - Constructor for exception org.apache.flink.runtime.jobgraph.tasks.InputSplitProviderException
- InputSplitProviderException(String, Throwable) - Constructor for exception org.apache.flink.runtime.jobgraph.tasks.InputSplitProviderException
- InputSplitProviderException(Throwable) - Constructor for exception org.apache.flink.runtime.jobgraph.tasks.InputSplitProviderException
- inputStream1 - Variable in class org.apache.flink.streaming.api.datastream.ConnectedStreams
- inputStream2 - Variable in class org.apache.flink.streaming.api.datastream.ConnectedStreams
- inputType - Variable in class org.apache.flink.streaming.api.operators.sortpartition.KeyedSortPartitionOperator
-
The type information of input records.
- inputType - Variable in class org.apache.flink.streaming.api.operators.sortpartition.SortPartitionOperator
-
The type information of input records.
- InputViewIterator<E> - Class in org.apache.flink.runtime.io.disk
- InputViewIterator(DataInputView, TypeSerializer<E>) - Constructor for class org.apache.flink.runtime.io.disk.InputViewIterator
- inputWatermark(Watermark, int, PushingAsyncDataInput.DataOutput<?>) - Method in class org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve
-
Feed a
Watermarkinto the valve. - inputWatermarkStatus(WatermarkStatus, int, PushingAsyncDataInput.DataOutput<?>) - Method in class org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve
-
Feed a
WatermarkStatusinto the valve. - insert(T) - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
- insert(T) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
- insert(T) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
Inserts the given record into the hash table.
- insertAfterNoMatch(T) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
-
This method can be called after getMatchFor returned null.
- insertIntoBuildBuffer(BT) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
Inserts the given object into the current buffer.
- insertIntoProbeBuffer(PT) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
Inserts the given record into the probe side buffers.
- insertIntoTable(BT, int) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
- insertOrReplaceRecord(T) - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
- insertOrReplaceRecord(T) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
-
Replaces record in hash table if record already present or append record if not.
- insertOrReplaceRecord(T) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
Searches the hash table for a record with the given key.
- install() - Method in class org.apache.flink.runtime.security.modules.HadoopModule
- install() - Method in class org.apache.flink.runtime.security.modules.JaasModule
- install() - Method in interface org.apache.flink.runtime.security.modules.SecurityModule
-
Install the security module.
- install() - Method in class org.apache.flink.runtime.security.modules.ZooKeeperModule
- install(SecurityConfiguration) - Static method in class org.apache.flink.runtime.security.SecurityUtils
-
Installs a process-wide security configuration.
- installAsShutdownHook(Logger) - Static method in class org.apache.flink.runtime.util.JvmShutdownSafeguard
-
Installs the safeguard shutdown hook.
- installAsShutdownHook(Logger, long) - Static method in class org.apache.flink.runtime.util.JvmShutdownSafeguard
-
Installs the safeguard shutdown hook.
- installSecurityContext(Configuration) - Static method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
- instance() - Static method in class org.apache.flink.runtime.broadcast.DefaultBroadcastVariableInitializer
- instance() - Static method in class org.apache.flink.runtime.iterative.concurrent.BlockingBackChannelBroker
-
Retrieve singleton instance.
- instance() - Static method in class org.apache.flink.runtime.iterative.concurrent.IterationAggregatorBroker
-
Retrieve singleton instance.
- instance() - Static method in class org.apache.flink.runtime.iterative.concurrent.SolutionSetBroker
-
Retrieve the singleton instance.
- instance() - Static method in class org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrierBroker
- instance() - Static method in class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatchBroker
-
Retrieve the singleton instance.
- INSTANCE - org.apache.flink.runtime.checkpoint.DeactivatedCheckpointCompletedCheckpointStore
- INSTANCE - org.apache.flink.runtime.checkpoint.DeactivatedCheckpointIDCounter
- INSTANCE - org.apache.flink.runtime.checkpoint.NoOpCheckpointStatsTracker
- INSTANCE - org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointStoreUtil
- INSTANCE - org.apache.flink.runtime.concurrent.UnsupportedOperationExecutor
- INSTANCE - org.apache.flink.runtime.dispatcher.cleanup.CheckpointResourcesCleanupRunnerFactory
- INSTANCE - org.apache.flink.runtime.dispatcher.cleanup.CleanupRetryStrategyFactory
- INSTANCE - org.apache.flink.runtime.dispatcher.JobDispatcherFactory
- INSTANCE - org.apache.flink.runtime.dispatcher.JobMasterServiceLeadershipRunnerFactory
- INSTANCE - org.apache.flink.runtime.dispatcher.runner.StoppedDispatcherLeaderProcess
- INSTANCE - org.apache.flink.runtime.dispatcher.SessionDispatcherFactory
- INSTANCE - org.apache.flink.runtime.dispatcher.VoidHistoryServerArchivist
- INSTANCE - org.apache.flink.runtime.executiongraph.failover.NoRestartBackoffTimeStrategy
- INSTANCE - org.apache.flink.runtime.executiongraph.failover.NoRestartBackoffTimeStrategy.NoRestartBackoffTimeStrategyFactory
- INSTANCE - org.apache.flink.runtime.executiongraph.NoOpExecutionDeploymentListener
- INSTANCE - org.apache.flink.runtime.jobmanager.NoOpJobGraphStoreWatcher
- INSTANCE - org.apache.flink.runtime.jobmanager.ThrowingJobGraphWriter
- INSTANCE - org.apache.flink.runtime.jobmanager.ZooKeeperJobGraphStoreUtil
- INSTANCE - org.apache.flink.runtime.jobmaster.factories.UnregisteredJobManagerJobMetricGroupFactory
- INSTANCE - org.apache.flink.runtime.jobmaster.JobMasterServiceProcess.WaitingForLeadership
- INSTANCE - org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPool.NoOpNewSlotsListener
- INSTANCE - org.apache.flink.runtime.jobmaster.slotpool.NoOpDeclareResourceRequirementServiceConnectionManager
- INSTANCE - org.apache.flink.runtime.jobmaster.slotpool.PreferredAllocationRequestSlotMatchingStrategy
- INSTANCE - org.apache.flink.runtime.jobmaster.slotpool.SimpleRequestSlotMatchingStrategy
- INSTANCE - org.apache.flink.runtime.rest.handler.legacy.metrics.VoidMetricFetcher
- INSTANCE - org.apache.flink.runtime.rest.JobRestEndpointFactory
- INSTANCE - org.apache.flink.runtime.rest.SessionRestEndpointFactory
- INSTANCE - org.apache.flink.runtime.shuffle.NettyShuffleDescriptor.LocalExecutionPartitionConnectionInfo
- INSTANCE - org.apache.flink.runtime.taskexecutor.slot.NoOpSlotAllocationSnapshotPersistenceService
- INSTANCE - org.apache.flink.runtime.webmonitor.WebMonitorExtension.EmptyWebMonitorExtension
- INSTANCE - Static variable in class org.apache.flink.runtime.checkpoint.FinishedOperatorSubtaskState
- INSTANCE - Static variable in class org.apache.flink.runtime.checkpoint.metadata.MetadataV1Serializer
- INSTANCE - Static variable in class org.apache.flink.runtime.checkpoint.metadata.MetadataV2Serializer
-
The singleton instance of the serializer.
- INSTANCE - Static variable in class org.apache.flink.runtime.checkpoint.metadata.MetadataV3Serializer
-
The singleton instance of the serializer.
- INSTANCE - Static variable in class org.apache.flink.runtime.checkpoint.metadata.MetadataV4Serializer
- INSTANCE - Static variable in class org.apache.flink.runtime.checkpoint.metadata.MetadataV5Serializer
- INSTANCE - Static variable in class org.apache.flink.runtime.checkpoint.RoundRobinOperatorStateRepartitioner
- INSTANCE - Static variable in class org.apache.flink.runtime.highavailability.DefaultClientHighAvailabilityServicesFactory
- INSTANCE - Static variable in class org.apache.flink.runtime.io.network.api.EndOfPartitionEvent
-
The singleton instance of this event.
- INSTANCE - Static variable in class org.apache.flink.runtime.io.network.api.EndOfSegmentEvent
-
The singleton instance of this event.
- INSTANCE - Static variable in class org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
-
The singleton instance of this event.
- INSTANCE - Static variable in class org.apache.flink.runtime.io.network.buffer.BufferRecycler.DummyBufferRecycler
- INSTANCE - Static variable in class org.apache.flink.runtime.io.network.buffer.FreeingBufferRecycler
- INSTANCE - Static variable in class org.apache.flink.runtime.io.network.partition.consumer.EndOfChannelStateEvent
-
The singleton instance of this event.
- INSTANCE - Static variable in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.NoOpMasterAgent
- INSTANCE - Static variable in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.NoOpTierShuffleDescriptor
- INSTANCE - Static variable in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.UnknownTierShuffleDescriptor
- INSTANCE - Static variable in class org.apache.flink.runtime.iterative.event.TerminationEvent
- INSTANCE - Static variable in class org.apache.flink.runtime.jobmaster.event.GenericJobEventSerializer
- INSTANCE - Static variable in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
- INSTANCE - Static variable in class org.apache.flink.runtime.resourcemanager.ArbitraryWorkerResourceSpecFactory
- INSTANCE - Static variable in class org.apache.flink.runtime.resourcemanager.slotmanager.NonSupportedResourceAllocatorImpl
- INSTANCE - Static variable in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
- INSTANCE - Static variable in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteStatusHeaders
- INSTANCE - Static variable in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteTriggerHeaders
- INSTANCE - Static variable in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetListHeaders
- INSTANCE - Static variable in class org.apache.flink.runtime.rest.messages.job.JobResourceRequirementsHeaders
- INSTANCE - Static variable in class org.apache.flink.runtime.rest.messages.job.JobResourcesRequirementsUpdateHeaders
- INSTANCE - Static variable in class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexWatermarksHeaders
- INSTANCE - Static variable in class org.apache.flink.runtime.scheduler.strategy.AllFinishedInputConsumableDecider.Factory
- INSTANCE - Static variable in class org.apache.flink.runtime.scheduler.strategy.DefaultInputConsumableDecider.Factory
- INSTANCE - Static variable in class org.apache.flink.runtime.scheduler.strategy.PartialFinishedInputConsumableDecider.Factory
- INSTANCE - Static variable in class org.apache.flink.runtime.state.filemerging.EmptySegmentFileStateHandle
- INSTANCE - Static variable in class org.apache.flink.runtime.state.SnappyStreamCompressionDecorator
- INSTANCE - Static variable in class org.apache.flink.runtime.state.UncompressedStreamCompressionDecorator
- INSTANCE - Static variable in class org.apache.flink.runtime.state.VoidNamespace
-
The singleton instance
- INSTANCE - Static variable in class org.apache.flink.runtime.state.VoidNamespaceSerializer
- INSTANCE - Static variable in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
- INSTANCE - Static variable in class org.apache.flink.runtime.webmonitor.NonLeaderRetrievalRestfulGateway
- INSTANCE - Static variable in class org.apache.flink.streaming.runtime.io.BlockingQueueBroker
-
Singleton instance.
- InstanceID - Class in org.apache.flink.runtime.instance
-
Class for statistically unique instance IDs.
- InstanceID() - Constructor for class org.apache.flink.runtime.instance.InstanceID
- InstanceID(byte[]) - Constructor for class org.apache.flink.runtime.instance.InstanceID
- instantiateFlinkMemoryMetricGroup(MetricGroup, TaskSlotTable<?>, Supplier<Long>) - Static method in class org.apache.flink.runtime.metrics.util.MetricUtils
- instantiateProcessMetricGroup(MetricRegistry, String, Optional<Duration>) - Static method in class org.apache.flink.runtime.metrics.util.MetricUtils
- instantiateStatusMetrics(MetricGroup) - Static method in class org.apache.flink.runtime.metrics.util.MetricUtils
- instantiateSystemMetrics(MetricGroup, Duration) - Static method in class org.apache.flink.runtime.metrics.util.SystemResourcesMetricsInitializer
- instantiateTaskManagerMetricGroup(MetricRegistry, String, ResourceID, Optional<Duration>) - Static method in class org.apache.flink.runtime.metrics.util.MetricUtils
- instantiateUserCode(TaskConfig, ClassLoader, Class<? super T>) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Instantiates a user code class from is definition in the task configuration.
- IntArrayList - Class in org.apache.flink.runtime.util
-
Minimal implementation of an array-backed list of ints
- IntArrayList(int) - Constructor for class org.apache.flink.runtime.util.IntArrayList
- IntegerResourceVersion - Class in org.apache.flink.runtime.persistence
-
ResourceVersionimplementation withIntegervalue. - INTERMEDIATE_RECORD_FROM_BUFFER - org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
- IntermediateDataSet - Class in org.apache.flink.runtime.jobgraph
-
An intermediate data set is the data set produced by an operator - either a source or any intermediate operation.
- IntermediateDataSet(IntermediateDataSetID, ResultPartitionType, JobVertex) - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateDataSet
- IntermediateDataSetID - Class in org.apache.flink.runtime.jobgraph
-
Id identifying
IntermediateDataSet. - IntermediateDataSetID() - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateDataSetID
-
Creates an new random intermediate data set ID.
- IntermediateDataSetID(UUID) - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateDataSetID
-
Creates a new intermediate data set ID with the bytes of the given UUID.
- IntermediateDataSetID(AbstractID) - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateDataSetID
-
Creates a new intermediate data set ID with the bytes of the given ID.
- IntermediateResult - Class in org.apache.flink.runtime.executiongraph
- IntermediateResult(IntermediateDataSet, ExecutionJobVertex, int, ResultPartitionType) - Constructor for class org.apache.flink.runtime.executiongraph.IntermediateResult
- IntermediateResultInfo - Interface in org.apache.flink.runtime.executiongraph
- IntermediateResultPartition - Class in org.apache.flink.runtime.executiongraph
- IntermediateResultPartition(IntermediateResult, ExecutionVertex, int, EdgeManager) - Constructor for class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
- IntermediateResultPartitionID - Class in org.apache.flink.runtime.jobgraph
-
Id identifying
IntermediateResultPartition. - IntermediateResultPartitionID() - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
-
Creates an new random intermediate result partition ID for testing.
- IntermediateResultPartitionID(IntermediateDataSetID, int) - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
-
Creates an new intermediate result partition ID with
IntermediateDataSetIDand the partitionNum. - INTERNAL_CLUSTER_EXECUTION_MODE - Static variable in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
- InternalAggregateProcessAllWindowFunction<T,ACC,V,R,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping a
ProcessAllWindowFunctionthat takes anIterableand anAggregateFunction. - InternalAggregateProcessAllWindowFunction(AggregateFunction<T, ACC, V>, ProcessAllWindowFunction<V, R, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
- InternalAggregateProcessWindowFunction<T,ACC,V,R,K,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping a
ProcessWindowFunctionthat takes anIterableand anAggregateFunction. - InternalAggregateProcessWindowFunction(AggregateFunction<T, ACC, V>, ProcessWindowFunction<V, R, K, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
- InternalAggregatingState<K,N,IN,SV,OUT> - Interface in org.apache.flink.runtime.state.internal
-
The peer to the
AggregatingStatein the internal state type hierarchy. - InternalAggregatingState<K,N,IN,ACC,OUT> - Interface in org.apache.flink.runtime.state.v2.internal
-
This class defines the internal interface for aggregating state.
- InternalAppendingState<K,N,IN,SV,OUT> - Interface in org.apache.flink.runtime.state.internal
-
The peer to the
AppendingStatein the internal state type hierarchy. - InternalAppendingState<K,N,IN,SV,OUT,SYNCOUT> - Interface in org.apache.flink.runtime.state.v2.internal
-
This class defines the internal interface for appending state.
- InternalCacheMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
A
CacheMetricGroupwhich register all cache related metrics under a subgroup of the parent metric group. - InternalCacheMetricGroup(MetricGroup, String) - Constructor for class org.apache.flink.runtime.metrics.groups.InternalCacheMetricGroup
-
Creates a subgroup with the specified subgroup name under the parent group.
- internalCleanup() - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
-
Clean up the meta data in the distributed system(e.g.
- internalCleanup() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperLeaderElectionHaServices
- internalCleanupJobData(JobID) - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
-
Clean up the meta data in the distributed system(e.g.
- internalCleanupJobData(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperLeaderElectionHaServices
- internalClose() - Method in class org.apache.flink.runtime.highavailability.AbstractHaServices
-
Closes the components which is used for external operations(e.g.
- internalClose() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperLeaderElectionHaServices
- internalDeregisterApplication(ApplicationStatus, String) - Method in class org.apache.flink.runtime.resourcemanager.active.ActiveResourceManager
- internalDeregisterApplication(ApplicationStatus, String) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
The framework specific code to deregister the application.
- internalDeregisterApplication(ApplicationStatus, String) - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
- InternalExecutionGraphAccessor - Interface in org.apache.flink.runtime.executiongraph
-
This interface encapsulates all methods needed by ExecutionJobVertex / ExecutionVertices / Execution from the DefaultExecutionGraph.
- InternalFailuresListener - Interface in org.apache.flink.runtime.scheduler
-
This interface enables subscribing to failures that are detected from the JobMaster side (e.g., from within the
ExecutionGraph). - InternalIterableAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping an
AllWindowFunctionthat takes anIterablewhen the window state also is anIterable. - InternalIterableAllWindowFunction(AllWindowFunction<IN, OUT, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
- InternalIterableProcessAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping a
ProcessAllWindowFunctionthat takes anIterablewhen the window state also is anIterable. - InternalIterableProcessAllWindowFunction(ProcessAllWindowFunction<IN, OUT, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
- InternalIterableProcessWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping a
ProcessWindowFunctionthat takes anIterablewhen the window state also is anIterable. - InternalIterableProcessWindowFunction(ProcessWindowFunction<IN, OUT, KEY, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
- InternalIterableWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping a
WindowFunctionthat takes anIterablewhen the window state also is anIterable. - InternalIterableWindowFunction(WindowFunction<IN, OUT, KEY, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
- InternalKeyContext<K> - Interface in org.apache.flink.runtime.state
-
This interface is the current context of a keyed state.
- InternalKeyContextImpl<K> - Class in org.apache.flink.runtime.state
-
The default
InternalKeyContextimplementation. - InternalKeyContextImpl(KeyGroupRange, int) - Constructor for class org.apache.flink.runtime.state.InternalKeyContextImpl
- InternalKeyedState<K,N,V> - Interface in org.apache.flink.runtime.state.v2.internal
-
This class defines the internal interface for all keyed state.
- InternalKvState<K,N,V> - Interface in org.apache.flink.runtime.state.internal
-
The
InternalKvStateis the root of the internal state type hierarchy, similar to theStatebeing the root of the public API state hierarchy. - InternalKvState.StateIncrementalVisitor<K,N,V> - Interface in org.apache.flink.runtime.state.internal
-
The state entry visitor which supports remove and update of the last returned entries.
- InternalListState<K,N,T> - Interface in org.apache.flink.runtime.state.internal
-
The peer to the
ListStatein the internal state type hierarchy. - InternalListState<K,N,V> - Interface in org.apache.flink.runtime.state.v2.internal
-
This class defines the internal interface for list state.
- InternalMapState<K,N,UK,UV> - Interface in org.apache.flink.runtime.state.internal
-
The peer to the
MapStatein the internal state type hierarchy. - InternalMapState<K,N,UK,UV> - Interface in org.apache.flink.runtime.state.v2.internal
-
This class defines the internal interface for map state.
- InternalMergingState<K,N,IN,SV,OUT> - Interface in org.apache.flink.runtime.state.internal
-
The peer to the
MergingStatein the internal state type hierarchy. - InternalMergingState<K,N,IN,SV,OUT,SYNCOUT> - Interface in org.apache.flink.runtime.state.v2.internal
-
This class defines the internal interface for merging state.
- internalNioBuffer(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- InternalOperatorCoordinatorMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
Special
MetricGrouprepresenting an OperatorCoordinator. - InternalOperatorCoordinatorMetricGroup(MetricGroup) - Constructor for class org.apache.flink.runtime.metrics.groups.InternalOperatorCoordinatorMetricGroup
- InternalOperatorIOMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
Metric group that contains shareable pre-defined IO-related metrics.
- InternalOperatorIOMetricGroup(InternalOperatorMetricGroup) - Constructor for class org.apache.flink.runtime.metrics.groups.InternalOperatorIOMetricGroup
- InternalOperatorMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
Special
MetricGrouprepresenting an Operator. - InternalPartitionedState<N> - Interface in org.apache.flink.runtime.state.v2.internal
-
A state that is partitioned into different namespaces.
- InternalPriorityQueue<T> - Interface in org.apache.flink.runtime.state
-
Interface for collection that gives in order access to elements w.r.t their priority.
- InternalProcessAllWindowContext<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal reusable context wrapper.
- InternalProcessApplyAllWindowContext<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
Internal reusable context wrapper.
- InternalProcessApplyWindowContext<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
Internal reusable context wrapper.
- InternalProcessWindowContext<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal reusable context wrapper.
- InternalReducingState<K,N,T> - Interface in org.apache.flink.runtime.state.internal
-
The peer to the
ReducingStatein the internal state type hierarchy. - InternalReducingState<K,N,T> - Interface in org.apache.flink.runtime.state.v2.internal
-
This class defines the internal interface for reducing state.
- internalSetKeyContextElement(StreamRecord<T>, KeySelector<T, ?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- InternalSingleValueAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping an
AllWindowFunctionthat takes anIterablewhen the window state is a single value. - InternalSingleValueAllWindowFunction(AllWindowFunction<IN, OUT, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
- InternalSingleValueProcessAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping a
ProcessAllWindowFunctionthat takes anIterablewhen the window state is a single value. - InternalSingleValueProcessAllWindowFunction(ProcessAllWindowFunction<IN, OUT, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
- InternalSingleValueProcessWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping a
ProcessWindowFunctionthat takes anIterablewhen the window state is a single value. - InternalSingleValueProcessWindowFunction(ProcessWindowFunction<IN, OUT, KEY, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
- InternalSingleValueWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal window function for wrapping a
WindowFunctionthat takes anIterablewhen the window state is a single value. - InternalSingleValueWindowFunction(WindowFunction<IN, OUT, KEY, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
- InternalSinkCommitterMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
Special
MetricGrouprepresenting an Operator. - InternalSinkWriterMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
Special
MetricGrouprepresenting an Operator. - InternalSourceReaderMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
Special
MetricGrouprepresenting an Operator. - InternalSplitEnumeratorMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
Special
MetricGrouprepresenting anSplitEnumerator. - InternalSplitEnumeratorMetricGroup(MetricGroup) - Constructor for class org.apache.flink.runtime.metrics.groups.InternalSplitEnumeratorMetricGroup
- InternalTimer<K,N> - Interface in org.apache.flink.streaming.api.operators
-
Internal interface for in-flight timers.
- internalTimerService - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
- InternalTimerService<N> - Interface in org.apache.flink.streaming.api.operators
-
Interface for working with time and timers.
- InternalTimerServiceAsyncImpl<K,N> - Class in org.apache.flink.streaming.api.operators
-
An implementation of
InternalTimerServicethat is used byorg.apache.flink.streaming.runtime.operators.asyncprocessing.AbstractAsyncStateStreamOperator. - InternalTimerServiceImpl<K,N> - Class in org.apache.flink.streaming.api.operators
-
InternalTimerServicethat stores timers on the Java heap. - internalTimerServiceManager() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
-
Returns the internal timer service manager for the stream operator.
- InternalTimerServiceSerializationProxy<K> - Class in org.apache.flink.streaming.api.operators
-
Serialization proxy for the timer services for a given key-group.
- InternalTimerServiceSerializationProxy(InternalTimeServiceManagerImpl<K>, int) - Constructor for class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
-
Constructor to use when writing timer services.
- InternalTimerServiceSerializationProxy(InternalTimeServiceManagerImpl<K>, ClassLoader, int) - Constructor for class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
-
Constructor to use when restoring timer services.
- InternalTimersSnapshot<K,N> - Class in org.apache.flink.streaming.api.operators
-
A snapshot of internal timers, containing event and processing timers and the serializers to use to write / read them.
- InternalTimersSnapshot() - Constructor for class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
Empty constructor used when restoring the timers.
- InternalTimersSnapshot(TypeSerializer<K>, TypeSerializer<N>, Set<TimerHeapInternalTimer<K, N>>, Set<TimerHeapInternalTimer<K, N>>) - Constructor for class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
-
Constructor to use when snapshotting the timers.
- InternalTimersSnapshotReaderWriters - Class in org.apache.flink.streaming.api.operators
-
Readers and writers for different versions of the
InternalTimersSnapshot. - InternalTimersSnapshotReaderWriters() - Constructor for class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters
- InternalTimersSnapshotReaderWriters.InternalTimersSnapshotReader<K,N> - Interface in org.apache.flink.streaming.api.operators
-
A reader for a
InternalTimersSnapshot. - InternalTimersSnapshotReaderWriters.InternalTimersSnapshotWriter - Interface in org.apache.flink.streaming.api.operators
-
A writer for a
InternalTimersSnapshot. - InternalTimersSnapshotReaderWriters.LegacyTimerSerializer<K,N> - Class in org.apache.flink.streaming.api.operators
-
A
TypeSerializerused to serialize/deserialize aTimerHeapInternalTimer. - InternalTimeServiceManager<K> - Interface in org.apache.flink.streaming.api.operators
-
An entity keeping all the time-related services.
- InternalTimeServiceManager.Provider - Interface in org.apache.flink.streaming.api.operators
-
A provider pattern for creating an instance of a
InternalTimeServiceManager. - InternalTimeServiceManager.ShouldStopAdvancingFn - Interface in org.apache.flink.streaming.api.operators
-
Signals whether the watermark should continue advancing.
- InternalTimeServiceManagerImpl<K> - Class in org.apache.flink.streaming.api.operators
-
An entity keeping all the time-related services.
- InternalValueState<K,N,T> - Interface in org.apache.flink.runtime.state.internal
-
The peer to the
ValueStatein the internal state type hierarchy. - InternalValueState<K,N,V> - Interface in org.apache.flink.runtime.state.v2.internal
-
This class defines the internal interface for value state.
- InternalWatermark - Class in org.apache.flink.streaming.api.watermark
-
The
Watermarkthat contains extra information to be used internally. - InternalWatermark(long, int) - Constructor for class org.apache.flink.streaming.api.watermark.InternalWatermark
- InternalWindowFunction<IN,OUT,KEY,W extends Window> - Interface in org.apache.flink.streaming.runtime.operators.windowing.functions
-
Internal interface for functions that are evaluated over keyed (grouped) windows.
- InternalWindowFunction.InternalWindowContext - Interface in org.apache.flink.streaming.runtime.operators.windowing.functions
-
A context for
InternalWindowFunction, similar toProcessWindowFunction.Contextbut for internal use. - intersects(TimeWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
Returns
trueif this window intersects the given window or if this window is just after or before the given window. - intervalJoin(KeyedStream<T1, KEY>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Join elements of this
KeyedStreamwith elements of anotherKeyedStreamover a time interval that can be specified withKeyedStream.IntervalJoin.between(Duration, Duration). - IntervalJoined(KeyedStream<IN1, KEY>, KeyedStream<IN2, KEY>, long, long, boolean, boolean) - Constructor for class org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoined
- IntervalJoinOperator<K,T1,T2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
An
operatorto execute time-bounded stream inner joins. - IntervalJoinOperator(long, long, boolean, boolean, OutputTag<T1>, OutputTag<T2>, TypeSerializer<T1>, TypeSerializer<T2>, ProcessJoinFunction<T1, T2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
-
Creates a new IntervalJoinOperator.
- IntervalJoinOperator.BufferEntry<T> - Class in org.apache.flink.streaming.api.operators.co
-
A container for elements put in the left/write buffer.
- IntervalJoinOperator.BufferEntrySerializer<T> - Class in org.apache.flink.streaming.api.operators.co
-
A
serializerfor theIntervalJoinOperator.BufferEntry. - IntervalJoinOperator.BufferEntrySerializerSnapshot<T> - Class in org.apache.flink.streaming.api.operators.co
-
A
TypeSerializerSnapshotforIntervalJoinOperator.BufferEntrySerializer. - INVALID_CHECKPOINT_ID - Static variable in interface org.apache.flink.runtime.checkpoint.CheckpointStoreUtil
- invalidate() - Method in class org.apache.flink.streaming.api.datastream.CachedDataStream
-
Invalidate the cache intermediate result of this DataStream to release the physical resources.
- invalidateClusterDataset(AbstractID) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- invalidateClusterDataset(AbstractID) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
- invalidateCurrentSchemaSerializerAccess() - Method in class org.apache.flink.runtime.state.StateSerializerProvider
-
Invalidates access to the current schema serializer.
- invert() - Method in class org.apache.flink.runtime.checkpoint.RescaleMappings
- invertNormalizedKey() - Method in class org.apache.flink.streaming.api.operators.sortpartition.FixedLengthByteKeyAndValueComparator
- invertNormalizedKey() - Method in class org.apache.flink.streaming.api.operators.sortpartition.VariableLengthByteKeyAndValueComparator
- inView - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
- inView - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
- invoke() - Method in class org.apache.flink.runtime.iterative.task.IterationSynchronizationSinkTask
- invoke() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
- invoke() - Method in interface org.apache.flink.runtime.jobgraph.tasks.TaskInvokable
-
Starts the execution.
- invoke() - Method in class org.apache.flink.runtime.operators.BatchTask
-
The main work method.
- invoke() - Method in class org.apache.flink.runtime.operators.DataSinkTask
- invoke() - Method in class org.apache.flink.runtime.operators.DataSourceTask
- invoke() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.OutputFormatSinkFunction
-
Deprecated.
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.PrintSinkFunction
-
Deprecated.
- invoke(IN) - Method in interface org.apache.flink.streaming.api.functions.sink.legacy.SinkFunction
-
Deprecated.
- invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.SocketClientSink
-
Deprecated.Called when new data arrives to the sink, and forwards it to Socket.
- invoke(IN, SinkFunction.Context) - Method in interface org.apache.flink.streaming.api.functions.sink.legacy.SinkFunction
-
Deprecated.Writes the given value to the sink.
- invoke(IN, SinkFunction.Context) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
- invokeRegistration(G, F, long) - Method in class org.apache.flink.runtime.registration.RetryingRegistration
- IO_CURRENT_INPUT_WATERMARK - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- IO_CURRENT_INPUT_WATERMARK_PATERN - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- IO_CURRENT_OUTPUT_WATERMARK - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- IO_EXCEPTION - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- IO_NUM_BUFFERS_IN - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- IO_NUM_BUFFERS_OUT - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- IO_NUM_BUFFERS_OUT_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- IO_NUM_BYTES_IN - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- IO_NUM_BYTES_IN_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- IO_NUM_BYTES_OUT - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- IO_NUM_BYTES_OUT_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- IO_NUM_RECORDS_IN - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- IO_NUM_RECORDS_IN_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- IO_NUM_RECORDS_OUT - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- IO_NUM_RECORDS_OUT_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- ioExecutor - Variable in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
-
The executor for I/O operations in this manager.
- ioExecutor - Variable in class org.apache.flink.runtime.highavailability.AbstractHaServices
-
The executor to run external IO operations on.
- ioExecutor - Variable in class org.apache.flink.runtime.resourcemanager.ResourceManager
- ioManager - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The I/O manager used to instantiate writers for the spilled partitions.
- IOManager - Class in org.apache.flink.runtime.io.disk.iomanager
-
The facade for the provided I/O manager services.
- IOManager(String[], ExecutorService) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Constructs a new IOManager.
- IOManagerAsync - Class in org.apache.flink.runtime.io.disk.iomanager
-
A version of the
IOManagerthat uses asynchronous I/O. - IOManagerAsync() - Constructor for class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
Constructs a new asynchronous I/O manager, writing files to the system 's temp directory.
- IOManagerAsync(String) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
Constructs a new asynchronous I/O manager, writing file to the given directory.
- IOManagerAsync(String[], ExecutorService) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
Constructs a new asynchronous I/O manager, writing file round robin across the given directories.
- IOManagerAsync(String, ExecutorService) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
Constructs a new asynchronous I/O manager, writing file to the given directory.
- IOManagerAsync(ExecutorService) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
Constructs a new asynchronous I/O manager, writing files to the system 's temp directory.
- IOMetrics - Class in org.apache.flink.runtime.executiongraph
-
An instance of this class represents a snapshot of the io-related metrics of a single task.
- IOMetrics(long, long, long, long, long, double, long) - Constructor for class org.apache.flink.runtime.executiongraph.IOMetrics
- IOMetrics(long, long, long, long, long, double, long, Map<IntermediateResultPartitionID, ResultPartitionBytes>) - Constructor for class org.apache.flink.runtime.executiongraph.IOMetrics
- IOMetrics(Meter, Meter, Meter, Meter, Gauge<Long>, Gauge<Long>, Gauge<Double>, Map<IntermediateResultPartitionID, ResultPartitionBytesCounter>) - Constructor for class org.apache.flink.runtime.executiongraph.IOMetrics
- IOMetricsInfo - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
IO metrics information.
- IOMetricsInfo(long, boolean, long, boolean, long, boolean, long, boolean, long, long, double) - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- IpOnlyHostNameSupplier(InetAddress) - Constructor for class org.apache.flink.runtime.taskmanager.TaskManagerLocation.IpOnlyHostNameSupplier
- IS_BACK_PRESSURED - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- isAborted() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
- isAcceptingMails() - Method in enum org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox.State
- isAcknowledgedBy(ExecutionAttemptID) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
- isActive() - Method in class org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
- isActive(JobID, AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
- isAlive() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
True if the slot is alive and has not been released.
- isAlive() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
- isAllInputsReceived() - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStatePendingResult
- isAllocated(int, JobID, AllocationID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Check whether the slot for the given index is allocated for the given job and allocation id.
- isAllocated(int, JobID, AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- isAllocated(JobID, AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
- isAllOutputsReceived() - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStatePendingResult
- isAllToAllDistribution() - Method in class org.apache.flink.runtime.shuffle.PartitionDescriptor
- isAllVerticesInSameSlotSharingGroupByDefault() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Gets whether to put all vertices into the same slot sharing group by default.
- isAmbiguous() - Method in enum org.apache.flink.runtime.io.network.api.writer.SubtaskStateMapper
-
Returns true iff this mapper can potentially lead to ambiguous mappings where the different new subtasks map to the same old subtask.
- isAmbiguous(int, int) - Method in class org.apache.flink.runtime.checkpoint.InflightDataRescalingDescriptor
- isAmbiguousKeyPossible(TypeSerializer, TypeSerializer) - Static method in class org.apache.flink.runtime.state.CompositeKeySerializationUtils
- isAnyOutputBlocking() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- isAnyOutputBlocking(ExecutionGraph) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionGraphUtils
- isApproximateLocalRecoveryEnabled() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
- isApproximateLocalRecoveryEnabled() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Returns whether approximate local recovery is enabled.
- isApproximatelyAvailable() - Method in interface org.apache.flink.runtime.io.AvailabilityProvider
-
Checks whether this instance is available only via constant
AvailabilityProvider.AVAILABLEto avoid performance concern caused by volatile access inCompletableFuture.isDone(). - isAsyncStateProcessingEnabled() - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperator
- isAsyncStateProcessingEnabled() - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperatorV2
- isAsyncStateProcessingEnabled() - Method in interface org.apache.flink.streaming.runtime.operators.asyncprocessing.AsyncStateProcessing
-
Get if the async state processing is enabled for this input/operator.
- isAutoParallelismEnabled() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- isAvailable() - Method in interface org.apache.flink.runtime.io.AvailabilityProvider
-
In order to best-effort avoid volatile access in
CompletableFuture.isDone(), we check the condition offuture == AVAILABLEfirstly for getting probable performance benefits while hot looping. - isAvailable() - Method in class org.apache.flink.runtime.io.network.api.writer.MultipleRecordWriters
- isAvailable() - Method in class org.apache.flink.runtime.io.network.api.writer.NonRecordWriter
- isAvailable() - Method in class org.apache.flink.runtime.io.network.api.writer.SingleRecordWriter
- isAvailable() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartitionView.AvailabilityWithBacklog
- isAvailable(IntermediateResultPartitionID) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraphResultPartitionAvailabilityChecker
- isAvailable(IntermediateResultPartitionID) - Method in interface org.apache.flink.runtime.executiongraph.failover.ResultPartitionAvailabilityChecker
-
Returns whether the given partition is available.
- isBacklog() - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinatorContext
-
Returns whether the Source is processing backlog data.
- isBacklog() - Method in class org.apache.flink.streaming.runtime.streamrecord.RecordAttributes
-
If it returns true, then the records received after this element are stale and an operator can optionally buffer records until isBacklog=false.
- isBackPressured() - Method in class org.apache.flink.runtime.taskmanager.Task
- isBasicType() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
- isBasicType() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
- isBatchShuffleCompressionEnabled() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- isBlockedNode(String) - Method in interface org.apache.flink.runtime.blocklist.BlocklistTracker
-
Returns whether the given node is blocked.
- isBlockedNode(String) - Method in class org.apache.flink.runtime.blocklist.DefaultBlocklistTracker
- isBlockedTaskManager(ResourceID) - Method in interface org.apache.flink.runtime.blocklist.BlockedTaskManagerChecker
-
Returns whether the given task manager is located on a blocked node.
- isBlockedTaskManager(ResourceID) - Method in interface org.apache.flink.runtime.blocklist.BlocklistHandler
-
Returns whether the given task manager is blocked (located on blocked nodes).
- isBlockedTaskManager(ResourceID) - Method in class org.apache.flink.runtime.blocklist.DefaultBlocklistHandler
- isBlockedTaskManager(ResourceID) - Method in class org.apache.flink.runtime.blocklist.NoOpBlocklistHandler
- isBlockingOrBlockingPersistentResultPartition() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
ResultPartitionType.isBlockingOrBlockingPersistentResultPartition()is used to judge whether it is the specifiedResultPartitionType.BLOCKINGorResultPartitionType.BLOCKING_PERSISTENTresultPartitionType. - isBlockingUpstream() - Method in enum org.apache.flink.runtime.io.network.buffer.Buffer.DataType
- isBlocklistEnabled(Configuration) - Static method in class org.apache.flink.runtime.blocklist.BlocklistUtils
- isBounded() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
Whether this partition uses a limited number of (network) buffers or not.
- isBroadcast() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
Whether the resultPartition is a broadcast edge.
- isBroadcast() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
- isBroadcast() - Method in interface org.apache.flink.runtime.executiongraph.IntermediateResultInfo
-
Whether it is a broadcast result.
- isBroadcast() - Method in interface org.apache.flink.runtime.io.network.api.writer.ChannelSelector
-
Returns whether the channel selector always selects all the output channels.
- isBroadcast() - Method in class org.apache.flink.runtime.io.network.api.writer.RoundRobinChannelSelector
- isBroadcast() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
- isBroadcast() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Gets whether the edge is broadcast edge.
- isBroadcast() - Method in class org.apache.flink.runtime.operators.shipping.OutputEmitter
- isBroadcast() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.AllToAllBlockingResultInfo
- isBroadcast() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.PointwiseBlockingResultInfo
- isBroadcast() - Method in class org.apache.flink.runtime.shuffle.PartitionDescriptor
- isBroadcast() - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
- isBroadcast() - Method in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
- isBuffer() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileSegment
- isBuffer() - Method in enum org.apache.flink.runtime.io.network.buffer.Buffer.DataType
- isBuffer() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Returns whether this buffer represents a buffer or an event.
- isBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
- isBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- isBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- isBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- isBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- isBuffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
- isBufferConsumed() - Method in enum org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
- isBytesReadComplete() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- isBytesWrittenComplete() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- isCached() - Method in class org.apache.flink.streaming.api.transformations.CacheTransformation
- isCanceled() - Method in class org.apache.flink.runtime.heartbeat.DefaultHeartbeatMonitor
- isCanceled() - Method in class org.apache.flink.runtime.registration.RetryingRegistration
-
Checks if the registration was canceled.
- isCanceled() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- isCanceledOrFailed() - Method in class org.apache.flink.runtime.taskmanager.Task
-
Checks whether the task has failed, is canceled, or is being canceled at the moment.
- isCanceledOrStopped() - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
Deprecated.Checks whether the source has been canceled or stopped.
- isCancelJob() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerRequestBody
- isCancelled() - Method in class org.apache.flink.runtime.state.DoneFuture
- isCancelled() - Method in interface org.apache.flink.streaming.runtime.tasks.StreamTaskCancellationContext
-
Find out whether the
StreamTaskthis context belongs to has been cancelled. - isChainable(StreamEdge, StreamGraph) - Static method in class org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator
- isChainEnd() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- isChainingEnabled() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns whether operator chaining is enabled.
- isChainingEnabled() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- isChainingOfOperatorsWithDifferentMaxParallelismEnabled() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
- isChainingOfOperatorsWithDifferentMaxParallelismEnabled() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- isChainStart() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- isChangelogStateBackend(StateBackend) - Static method in class org.apache.flink.runtime.state.StateBackendLoader
- isChangelogStateBackendEnabled() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns whether the state changelog is enabled for this ExecutionGraph.
- isChangelogStateBackendEnabled() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
- isChangelogStateBackendEnabled() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- isChangelogStateBackendEnabled() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
- isChangelogStateBackendEnabled() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Gets the enable status of change log for state backend.
- isChangelogStateBackendEnabled(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- isCheckpoint() - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
- isCheckpointingEnabled() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Checks if the checkpointing was enabled for this job graph.
- isCheckpointingEnabled() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
- isCheckpointingEnabled() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Checks whether checkpointing is enabled.
- isCheckpointingEnabled() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- isCheckpointingEnabled() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
-
Returns true if checkpointing is enabled for the running job.
- isCheckpointingEnabled(JobGraph) - Static method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraphBuilder
- isCheckpointPending() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
- isCheckpointPending() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierTracker
- isCheckpointPending() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
- isCleanupTime(W, long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Returns
trueif the given time is the cleanup time for the given window. - isClosed - Variable in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- isClosed() - Method in class org.apache.flink.runtime.blob.BlobClient
- isClosed() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
- isClosed() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
- isClosed() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
- isClosed() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
-
Checks whether the channel has been closed.
- isClosed() - Method in class org.apache.flink.runtime.io.disk.iomanager.RequestQueue
-
Checks whether this request queue is closed.
- isClosed() - Method in class org.apache.flink.runtime.io.disk.iomanager.SynchronousFileIOChannel
- isClosed() - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
- isClosed() - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
- isClosed() - Method in class org.apache.flink.runtime.operators.sort.ExternalSorter
- isClosed() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
- isClosed() - Method in class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
- isClosed() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
- isClosed() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
-
Checks whether the stream is closed.
- isClosed() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
- isClosed() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- isClosed() - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
- isClosed() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- isClosed() - Method in class org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper
-
Checks if the wrapped operator has been closed.
- isCompacted() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
- isCompatibleWith(SecurityConfiguration) - Method in class org.apache.flink.runtime.security.contexts.HadoopSecurityContextFactory
- isCompatibleWith(SecurityConfiguration) - Method in class org.apache.flink.runtime.security.contexts.NoOpSecurityContextFactory
- isCompatibleWith(SecurityConfiguration) - Method in interface org.apache.flink.runtime.security.contexts.SecurityContextFactory
-
Check if this factory is compatible with the security configuration.
- isComplete() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetEntry
- isComplete() - Method in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator.PendingStatsRequest
- isCompleted() - Method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
-
Returns whether the checkpoint has completed successfully.
- isCompleted() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
- isCompressed() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
- isCompressed() - Method in class org.apache.flink.runtime.io.network.buffer.BufferHeader
- isCompressed() - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- isCompressed() - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- isCompressed() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- isCompressed() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- isConcurrentExecutionAttemptsSupported() - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator.Context
-
Gets that whether the coordinator supports an execution vertex to have multiple concurrent running execution attempts.
- isConnected() - Method in class org.apache.flink.runtime.blob.BlobClient
- isConnected() - Method in class org.apache.flink.runtime.jobmaster.slotpool.AbstractServiceConnectionManager
- isConnected() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
- isConnected() - Method in interface org.apache.flink.runtime.taskexecutor.JobTable.Job
-
Returns
trueif the job is connected to a JobManager. - isConnectionInfoPath(String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
- isConnectionReuseEnabled() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- isConsumableBasedOnFinishedProducers(ConsumedPartitionGroup) - Method in class org.apache.flink.runtime.scheduler.strategy.AllFinishedInputConsumableDecider
- isConsumableBasedOnFinishedProducers(ConsumedPartitionGroup) - Method in class org.apache.flink.runtime.scheduler.strategy.DefaultInputConsumableDecider
- isConsumableBasedOnFinishedProducers(ConsumedPartitionGroup) - Method in interface org.apache.flink.runtime.scheduler.strategy.InputConsumableDecider
-
Determining whether the consumed partition group is consumable based on finished producers.
- isConsumableBasedOnFinishedProducers(ConsumedPartitionGroup) - Method in class org.apache.flink.runtime.scheduler.strategy.PartialFinishedInputConsumableDecider
- isConverged(int, LongValue) - Method in class org.apache.flink.runtime.iterative.convergence.WorksetEmptyConvergenceCriterion
- isDataAvailable() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
-
Returns true if there is new data available for reading.
- isDataAvailable() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition.BufferAndBacklog
- isDefaultActionAvailable() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
- isDefaultReference() - Method in class org.apache.flink.runtime.state.CheckpointStorageLocationReference
-
Returns true, if this object is the default reference.
- isDefaultVersion() - Method in interface org.apache.flink.runtime.rest.versioning.RestAPIVersion
-
Returns whether this version is the default REST API version.
- isDefaultVersion() - Method in enum org.apache.flink.runtime.rest.versioning.RuntimeRestAPIVersion
-
Returns whether this version is the default REST API version.
- isDeleted() - Method in class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFile
- isDestroyed() - Method in class org.apache.flink.runtime.io.disk.BatchShuffleReadBufferPool
- isDestroyed() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
Checks whether this buffer pool has been destroyed.
- isDestroyed() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
Returns whether the buffer provider has been destroyed.
- isDestroyed() - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
- isDestroyed() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
- isDeterministic() - Method in class org.apache.flink.runtime.entrypoint.DeterminismEnvelope
- isDirect() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- isDiscarded - Variable in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator.PendingStatsRequest
- isDiscarded() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
-
Returns whether the checkpoint has been discarded.
- isDiscarded() - Method in class org.apache.flink.runtime.checkpoint.filemerging.LogicalFile
- isDiscarded() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.CompletedCheckpointStatistics
- isDisposed() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
- isDone() - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStatePendingResult
- isDone() - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter.ChannelStateWriteResult
- isDone() - Method in class org.apache.flink.runtime.state.DoneFuture
- isDynamic() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- isDynamic() - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
- isDynamic() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
- isDynamic() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- isDynamicParallelism() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- isElementLate(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Decide if a record is currently late, based on current watermark and allowed lateness.
- isEmpty() - Method in class org.apache.flink.runtime.asyncprocessing.AbstractStateIterator
- isEmpty() - Method in interface org.apache.flink.runtime.asyncprocessing.StateRequestContainer
-
Returns whether the container is empty.
- isEmpty() - Method in class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFilePool
-
Return whether the pool is empty or not.
- isEmpty() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- isEmpty() - Method in class org.apache.flink.runtime.io.network.partition.DeduplicatedQueue
- isEmpty() - Method in class org.apache.flink.runtime.io.network.partition.PartitionRequestListenerManager
- isEmpty() - Method in class org.apache.flink.runtime.io.network.partition.PrioritizedDeque
-
Returns true if there are no elements.
- isEmpty() - Method in class org.apache.flink.runtime.jobmaster.event.FileSystemJobEventStore
- isEmpty() - Method in interface org.apache.flink.runtime.jobmaster.event.JobEventStore
-
Returns whether the store is empty.
- isEmpty() - Method in class org.apache.flink.runtime.jobmaster.SerializedInputSplit
- isEmpty() - Method in class org.apache.flink.runtime.leaderelection.LeaderInformation
- isEmpty() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
Checks whether the buffer is empty.
- isEmpty() - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Checks whether the buffer is empty.
- isEmpty() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
Checks whether the buffer is empty.
- isEmpty() - Method in class org.apache.flink.runtime.rest.messages.ConfigurationInfo
- isEmpty() - Method in class org.apache.flink.runtime.scheduler.adaptive.allocator.JobAllocationsInformation
- isEmpty() - Method in class org.apache.flink.runtime.scheduler.strategy.ConsumedPartitionGroup
- isEmpty() - Method in class org.apache.flink.runtime.scheduler.strategy.ConsumerVertexGroup
- isEmpty() - Method in class org.apache.flink.runtime.state.ChainedStateHandle
-
Check if there are any states handles present.
- isEmpty() - Method in class org.apache.flink.runtime.state.changelog.SequenceNumberRange.GenericSequenceNumberRange
- isEmpty() - Method in interface org.apache.flink.runtime.state.changelog.SequenceNumberRange
- isEmpty() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
- isEmpty() - Method in class org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
- isEmpty() - Method in class org.apache.flink.runtime.state.heap.StateMap
-
Returns whether this
StateMapis empty. - isEmpty() - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Returns whether this
StateTableis empty. - isEmpty() - Method in interface org.apache.flink.runtime.state.InternalPriorityQueue
-
Check if the set contains any elements.
- isEmpty() - Method in class org.apache.flink.runtime.state.v2.AbstractMapState
- isEmpty() - Method in class org.apache.flink.runtime.state.v2.adaptor.CompleteStateIterator
- isEmpty() - Method in class org.apache.flink.runtime.state.v2.adaptor.MapStateAdaptor
- isEmpty() - Method in class org.apache.flink.runtime.taskexecutor.DefaultJobTable
- isEmpty() - Method in interface org.apache.flink.runtime.taskexecutor.JobTable
-
Returns
trueif the job table does not contain any jobs. - isEmpty() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
- isEmpty() - Method in class org.apache.flink.runtime.util.BooleanArrayList
- isEmpty() - Method in class org.apache.flink.runtime.util.IntArrayList
- isEmpty() - Method in class org.apache.flink.runtime.util.LongArrayList
- isEmpty() - Method in class org.apache.flink.runtime.util.ResourceCounter
-
Checks whether the resource counter is empty.
- isEmpty() - Method in class org.apache.flink.streaming.runtime.watermarkstatus.HeapPriorityQueue
- isEnableCheckpointsAfterTasksFinish() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
- isEnableCheckpointsAfterTasksFinish() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- isEnabled() - Method in class org.apache.flink.runtime.state.metrics.LatencyTrackingStateConfig
- isEnabled() - Method in class org.apache.flink.runtime.throughput.BufferDebloatConfiguration
- isEndOfSuperstep() - Method in class org.apache.flink.runtime.iterative.task.SyncEventHandler
- isEvent() - Method in enum org.apache.flink.runtime.io.network.buffer.Buffer.DataType
- isEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
- isEventAvailable() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition.BufferAndBacklog
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
- isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
-
Returns
trueif elements are assigned to windows based on event time,falseotherwise. - isExactlyOnce() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
- isExactlyOnceCheckpointMode() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- isExactlyOnceMode() - Method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
- isExisting() - Method in class org.apache.flink.runtime.persistence.IntegerResourceVersion
- isExisting() - Method in interface org.apache.flink.runtime.persistence.ResourceVersion
-
Check whether the state handle is existing.
- isExisting() - Method in class org.apache.flink.runtime.persistence.StringResourceVersion
- isExternalizedCheckpointsEnabled() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Returns whether checkpoints should be persisted externally.
- isExtremal(Comparable<R>, R) - Method in class org.apache.flink.streaming.api.functions.aggregation.Comparator
- isFailed() - Method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
-
Returns whether the checkpoint has failed.
- isFailing() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- isFileMerged() - Method in class org.apache.flink.runtime.state.PlaceholderStreamStateHandle
- isFileMergingHandle(StreamStateHandle) - Static method in interface org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager
- isFileUploadRoute(String) - Method in class org.apache.flink.runtime.rest.handler.router.MultipartRoutes
-
Returns
trueif the handler at the providedrequestUriendpoint accepts file uploads. - isFinalState() - Method in enum org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestState
- isFinished - Variable in class org.apache.flink.runtime.io.network.partition.SortBuffer
-
Whether this sort buffer is finished.
- isFinished() - Method in class org.apache.flink.runtime.checkpoint.FinishedOperatorSubtaskState
- isFinished() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
- isFinished() - Method in class org.apache.flink.runtime.executiongraph.Execution
- isFinished() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- isFinished() - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
- isFinished() - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
-
Returns whether the reader has consumed the input.
- isFinished() - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
- isFinished() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
- isFinished() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
-
Checks whether the
BufferBuilderhas already been finished. - isFinished() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
- isFinished() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- isFinished() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
- isFinished() - Method in interface org.apache.flink.runtime.io.network.partition.DataBuffer
-
Whether this
DataBufferis finished or not. - isFinished() - Method in class org.apache.flink.runtime.io.network.partition.HashBasedDataBuffer
- isFinished() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- isFinished() - Method in class org.apache.flink.runtime.io.network.partition.SortBuffer
- isFinished() - Method in interface org.apache.flink.runtime.io.PullingAsyncDataInput
- isFinished() - Method in class org.apache.flink.runtime.rest.handler.async.OperationResult
- isFinished() - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
- isFinished() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
- isFinished() - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
-
Returns whether all
CheckpointCommittableManagercurrently hold by the collector are either committed or failed. - isFire() - Method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
- isForceUnalignedCheckpoints() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Checks whether unaligned checkpoints are forced, despite iteration feedback.
- isForceUnalignedCheckpoints() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns whether unaligned checkpoints are force-enabled.
- isForward() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Gets whether the edge is forward edge.
- isFull() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
- isFullRecord() - Method in enum org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
- isFullyAcknowledged() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
- isFullyFinished() - Method in class org.apache.flink.runtime.checkpoint.FullyFinishedOperatorState
- isFullyFinished() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- isGlobal() - Method in class org.apache.flink.runtime.scheduler.exceptionhistory.ExceptionHistoryEntry
- isGlobalFailure() - Method in class org.apache.flink.runtime.executiongraph.failover.FailureHandlingResult
-
Checks if this failure was a global failure, i.e., coming from a "safety net" failover that involved all tasks and should reset also components like the coordinators.
- isGloballyTerminated() - Method in exception org.apache.flink.runtime.client.DuplicateJobSubmissionException
-
Checks whether the duplicate job has already been finished.
- isGraphContainingLoops() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- isGuaranteedReclaimable() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemorySpec
- isHadoopCommonOnClasspath(ClassLoader) - Static method in class org.apache.flink.runtime.hadoop.HadoopDependency
- isHasMail() - Method in class org.apache.flink.runtime.asyncprocessing.BatchCallbackRunner
- isHighAvailabilityModeActivated(Configuration) - Static method in enum org.apache.flink.runtime.jobmanager.HighAvailabilityMode
-
Returns true if the defined recovery mode supports high availability.
- isHistoryServer() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration.Features
- isHybridResultPartition() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
ResultPartitionType.isHybridResultPartition()is used to judge whether it is the specifiedResultPartitionType.HYBRID_FULLorResultPartitionType.HYBRID_SELECTIVEresultPartitionType. - isIdentity() - Method in class org.apache.flink.runtime.checkpoint.InflightDataRescalingDescriptor.InflightDataGateOrPartitionRescalingDescriptor
- isIdentity() - Method in class org.apache.flink.runtime.checkpoint.RescaleMappings
- isIdle() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerRegistration
- isIdle() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerInfo
-
Check whether this task manager is idle.
- isIdle() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
- isIdle() - Method in class org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
- isImmutableType() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
- isImmutableType() - Method in class org.apache.flink.runtime.state.JavaSerializer
- isImmutableType() - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
- isImmutableType() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
- isImmutableType() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
- isImmutableType() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
- isImmutableType() - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
- isImmutableType() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
- isImmutableType() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
- isImmutableType() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
- isIncremental() - Method in class org.apache.flink.runtime.shuffle.EmptyShuffleMasterSnapshot
- isIncremental() - Method in interface org.apache.flink.runtime.shuffle.ShuffleMasterSnapshot
-
Returns whether the snapshot is incremental.
- isInitializationFailure() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunnerResult
- isInitialized() - Method in class org.apache.flink.runtime.dispatcher.cleanup.CheckpointResourcesCleanupRunner
- isInitialized() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- isInitialized() - Method in interface org.apache.flink.runtime.jobmaster.JobManagerRunner
-
Flag indicating if the JobManagerRunner has been initialized.
- isInitialized() - Method in class org.apache.flink.runtime.jobmaster.JobMasterServiceLeadershipRunner
- isInitializedAndRunning() - Method in class org.apache.flink.runtime.jobmaster.DefaultJobMasterServiceProcess
- isInitializedAndRunning() - Method in interface org.apache.flink.runtime.jobmaster.JobMasterServiceProcess
-
True iff the
JobMasterServicehas been initialized and is running. - isInitializedAndRunning() - Method in enum org.apache.flink.runtime.jobmaster.JobMasterServiceProcess.WaitingForLeadership
- isInMemory() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
Checks whether this partition is in memory or spilled.
- isInProgress() - Method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
-
Returns whether the checkpoint is in progress.
- isInputAsynchronouslyMaterialized(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- isInputCached(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- isInputConsumable(SchedulingExecutionVertex, Set<ExecutionVertexID>, Map<ConsumedPartitionGroup, Boolean>) - Method in class org.apache.flink.runtime.scheduler.strategy.AllFinishedInputConsumableDecider
- isInputConsumable(SchedulingExecutionVertex, Set<ExecutionVertexID>, Map<ConsumedPartitionGroup, Boolean>) - Method in class org.apache.flink.runtime.scheduler.strategy.DefaultInputConsumableDecider
- isInputConsumable(SchedulingExecutionVertex, Set<ExecutionVertexID>, Map<ConsumedPartitionGroup, Boolean>) - Method in interface org.apache.flink.runtime.scheduler.strategy.InputConsumableDecider
-
Determining whether the input of an execution vertex is consumable.
- isInputConsumable(SchedulingExecutionVertex, Set<ExecutionVertexID>, Map<ConsumedPartitionGroup, Boolean>) - Method in class org.apache.flink.runtime.scheduler.strategy.PartialFinishedInputConsumableDecider
- isInputFinished(int) - Method in class org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
- isInputResettable(int) - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
- isInputResettable(int) - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
- isInputResettable(int) - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
- isInputResettable(int) - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
- isInputResettable(int) - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
- isInputResettable(int) - Method in interface org.apache.flink.runtime.operators.ResettableDriver
- isInputSelected(int) - Method in class org.apache.flink.streaming.api.operators.InputSelection
-
Tests if the input specified by
inputIdis selected. - isInputTypeConfigurable() - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
- isInputTypeConfigurable() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
-
If the stream operator need to be configured with the data type they will operate on.
- isInputVertex() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- isInternalSorterSupported() - Method in class org.apache.flink.streaming.api.operators.OperatorAttributes
-
Returns true iff the operator uses an internal sorter to sort inputs by key.
- isInternalSorterSupported() - Method in class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
- isInternalSorterSupported() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
- isInternalSorterSupported() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
- isIterative() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- isIterativeInputGate(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- isKeyGroupAlreadyFinished(int) - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
-
Returns true if the key group is already completely written and immutable.
- isKeyGroupAlreadyStarted(int) - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
-
Returns true, if the key group with the given id was already started.
- isKeyType() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
- isKeyType() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
- isLatencyMarker() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Checks whether this element is a latency marker.
- isLatencyMeasurementSetup() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
-
Indicates if latency measurement has been setup.
- isLatencyMeasurementStarted() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
-
Indicates if latency mesurement has been started.
- isLeader() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionDriver
- isLegacySource() - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
- isLegacySource() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
- isLocalBackupEnabled() - Method in class org.apache.flink.runtime.state.LocalRecoveryConfig
- isLocalCommunicationOnly() - Method in class org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
- isLocalRecoveryEnabled() - Method in class org.apache.flink.runtime.state.LocalRecoveryConfig
- isLocalRecoveryOrLocalBackupEnabled() - Method in class org.apache.flink.runtime.state.LocalRecoveryConfig
- isLocalTo(ResourceID) - Method in class org.apache.flink.runtime.shuffle.NettyShuffleDescriptor
- isLoginPossible(boolean) - Method in class org.apache.flink.runtime.security.token.hadoop.KerberosLoginProvider
- isMailboxLoopRunning() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
- isMailboxLoopRunning() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- isMailboxThread() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
Check if the current thread is the mailbox thread.
- isMailboxThread() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
Check if the current thread is the mailbox thread.
- isMailboxThread() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
- isMandatory() - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Returns whether this parameter must be resolved for the request.
- isMatching(ResourceProfile) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Check whether required resource profile can be matched.
- isMatchingRequirement(ResourceProfile) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerSlotInformation
-
Returns true if the required
ResourceProfilecan be fulfilled by this slot. - isMaterializing() - Method in enum org.apache.flink.runtime.operators.DamBehavior
-
Checks whether this enumeration represents some form of materialization, either with a full dam or without.
- isMaterializing() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
- isMaxParallelismDecided() - Method in class org.apache.flink.runtime.jobgraph.forwardgroup.ForwardGroup
- isMeasuring() - Method in class org.apache.flink.runtime.metrics.TimerGauge
- isModified(ExecutionVertexVersion) - Method in class org.apache.flink.runtime.scheduler.ExecutionVertexVersioner
- isMoreSubpartitionSwitchable() - Method in class org.apache.flink.runtime.io.network.partition.RoundRobinSubpartitionSelector
- isMoreSubpartitionSwitchable() - Method in interface org.apache.flink.runtime.io.network.partition.SubpartitionSelector
-
Whether the invoker can get a different subpartition in the next invocation of
SubpartitionSelector.getNextSubpartitionToConsume(). - isNetworkDetailedMetrics() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- isNetworkStrategy() - Method in enum org.apache.flink.runtime.operators.shipping.ShipStrategyType
- isNewKeyGroup() - Method in class org.apache.flink.runtime.state.heap.HeapKeyValueStateIterator
- isNewKeyGroup() - Method in interface org.apache.flink.runtime.state.KeyValueStateIterator
-
Indicates if current key starts a new key-group, i.e. belong to a different key-group than it's predecessor.
- isNewKeyValueState() - Method in class org.apache.flink.runtime.state.heap.HeapKeyValueStateIterator
- isNewKeyValueState() - Method in interface org.apache.flink.runtime.state.KeyValueStateIterator
-
Indicates if current key starts a new k/v-state, i.e. belong to a different k/v-state than it's predecessor.
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.streaming.api.operators.sortpartition.FixedLengthByteKeyAndValueComparator
- isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.streaming.api.operators.sortpartition.VariableLengthByteKeyAndValueComparator
- isNullOrEmpty(ChainedStateHandle<?>) - Static method in class org.apache.flink.runtime.state.ChainedStateHandle
- isNumberOfPartitionConsumersUndefined() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
- isNumberOfPartitionConsumerUndefined() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
- isNumberOfPartitionConsumerUndefined() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- isNumberOfPartitionConsumerUndefined() - Method in class org.apache.flink.runtime.shuffle.PartitionDescriptor
- isNumberOfPartitionConsumerUndefined(boolean) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- isNumBytesInComplete() - Method in class org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
- isNumBytesOutComplete() - Method in class org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
- isNumRecordsInComplete() - Method in class org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
- isNumRecordsOutComplete() - Method in class org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
- isObjectReuse() - Method in class org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
- isOne() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
- isOpen() - Method in class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFile
- isOriginalAttempt(int) - Method in class org.apache.flink.runtime.executiongraph.SpeculativeExecutionVertex
-
Returns whether the given attempt is the original execution attempt of the execution vertex, i.e. it is created along with the creation of resetting of the execution vertex.
- isOutputOnlyAfterEndOfStream() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- isOutputOnlyAfterEndOfStream() - Method in class org.apache.flink.streaming.api.operators.OperatorAttributes
-
Returns true if and only if the operator only emits records after all its inputs have ended.
- isOutputOnlyAfterEndOfStream() - Method in class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
- isOutputOnlyAfterEndOfStream() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
- isOutputOnlyAfterEndOfStream() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
- isOutputTypeConfigurable() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
- isOutputTypeConfigurable() - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
- isOutputTypeConfigurable() - Method in class org.apache.flink.streaming.api.operators.SourceOperatorFactory
- isOutputTypeConfigurable() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
-
If the stream operator need access to the output type information at
StreamGraphgeneration. - isOutputVertex() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- isOwned() - Method in class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFile
- isOwner(T) - Method in class org.apache.flink.runtime.state.heap.StateMapSnapshot
-
Returns true iff the given state map is the owner of this snapshot object.
- isParallelismConfigured() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- isParallelismDecided() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- isParallelismDecided() - Method in class org.apache.flink.runtime.jobgraph.forwardgroup.ForwardGroup
- isPartialRecord() - Method in enum org.apache.flink.runtime.io.network.buffer.Buffer.DataType
- isPartitionTracked(ResultPartitionID) - Method in class org.apache.flink.runtime.io.network.partition.AbstractPartitionTracker
- isPartitionTracked(ResultPartitionID) - Method in interface org.apache.flink.runtime.io.network.partition.PartitionTracker
-
Returns whether the given partition is being tracked.
- isPeriodicCheckpointingConfigured() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Returns whether periodic checkpointing has been configured.
- isPeriodicCheckpointingStarted() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
- isPersistent() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
- isPipelinedOrPipelinedBoundedResultPartition() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
ResultPartitionType.isPipelinedOrPipelinedBoundedResultPartition()is used to judge whether it is the specifiedResultPartitionType.PIPELINEDorResultPartitionType.PIPELINED_BOUNDEDresultPartitionType. - isPointwise() - Method in interface org.apache.flink.runtime.executiongraph.IntermediateResultInfo
-
Whether it is a pointwise result.
- isPointwise() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.AllToAllBlockingResultInfo
- isPointwise() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.PointwiseBlockingResultInfo
- isPointwise() - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
- isPointwise() - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
- isPointwise() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardForConsecutiveHashPartitioner
- isPointwise() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
- isPointwise() - Method in class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
- isPointwise() - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
- isPointwise() - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
- isPointwise() - Method in class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
- isPointwise() - Method in class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
- isPointwise() - Method in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
- isPostRoute(String) - Method in class org.apache.flink.runtime.rest.handler.router.MultipartRoutes
-
Returns
trueif the handler at the providedrequestUriendpoint accepts POST requests. - isPreFlight() - Method in enum org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- isProcessingBacklog() - Method in class org.apache.flink.runtime.source.event.IsProcessingBacklogEvent
- IsProcessingBacklogEvent - Class in org.apache.flink.runtime.source.event
-
A source event that notify the source operator of the backlog status.
- IsProcessingBacklogEvent(boolean) - Constructor for class org.apache.flink.runtime.source.event.IsProcessingBacklogEvent
- isProducerReadyOrAbortConsumption(PartitionProducerStateProvider.ResponseHandle) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteChannelStateChecker
- isProxyUser(UserGroupInformation) - Static method in class org.apache.flink.runtime.hadoop.HadoopUserUtils
- isPurge() - Method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
- isReadable() - Method in class org.apache.flink.runtime.io.network.partition.PartitionedFile
- isReconsumable() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
- isRecord() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Checks whether this element is a record.
- isRecordAttributes() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Check whether this element is record attributes.
- isRecordsReadComplete() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- isRecordsWrittenComplete() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- isRecovering() - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.BatchJobRecoveryHandler
-
Determines whether the job is recovering.
- isRecovering() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DefaultBatchJobRecoveryHandler
- isRecovering() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DummyBatchJobRecoveryHandler
- isRecycled() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Returns whether this buffer has been recycled or not.
- isRecycled() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
- isRecycled() - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- isRecycled() - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- isRecycled() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- isRecycled() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- isRegionOfVertexFinished(ExecutionVertexID) - Method in class org.apache.flink.runtime.executiongraph.failover.partitionrelease.RegionPartitionGroupReleaseStrategy
- isRegistered(JobID) - Method in class org.apache.flink.runtime.dispatcher.DefaultJobManagerRunnerRegistry
- isRegistered(JobID) - Method in interface org.apache.flink.runtime.dispatcher.JobManagerRunnerRegistry
-
Checks whether a
JobManagerRunneris registered under the givenJobID. - isRegistered(JobID) - Method in class org.apache.flink.runtime.dispatcher.OnMainThreadJobManagerRunnerRegistry
- isRegisteredAsAvailable() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
- isReleaseByScheduler() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
- isReleaseByUpstream() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
- isReleased - Variable in class org.apache.flink.runtime.io.network.partition.SortBuffer
-
Whether this sort buffer is released.
- isReleased() - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
- isReleased() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
- isReleased() - Method in class org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionDirectTransferReader
- isReleased() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- isReleased() - Method in interface org.apache.flink.runtime.io.network.partition.DataBuffer
-
Whether this
DataBufferis released or not. - isReleased() - Method in class org.apache.flink.runtime.io.network.partition.HashBasedDataBuffer
- isReleased() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.TieredStorageResultSubpartitionView
- isReleased() - Method in class org.apache.flink.runtime.io.network.partition.NoOpResultSubpartitionView
- isReleased() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartition
- isReleased() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartitionView
- isReleased() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Whether this partition is released.
- isReleased() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
- isReleased() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
- isReleased() - Method in class org.apache.flink.runtime.io.network.partition.SortBuffer
- isReleased() - Method in class org.apache.flink.runtime.io.network.partition.UnionResultSubpartitionView
- isReleased() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMapSnapshot
- isReleasing() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
- isRequirementEmpty(JobID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.DefaultResourceTracker
- isRequirementEmpty(JobID) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ResourceTracker
-
Returns whether the
ResourceRequirementof the given job is empty. - isResolved() - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Returns whether this parameter has been resolved.
- isResolved() - Method in class org.apache.flink.runtime.rest.messages.MessageParameters
-
Returns whether all mandatory parameters have been resolved.
- isRestored() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns true if this was created for a restored operator, false otherwise.
- isRestored() - Method in interface org.apache.flink.runtime.state.ManagedInitializationContext
-
Returns true, if state was restored from the snapshot of a previous execution.
- isRestored() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
- isRestored() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
-
Returns true if the states provided by this context are restored from a checkpoint/savepoint.
- isRootCause() - Method in class org.apache.flink.runtime.executiongraph.failover.FailureHandlingResult
- isRootCause() - Method in class org.apache.flink.runtime.scheduler.exceptionhistory.FailureHandlingResultSnapshot
- isRunning() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
Checks if the mini cluster was started and is running.
- isRunning() - Method in enum org.apache.flink.runtime.rest.messages.ProfilingInfo.ProfilingStatus
- isRunning() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- isSafeToReuseKVState() - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
-
Whether it's safe to reuse key-values from the state-backend, e.g for the purpose of optimization.
- isSameSlotSharingGroup(StreamNode) - Method in class org.apache.flink.streaming.api.graph.StreamNode
- isSavepoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
-
Returns whether the checkpoint properties describe a standard savepoint.
- isSavepoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointType
- isSavepoint() - Method in class org.apache.flink.runtime.checkpoint.SavepointType
- isSavepoint() - Method in interface org.apache.flink.runtime.checkpoint.SnapshotType
- isSavepoint() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
- isSavepoint() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
- isSegmentFinished() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.PartitionFileWriter.SegmentBufferContext
- isSerializerTypeVariableSized(TypeSerializer<?>) - Static method in class org.apache.flink.runtime.state.CompositeKeySerializationUtils
- isShutdown() - Method in class org.apache.flink.runtime.blob.BlobServer
-
Tests whether the BLOB server has been requested to shut down.
- isShutdown() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
- isShutdown() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
- isShutdown() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Checks whether the MemoryManager has been shut down.
- isShutdown() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
Returns whether this registry has been shutdown.
- isShutdown() - Method in class org.apache.flink.runtime.taskexecutor.KvStateService
- isShutDown - Variable in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator
-
Flag indicating whether the coordinator is still running.
- isShutDown() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
- isSlotAvailableAndFree(AllocationID) - Method in interface org.apache.flink.runtime.scheduler.adaptive.allocator.IsSlotAvailableAndFreeFunction
-
Returns
trueif a slot with the givenAllocationIDis available and free. - IsSlotAvailableAndFreeFunction - Interface in org.apache.flink.runtime.scheduler.adaptive.allocator
-
Functional interface for checking whether a slot is available and free.
- isSlotFree(int) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Check whether the task slot with the given index is free.
- isSlotFree(int) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- isSnapshotCompleted() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
-
Returns
trueif the snapshot is marked as completed. - isSolutionSetUnmanaged() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- isSolutionSetUpdate - Variable in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
- isSSLEnabled() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- isSSLEnabled(Configuration) - Static method in enum org.apache.flink.runtime.webmonitor.history.HistoryServerUtils
- isStableVersion() - Method in interface org.apache.flink.runtime.rest.versioning.RestAPIVersion
-
Returns whether this version is considered stable.
- isStableVersion() - Method in enum org.apache.flink.runtime.rest.versioning.RuntimeRestAPIVersion
-
Returns whether this version is considered stable.
- isStarted() - Method in class org.apache.flink.runtime.resourcemanager.DefaultJobLeaderIdService
-
Checks whether the service has been started.
- isState(State) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- isStateNameAsVariable() - Method in class org.apache.flink.runtime.state.metrics.LatencyTrackingStateConfig
- isStoppable() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns whether the job for this execution graph is stoppable.
- isStoppable() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
- isStoppable() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- isStoppable() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- isStoppable() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- isStreamSource() - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
- isStreamSource() - Method in class org.apache.flink.streaming.api.operators.SourceOperatorFactory
- isStreamSource() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
-
Is this factory for
StreamSource. - isSubpartitionDerivable() - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
Whether the subpartition where an element comes from can be derived from the existing information.
- isSuccess() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunnerResult
- isSuccess() - Method in class org.apache.flink.runtime.jobmaster.JobResult
-
Returns
trueif the job finished successfully. - isSupportChannelStateRecover() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedApproximateSubpartition
- isSupportChannelStateRecover() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartition
- isSupported() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.NonSupportedResourceAllocatorImpl
- isSupported() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ResourceAllocator
-
Whether allocate/release resources are supported.
- isSupportsConcurrentExecutionAttempts() - Method in class org.apache.flink.runtime.executiongraph.SpeculativeExecutionVertex
- isSupportsConcurrentExecutionAttempts() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- isSupportsConcurrentExecutionAttempts() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- isSupportsConcurrentExecutionAttempts() - Method in class org.apache.flink.streaming.api.transformations.LegacySinkTransformation
- isSupportsConcurrentExecutionAttempts() - Method in class org.apache.flink.streaming.api.transformations.PhysicalTransformation
- isSupportsUnalignedCheckpoint() - Method in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
- isSynchronous() - Method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
-
Returns whether the checkpoint properties describe a synchronous savepoint/checkpoint.
- isSynchronous() - Method in class org.apache.flink.runtime.checkpoint.SavepointType
- isTaskDeployedAsFinished() - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
-
Returns whether all the operators of the task are already finished on restoring.
- isTaskDeployedAsFinished() - Method in interface org.apache.flink.runtime.state.TaskStateManager
-
Whether all the operators of the task are finished on restore.
- isTaskDeployedAsFinished() - Method in class org.apache.flink.runtime.state.TaskStateManagerImpl
- isTaskDeployedAsFinished() - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
- isTaskDeployedAsFinished() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- isTaskDeployedAsFinished() - Method in class org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
- isTaskFinished() - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
-
Returns whether all the operators of the task have called finished methods.
- isTerminal() - Method in enum org.apache.flink.runtime.execution.ExecutionState
- isTerminalMode() - Method in enum org.apache.flink.runtime.dispatcher.TriggerSavepointMode
-
Whether the operation will result in a globally terminal job status.
- isTerminalState() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails.CurrentAttempts
- isTerminated() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
- isTerminated() - Method in interface org.apache.flink.streaming.runtime.tasks.TimerService
-
Returns true if the service has been shut down, false otherwise.
- isTimeoutable() - Method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
- isTrackingPartitionsFor(K) - Method in class org.apache.flink.runtime.io.network.partition.AbstractPartitionTracker
- isTrackingPartitionsFor(K) - Method in interface org.apache.flink.runtime.io.network.partition.PartitionTracker
-
Returns whether any partition is being tracked for the given key.
- isTriggering() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
- isTruncated() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.JobExceptionHistory
- isTtlStateSerializer(TypeSerializer<?>) - Static method in class org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
- isTupleType() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
- isTupleType() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
- isTwo() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
- isUnalignedCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
- isUnalignedCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
- isUnalignedCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
- isUnalignedCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
- isUnalignedCheckpointsEnabled() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
- isUnalignedCheckpointsEnabled() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Returns whether unaligned checkpoints are enabled.
- isUnalignedCheckpointsEnabled() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Returns whether unaligned checkpoints are enabled.
- isUnalignedCheckpointsEnabled() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- isUnalignedCheckpointsInterruptibleTimersEnabled() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
- isUnalignedCheckpointsSplittableTimersEnabled() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- isUnclaimed() - Method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
-
Returns whether the checkpoint should be restored in a
RecoveryClaimMode.NO_CLAIMmode. - isUnknown() - Method in interface org.apache.flink.runtime.shuffle.ShuffleDescriptor
-
Returns whether the partition is known and registered with the
ShuffleMasterimplementation. - isUnknown() - Method in class org.apache.flink.runtime.shuffle.UnknownShuffleDescriptor
- isUnrecoverableError(Throwable) - Static method in class org.apache.flink.runtime.executiongraph.failover.ExecutionFailureHandler
- isUsingCustomRawKeyedState() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Indicates whether or not implementations of this class is writing to the raw keyed state streams on snapshots, using
AbstractStreamOperator.snapshotState(StateSnapshotContext). - isUsingCustomRawKeyedState() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
Indicates whether or not implementations of this class is writing to the raw keyed state streams on snapshots, using
AbstractStreamOperatorV2.snapshotState(StateSnapshotContext). - isUsingKeyGroupCompression() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
- isUsingNonBlockingInput() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
- isUsingNonBlockingInput() - Method in interface org.apache.flink.runtime.jobgraph.tasks.TaskInvokable
- isUsingNonBlockingInput() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- isValid() - Method in class org.apache.flink.runtime.state.heap.HeapKeyValueStateIterator
- isValid() - Method in interface org.apache.flink.runtime.state.KeyValueStateIterator
-
Check if the iterator is still valid.
- isValid(K, UUID) - Method in class org.apache.flink.runtime.taskexecutor.slot.DefaultTimerService
- isValid(K, UUID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TimerService
-
Check whether the timeout for the given key and ticket is still valid (not yet unregistered and not yet overwritten).
- isValidAttemptNumber(int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionHistory
- isValidTimeout(JobID, UUID) - Method in class org.apache.flink.runtime.resourcemanager.DefaultJobLeaderIdService
- isValidTimeout(JobID, UUID) - Method in interface org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
Checks whether the given timeoutId for the given jobId is valid or not.
- isValidTimeout(AllocationID, UUID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Check whether the timeout with ticket is valid for the given allocation id.
- isValidTimeout(AllocationID, UUID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- isVertexNameIncludeIndexPrefix() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- isWatermark() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Checks whether this element is a watermark.
- isWatermarkAligned - Variable in class org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve.SubpartitionStatus
- isWatermarkStatus() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
-
Checks whether this element is a watermark status.
- isWebCancelEnabled() - Method in class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
- isWebCancelEnabled() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration.Features
- isWebRescaleEnabled() - Method in class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
- isWebRescaleEnabled() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration.Features
- isWebSubmitEnabled() - Method in class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
- isWebSubmitEnabled() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration.Features
- isWindowLate(W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Returns
trueif the watermark is after the end timestamp plus the allowed lateness of the given window. - isWorksetIteration - Variable in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
- isWorksetUpdate - Variable in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
- isWritable() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- isWritable(int) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- isZkSaslDisable() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
- isZooKeeperRecoveryMode(Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Returns whether
HighAvailabilityMode.ZOOKEEPERis configured. - IterableStateSnapshot<K,N,S> - Interface in org.apache.flink.runtime.state
-
A
StateSnapshotthat can return an iterator over all containedStateEntries. - ITERATION_SINK_NAME_PREFIX - Static variable in class org.apache.flink.streaming.api.graph.StreamGraph
- ITERATION_SOURCE_NAME_PREFIX - Static variable in class org.apache.flink.streaming.api.graph.StreamGraph
- IterationAggregatorBroker - Class in org.apache.flink.runtime.iterative.concurrent
- IterationAggregatorBroker() - Constructor for class org.apache.flink.runtime.iterative.concurrent.IterationAggregatorBroker
- IterationEventWithAggregators - Class in org.apache.flink.runtime.iterative.event
-
Base class for iteration
TaskEventtransmitting operator aggregators. - IterationEventWithAggregators() - Constructor for class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
- IterationEventWithAggregators(String, Value) - Constructor for class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
- IterationEventWithAggregators(Map<String, Aggregator<?>>) - Constructor for class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
- IterationHeadTask<X,Y,S extends org.apache.flink.api.common.functions.Function,OT> - Class in org.apache.flink.runtime.iterative.task
-
The head is responsible for coordinating an iteration and can run a
Driverinside. - IterationHeadTask(Environment) - Constructor for class org.apache.flink.runtime.iterative.task.IterationHeadTask
-
Create an Invokable task and set its environment.
- iterationIdCounter - Static variable in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
- IterationIntermediateTask<S extends org.apache.flink.api.common.functions.Function,OT> - Class in org.apache.flink.runtime.iterative.task
-
An intermediate iteration task, which runs a
Driverinside. - IterationIntermediateTask(Environment) - Constructor for class org.apache.flink.runtime.iterative.task.IterationIntermediateTask
-
Create an Invokable task and set its environment.
- IterationSynchronizationSinkTask - Class in org.apache.flink.runtime.iterative.task
-
The task responsible for synchronizing all iteration heads, implemented as an output task.
- IterationSynchronizationSinkTask(Environment) - Constructor for class org.apache.flink.runtime.iterative.task.IterationSynchronizationSinkTask
-
Create an Invokable task and set its environment.
- IterationTailTask<S extends org.apache.flink.api.common.functions.Function,OT> - Class in org.apache.flink.runtime.iterative.task
-
An iteration tail, which runs a driver inside.
- IterationTailTask(Environment) - Constructor for class org.apache.flink.runtime.iterative.task.IterationTailTask
-
Create an Invokable task and set its environment.
- iterativeBroadcastInputs - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The indices of the iterative broadcast inputs.
- iterativeInputs - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The indices of the iterative inputs.
- iterator - Variable in class org.apache.flink.streaming.api.operators.collect.ClientAndIterator
- iterator() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- iterator() - Method in class org.apache.flink.runtime.executiongraph.failover.partitionrelease.ConsumerRegionGroupExecutionView
- iterator() - Method in class org.apache.flink.runtime.io.network.partition.PrioritizedDeque
- iterator() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable
- iterator() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
- iterator() - Method in class org.apache.flink.runtime.operators.util.metrics.CountingIterable
- iterator() - Method in class org.apache.flink.runtime.scheduler.strategy.ConsumedPartitionGroup
- iterator() - Method in class org.apache.flink.runtime.scheduler.strategy.ConsumerVertexGroup
- iterator() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
-
Returns an iterator over the elements in this queue.
- iterator() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
- iterator() - Method in class org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
- iterator() - Method in class org.apache.flink.runtime.state.heap.StateTable
- iterator() - Method in class org.apache.flink.runtime.state.HeapBroadcastState
- iterator() - Method in interface org.apache.flink.runtime.state.InternalPriorityQueue
-
Iterator over all elements, no order guaranteed.
- iterator() - Method in class org.apache.flink.runtime.state.KeyGroupRange
- iterator() - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
- iterator() - Method in class org.apache.flink.runtime.state.v2.AbstractMapState
- iterator() - Method in class org.apache.flink.runtime.state.v2.adaptor.MapStateAdaptor
- iterator() - Method in class org.apache.flink.runtime.taskexecutor.SlotReport
- iterator() - Method in class org.apache.flink.runtime.util.BoundedFIFOQueue
-
Returns the
BoundedFIFOQueue'sIterator. - iterator() - Method in class org.apache.flink.runtime.util.EmptyIterator
- iterator() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator.ValuesIterator
- iterator() - Method in class org.apache.flink.runtime.util.NonReusingMutableToRegularIteratorWrapper
- iterator() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator.ValuesIterator
- iterator() - Method in class org.apache.flink.runtime.util.ReusingMutableToRegularIteratorWrapper
- iterator() - Method in class org.apache.flink.runtime.util.SingleElementIterator
- iterator(int) - Method in interface org.apache.flink.runtime.state.KeyGroupPartitioner.PartitioningResult
- ITERATOR_LOADING - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Continuously load elements for one iterator.
- iterator1 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
- iterator2 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
- ITIMER - org.apache.flink.runtime.rest.messages.ProfilingInfo.ProfilingMode
J
- JaasModule - Class in org.apache.flink.runtime.security.modules
-
Responsible for installing a process-wide JAAS configuration.
- JaasModule(SecurityConfiguration) - Constructor for class org.apache.flink.runtime.security.modules.JaasModule
- JaasModuleFactory - Class in org.apache.flink.runtime.security.modules
-
A
SecurityModuleFactoryforJaasModule. - JaasModuleFactory() - Constructor for class org.apache.flink.runtime.security.modules.JaasModuleFactory
- JACKSON_FACTORY - Static variable in class org.apache.flink.runtime.rest.handler.legacy.JsonFactory
-
The singleton Jackson JSON factory.
- jarFileNames - Variable in class org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody
- JavaSerializer<T extends Serializable> - Class in org.apache.flink.runtime.state
-
A
TypeSerializerthat uses Java serialization. - JavaSerializer() - Constructor for class org.apache.flink.runtime.state.JavaSerializer
- JavaSerializer.JavaSerializerSnapshot<T extends Serializable> - Class in org.apache.flink.runtime.state
-
Serializer configuration snapshot for compatibility and format evolution.
- JavaSerializerSnapshot() - Constructor for class org.apache.flink.runtime.state.JavaSerializer.JavaSerializerSnapshot
- JMTMRegistrationRejection - Class in org.apache.flink.runtime.jobmaster
-
Message indicating a registration rejection from the
JobMasterfor theTaskExecutor. - JMTMRegistrationRejection(String) - Constructor for class org.apache.flink.runtime.jobmaster.JMTMRegistrationRejection
- JMTMRegistrationSuccess - Class in org.apache.flink.runtime.jobmaster
-
Message indicating a successful
JobMasterandTaskExecutorregistration. - JMTMRegistrationSuccess(ResourceID) - Constructor for class org.apache.flink.runtime.jobmaster.JMTMRegistrationSuccess
- JOB_FAILOVER_REGION - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- JOB_GRAPH_FILE_PATH - Static variable in class org.apache.flink.runtime.entrypoint.component.FileJobGraphRetriever
- JOB_MANAGER_ENV_REST_PATH - Static variable in class org.apache.flink.runtime.rest.messages.JobManagerEnvironmentHeaders
- JOB_MANAGER_NAME - Static variable in class org.apache.flink.runtime.jobmaster.JobMaster
-
Default names for Flink's distributed components.
- JobAccumulator() - Constructor for class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.JobAccumulator
- JobAccumulatorsHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Request handler that returns the aggregated accumulators of a job.
- JobAccumulatorsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, JobAccumulatorsInfo, JobAccumulatorsMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobAccumulatorsHandler
- JobAccumulatorsHeaders - Class in org.apache.flink.runtime.rest.messages
-
Message headers for the
JobAccumulatorsHandler. - JobAccumulatorsInfo - Class in org.apache.flink.runtime.rest.messages
-
Response type of the
JobAccumulatorsHandler. - JobAccumulatorsInfo(List<JobAccumulatorsInfo.JobAccumulator>, List<JobAccumulatorsInfo.UserTaskAccumulator>, Map<String, SerializedValue<OptionalFailure<Object>>>) - Constructor for class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
- JobAccumulatorsInfo.JobAccumulator - Class in org.apache.flink.runtime.rest.messages
-
Json serializer for the
JobAccumulatorsInfo. - JobAccumulatorsInfo.UserTaskAccumulator - Class in org.apache.flink.runtime.rest.messages
-
Json serializer for the
JobAccumulatorsInfo. - JobAccumulatorsMessageParameters - Class in org.apache.flink.runtime.rest.messages
-
Request parameter for job accumulator's handler
JobAccumulatorsHandler. - JobAccumulatorsMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.JobAccumulatorsMessageParameters
- JobAllocationsInformation - Class in org.apache.flink.runtime.scheduler.adaptive.allocator
-
Information about allocations of Job Vertices.
- JobAllocationsInformation.VertexAllocationInformation - Class in org.apache.flink.runtime.scheduler.adaptive.allocator
-
Information about the allocations of a single Job Vertex.
- JobCancellationException - Exception in org.apache.flink.runtime.client
-
An exception which is thrown by the JobClient if a job is aborted as a result of a user cancellation.
- JobCancellationException(JobID, String, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobCancellationException
- JobCancellationFailedException - Exception in org.apache.flink.runtime.dispatcher
-
JobCancellationFailedExceptionis thrown if the cancellation of a job failed. - JobCancellationFailedException(String) - Constructor for exception org.apache.flink.runtime.dispatcher.JobCancellationFailedException
- JobCancellationFailedException(String, Throwable) - Constructor for exception org.apache.flink.runtime.dispatcher.JobCancellationFailedException
- JobCancellationHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Request handler for the cancel and stop request.
- JobCancellationHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, EmptyResponseBody, JobCancellationMessageParameters>, TerminationModeQueryParameter.TerminationMode) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobCancellationHandler
- JobCancellationHeaders - Class in org.apache.flink.runtime.rest.messages
-
Message headers for the
JobCancellationHandler. - JobCancellationMessageParameters - Class in org.apache.flink.runtime.rest.messages
-
Parameters for job related REST handlers.
- JobCancellationMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.JobCancellationMessageParameters
- JobCheckpointingSettings - Class in org.apache.flink.runtime.jobgraph.tasks
-
The JobCheckpointingSettings are attached to a JobGraph and describe the settings for the asynchronous checkpoints of the JobGraph, such as interval.
- JobCheckpointingSettings(CheckpointCoordinatorConfiguration, SerializedValue<StateBackend>) - Constructor for class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
- JobCheckpointingSettings(CheckpointCoordinatorConfiguration, SerializedValue<StateBackend>, TernaryBoolean, SerializedValue<CheckpointStorage>, SerializedValue<MasterTriggerRestoreHook.Factory[]>) - Constructor for class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
- JobClientHeartbeatHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Receive the heartbeat from the client.
- JobClientHeartbeatHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<JobClientHeartbeatRequestBody, EmptyResponseBody, JobClientHeartbeatParameters>) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobClientHeartbeatHandler
- JobClientHeartbeatHeaders - Class in org.apache.flink.runtime.rest.messages
-
Message headers for the
JobClientHeartbeatHandler. - JobClientHeartbeatParameters - Class in org.apache.flink.runtime.rest.messages
-
The parameter when the client reports heartbeat.
- JobClientHeartbeatParameters() - Constructor for class org.apache.flink.runtime.rest.messages.JobClientHeartbeatParameters
- JobClientHeartbeatRequestBody - Class in org.apache.flink.runtime.rest.messages
-
RequestBodyto report heartbeat for client. - JobClientHeartbeatRequestBody(long) - Constructor for class org.apache.flink.runtime.rest.messages.JobClientHeartbeatRequestBody
- JobClusterEntrypoint - Class in org.apache.flink.runtime.entrypoint
-
Deprecated.Per-job mode has been deprecated in Flink 1.15 and will be removed in the future. Please use application mode instead.
- JobClusterEntrypoint(Configuration) - Constructor for class org.apache.flink.runtime.entrypoint.JobClusterEntrypoint
-
Deprecated.
- JobConfigHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Handler serving the job configuration.
- JobConfigHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, JobConfigInfo, JobMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobConfigHandler
- JobConfigHeaders - Class in org.apache.flink.runtime.rest.messages
-
Message headers for the
JobConfigHandler. - JobConfigInfo - Class in org.apache.flink.runtime.rest.messages
-
Response type of the
JobConfigHandler. - JobConfigInfo(JobID, String, JobConfigInfo.ExecutionConfigInfo) - Constructor for class org.apache.flink.runtime.rest.messages.JobConfigInfo
- JobConfigInfo.Deserializer - Class in org.apache.flink.runtime.rest.messages
-
Json deserializer for the
JobConfigInfo. - JobConfigInfo.ExecutionConfigInfo - Class in org.apache.flink.runtime.rest.messages
-
Nested class to encapsulate the execution configuration.
- JobConfigInfo.Serializer - Class in org.apache.flink.runtime.rest.messages
-
Json serializer for the
JobConfigInfo. - JobDetails - Class in org.apache.flink.runtime.messages.webmonitor
-
An actor message with a detailed overview of the current status of a job.
- JobDetails(JobID, String, long, long, long, JobStatus, long, int[], int) - Constructor for class org.apache.flink.runtime.messages.webmonitor.JobDetails
- JobDetails(JobID, String, long, long, long, JobStatus, long, int[], int, Map<String, Map<Integer, JobDetails.CurrentAttempts>>) - Constructor for class org.apache.flink.runtime.messages.webmonitor.JobDetails
- JobDetails(JobID, String, long, long, long, JobStatus, long, Map<String, Integer>) - Constructor for class org.apache.flink.runtime.messages.webmonitor.JobDetails
- JobDetails.CurrentAttempts - Class in org.apache.flink.runtime.messages.webmonitor
-
The CurrentAttempts holds the attempt number of the current representative execution attempt, the attempt numbers of all the running attempts, and whether the current execution has reached terminal state.
- JobDetailsHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Handler returning the details for the specified job.
- JobDetailsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, JobDetailsInfo, JobMessageParameters>, ExecutionGraphCache, Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobDetailsHandler
- JobDetailsHeaders - Class in org.apache.flink.runtime.rest.messages.job
-
Message headers for the
JobDetailsHandler. - JobDetailsInfo - Class in org.apache.flink.runtime.rest.messages.job
-
Details about a job.
- JobDetailsInfo(JobID, String, boolean, JobStatus, JobType, long, long, long, long, long, Map<JobStatus, Long>, Collection<JobDetailsInfo.JobVertexDetailsInfo>, Map<ExecutionState, Integer>, JobPlanInfo.RawJson) - Constructor for class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- JobDetailsInfo.JobVertexDetailsInfo - Class in org.apache.flink.runtime.rest.messages.job
-
Detailed information about a job vertex.
- JobDispatcherFactory - Enum in org.apache.flink.runtime.dispatcher
-
DispatcherFactorywhich creates aMiniDispatcher. - JobDispatcherLeaderProcess - Class in org.apache.flink.runtime.dispatcher.runner
-
DispatcherLeaderProcessimplementation for the per-job mode. - JobDispatcherLeaderProcessFactory - Class in org.apache.flink.runtime.dispatcher.runner
-
Factory for the
JobDispatcherLeaderProcess. - JobDispatcherLeaderProcessFactoryFactory - Class in org.apache.flink.runtime.dispatcher.runner
-
Factory for the
JobDispatcherLeaderProcessFactory. - JobEdge - Class in org.apache.flink.runtime.jobgraph
-
This class represent edges (communication channels) in a job graph.
- JobEdge(IntermediateDataSet, JobVertex, DistributionPattern, boolean) - Constructor for class org.apache.flink.runtime.jobgraph.JobEdge
-
Constructs a new job edge, that connects an intermediate result to a consumer task.
- JobEvent - Interface in org.apache.flink.runtime.jobmaster.event
-
A class that represents an event that happens during the job execution.
- JobEventManager - Class in org.apache.flink.runtime.jobmaster.event
-
The manager for recording and replaying
JobEvent. - JobEventManager(JobEventStore) - Constructor for class org.apache.flink.runtime.jobmaster.event.JobEventManager
- JobEventReplayHandler - Interface in org.apache.flink.runtime.jobmaster.event
-
The interface for process job event.
- JobEvents - Class in org.apache.flink.runtime.jobmaster.event
-
A class hosts all the type ids of events.
- JobEvents() - Constructor for class org.apache.flink.runtime.jobmaster.event.JobEvents
- JobEventStore - Interface in org.apache.flink.runtime.jobmaster.event
-
A store for recording the
JobEvent. - JobException - Exception in org.apache.flink.runtime
-
Indicates that a job has failed.
- JobException(String) - Constructor for exception org.apache.flink.runtime.JobException
- JobException(String, Throwable) - Constructor for exception org.apache.flink.runtime.JobException
- JobExceptionHistory(List<JobExceptionsInfoWithHistory.RootExceptionInfo>, boolean) - Constructor for class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.JobExceptionHistory
- JobExceptionsHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Handler serving the job exceptions.
- JobExceptionsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, JobExceptionsInfoWithHistory, JobExceptionsMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobExceptionsHandler
- JobExceptionsHeaders - Class in org.apache.flink.runtime.rest.messages
-
Message headers for the
JobExceptionsHandler. - JobExceptionsInfoWithHistory - Class in org.apache.flink.runtime.rest.messages
-
JobExceptionsInfoWithHistoryproviding a history of previously caused failures. - JobExceptionsInfoWithHistory(JobExceptionsInfoWithHistory.JobExceptionHistory) - Constructor for class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory
- JobExceptionsInfoWithHistory.ExceptionInfo - Class in org.apache.flink.runtime.rest.messages
-
Json equivalent of
ExceptionHistoryEntry. - JobExceptionsInfoWithHistory.JobExceptionHistory - Class in org.apache.flink.runtime.rest.messages
-
JobExceptionHistorycollects all previously caught errors. - JobExceptionsInfoWithHistory.RootExceptionInfo - Class in org.apache.flink.runtime.rest.messages
-
Json equivalent of
RootExceptionHistoryEntry. - JobExceptionsMessageParameters - Class in org.apache.flink.runtime.rest.messages.job
- JobExceptionsMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.JobExceptionsMessageParameters
- JobExecutionException - Exception in org.apache.flink.runtime.client
-
This exception is the base exception for all exceptions that denote any failure during the execution of a job.
- JobExecutionException(JobID, String) - Constructor for exception org.apache.flink.runtime.client.JobExecutionException
- JobExecutionException(JobID, String, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobExecutionException
-
Constructs a new job execution exception.
- JobExecutionException(JobID, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobExecutionException
- JobExecutionResultHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Returns the
JobExecutionResultfor a givenJobID. - JobExecutionResultHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobExecutionResultHandler
- JobExecutionResultHeaders - Class in org.apache.flink.runtime.rest.messages.job
- JobExecutionResultHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
- JobExecutionResultResponseBody - Class in org.apache.flink.runtime.rest.messages.job
- JobExecutionResultResponseBody(QueueStatus, JobResult) - Constructor for class org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
- JobFailureMetricReporter - Class in org.apache.flink.runtime.scheduler.adaptive
-
Helper class to simplify job failure reporting through a metric group.
- JobFailureMetricReporter(MetricGroup) - Constructor for class org.apache.flink.runtime.scheduler.adaptive.JobFailureMetricReporter
- JobGraph - Class in org.apache.flink.runtime.jobgraph
-
The JobGraph represents a Flink dataflow program, at the low level that the JobManager accepts.
- JobGraph(String) - Constructor for class org.apache.flink.runtime.jobgraph.JobGraph
-
Constructs a new job graph with the given name, the given
ExecutionConfig, and a random job ID. - JobGraph(JobID, String) - Constructor for class org.apache.flink.runtime.jobgraph.JobGraph
-
Constructs a new job graph with the given job ID (or a random ID, if
nullis passed), the given name and the given execution configuration (seeExecutionConfig). - JobGraph(JobID, String, JobVertex...) - Constructor for class org.apache.flink.runtime.jobgraph.JobGraph
-
Constructs a new job graph with the given name, the given
ExecutionConfig, the given jobId or a random one if null supplied, and the given job vertices. - JobGraphBuilder - Class in org.apache.flink.runtime.jobgraph
-
Builder for the
JobGraph. - jobGraphFileName - Variable in class org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody
- JobGraphJobInformation - Class in org.apache.flink.runtime.scheduler.adaptive
-
JobInformationcreated from aJobGraph. - JobGraphJobInformation(JobGraph, VertexParallelismStore) - Constructor for class org.apache.flink.runtime.scheduler.adaptive.JobGraphJobInformation
- JobGraphRetriever - Interface in org.apache.flink.runtime.entrypoint.component
-
Interface which allows to retrieve the
JobGraph. - JobGraphStore - Interface in org.apache.flink.runtime.jobmanager
-
JobGraphinstances for recovery. - JobGraphStore.JobGraphListener - Interface in org.apache.flink.runtime.jobmanager
-
A listener for
JobGraphinstances. - JobGraphStoreUtil - Interface in org.apache.flink.runtime.jobmanager
-
JobGraphStore utility interfaces.
- JobGraphStoreWatcher - Interface in org.apache.flink.runtime.jobmanager
-
A watcher on
JobGraphStore. - JobGraphUtils - Enum in org.apache.flink.runtime.jobgraph
-
Utilities for generating
JobGraph. - JobGraphWriter - Interface in org.apache.flink.runtime.jobmanager
-
Allows to store and remove job graphs.
- jobId - Variable in class org.apache.flink.runtime.metrics.groups.JobMetricGroup
-
The ID of the job represented by this metrics group.
- jobId() - Method in class org.apache.flink.runtime.metrics.groups.JobMetricGroup
- jobId(JobID) - Method in class org.apache.flink.runtime.jobmaster.JobResult.Builder
- jobID - Variable in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
- jobID - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobManagerOperatorQueryScopeInfo
- jobID - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobQueryScopeInfo
- jobID - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
- jobID - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
- jobID - Variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointTriggerMessageParameters
- jobID - Variable in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerMessageParameters
- jobID - Variable in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
JobID from the owning subtask.
- JobIDDeserializer - Class in org.apache.flink.runtime.rest.messages.json
-
Json deserializer for
JobID. - JobIDDeserializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.JobIDDeserializer
- jobIdPathParameter - Variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatusMessageParameters
- jobIdPathParameter - Variable in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusMessageParameters
- JobIDPathParameter - Class in org.apache.flink.runtime.rest.messages
-
Path parameter identifying jobs.
- JobIDPathParameter() - Constructor for class org.apache.flink.runtime.rest.messages.JobIDPathParameter
- JobIDSerializer - Class in org.apache.flink.runtime.rest.messages.json
-
Json serializer for
JobID. - JobIDSerializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.JobIDSerializer
- JobIdsHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Handler for job IDs.
- JobIdsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, JobIdsWithStatusOverview, EmptyMessageParameters>) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobIdsHandler
- JobIdsWithStatusesOverviewHeaders - Class in org.apache.flink.runtime.rest.messages
-
Message headers for the
JobIdsWithStatusOverview. - JobIdsWithStatusOverview - Class in org.apache.flink.runtime.messages.webmonitor
-
An overview of how many jobs are in which status.
- JobIdsWithStatusOverview(Collection<JobIdsWithStatusOverview.JobIdWithStatus>) - Constructor for class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview
- JobIdsWithStatusOverview(JobIdsWithStatusOverview, JobIdsWithStatusOverview) - Constructor for class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview
- JobIdsWithStatusOverview.JobIdWithStatus - Class in org.apache.flink.runtime.messages.webmonitor
- jobIDToName(JobID) - Method in interface org.apache.flink.runtime.jobmanager.JobGraphStoreUtil
-
Get the name in external storage from job id.
- jobIDToName(JobID) - Method in enum org.apache.flink.runtime.jobmanager.ZooKeeperJobGraphStoreUtil
- JobIdWithStatus(JobID, JobStatus) - Constructor for class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview.JobIdWithStatus
- jobInfo - Variable in class org.apache.flink.runtime.scheduler.SchedulerBase
- JobInformation - Class in org.apache.flink.runtime.executiongraph
-
Container class for job information which is stored in the
ExecutionGraph. - JobInformation - Interface in org.apache.flink.runtime.scheduler.adaptive.allocator
-
Information about the job.
- JobInformation(JobID, JobType, String, SerializedValue<ExecutionConfig>, Configuration, Collection<PermanentBlobKey>, Collection<URL>) - Constructor for class org.apache.flink.runtime.executiongraph.JobInformation
- JobInformation.VertexInformation - Interface in org.apache.flink.runtime.scheduler.adaptive.allocator
-
Information about a single vertex.
- JobInitializationException - Exception in org.apache.flink.runtime.client
-
An exception indicating that the job has failed in the INITIALIZING job status.
- JobInitializationException(JobID, String, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobInitializationException
- JobLeaderIdActions - Interface in org.apache.flink.runtime.resourcemanager
-
Interface for actions called by the
DefaultJobLeaderIdService. - JobLeaderIdService - Interface in org.apache.flink.runtime.resourcemanager
-
Service which retrieves for a registered job the current job leader id (the leader id of the job manager responsible for the job).
- JobLeaderListener - Interface in org.apache.flink.runtime.taskexecutor
-
Listener for the
JobLeaderService. - jobLeaderLostLeadership(JobID, JobMasterId) - Method in interface org.apache.flink.runtime.resourcemanager.JobLeaderIdActions
-
Callback when a monitored job leader lost its leadership.
- jobLeaderLostLeadership(JobID, JobMasterId) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- JobLeaderService - Interface in org.apache.flink.runtime.taskexecutor
-
This service has the responsibility to monitor the job leaders (the job manager which is leader for a given job) for all registered jobs.
- JOBMANAGER_JOB_CONFIG_REST_PATH - Static variable in class org.apache.flink.runtime.rest.messages.job.JobManagerJobConfigurationHeaders
- JOBMANAGER_JOB_ENV_REST_PATH - Static variable in class org.apache.flink.runtime.rest.messages.job.JobManagerJobEnvironmentHeaders
- JobManagerCheckpointStorage - Class in org.apache.flink.runtime.state.storage
-
The
CheckpointStoragecheckpoints state directly to the JobManager's memory (hence the name), but savepoints will be persisted to a file system. - JobManagerCheckpointStorage() - Constructor for class org.apache.flink.runtime.state.storage.JobManagerCheckpointStorage
-
Creates a new job manager checkpoint storage that accepts states whose serialized forms are up to the default state size (5 MB).
- JobManagerCheckpointStorage(int) - Constructor for class org.apache.flink.runtime.state.storage.JobManagerCheckpointStorage
-
Creates a new JobManagerCheckpointStorage, setting optionally the paths to persist checkpoint metadata and savepoints to, as well as configuring state thresholds and asynchronous operations.
- JobManagerCheckpointStorage(String) - Constructor for class org.apache.flink.runtime.state.storage.JobManagerCheckpointStorage
-
Creates a new JobManagerCheckpointStorage, setting optionally the paths to persist checkpoint metadata and savepoints to, as well as configuring state thresholds and asynchronous operations.
- JobManagerCheckpointStorage(Path, int) - Constructor for class org.apache.flink.runtime.state.storage.JobManagerCheckpointStorage
-
Creates a new JobManagerCheckpointStorage, setting optionally the paths to persist checkpoint metadata and savepoints to, as well as configuring state thresholds and asynchronous operations.
- JobManagerCustomLogHandler - Class in org.apache.flink.runtime.rest.handler.cluster
-
Rest handler which serves the custom log file from JobManager.
- JobManagerCustomLogHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, UntypedResponseMessageHeaders<EmptyRequestBody, FileMessageParameters>, File) - Constructor for class org.apache.flink.runtime.rest.handler.cluster.JobManagerCustomLogHandler
- JobManagerCustomLogHeaders - Class in org.apache.flink.runtime.rest.messages.cluster
-
Headers for the
JobManagerCustomLogHandler. - JobManagerEnvironmentHandler - Class in org.apache.flink.runtime.rest.handler.cluster
-
Handler which serves the jobmanager's environment variables.
- JobManagerEnvironmentHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, EnvironmentInfo, EmptyMessageParameters>) - Constructor for class org.apache.flink.runtime.rest.handler.cluster.JobManagerEnvironmentHandler
- JobManagerEnvironmentHeaders - Class in org.apache.flink.runtime.rest.messages
-
Message headers for the
JobManagerEnvironmentHandler. - JobManagerEnvironmentHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.JobManagerEnvironmentHeaders
- JobManagerException - Exception in org.apache.flink.runtime.jobmaster
-
Base exception thrown by the
JobMaster. - JobManagerException(String) - Constructor for exception org.apache.flink.runtime.jobmaster.JobManagerException
- JobManagerException(String, Throwable) - Constructor for exception org.apache.flink.runtime.jobmaster.JobManagerException
- JobManagerException(Throwable) - Constructor for exception org.apache.flink.runtime.jobmaster.JobManagerException
- JobManagerFlinkMemory - Class in org.apache.flink.runtime.util.config.memory.jobmanager
-
Flink internal memory components of Job Manager.
- JobManagerFlinkMemory(MemorySize, MemorySize) - Constructor for class org.apache.flink.runtime.util.config.memory.jobmanager.JobManagerFlinkMemory
- JobManagerFlinkMemoryUtils - Class in org.apache.flink.runtime.util.config.memory.jobmanager
-
FlinkMemoryUtilsfor Job Manager. - JobManagerFlinkMemoryUtils() - Constructor for class org.apache.flink.runtime.util.config.memory.jobmanager.JobManagerFlinkMemoryUtils
- jobManagerGainedLeadership(JobID, JobMasterGateway, JMTMRegistrationSuccess) - Method in interface org.apache.flink.runtime.taskexecutor.JobLeaderListener
-
Callback if a job manager has gained leadership for the job identified by the job id and a connection could be established to this job manager.
- JobManagerJobConfigurationHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Handler which serves the jobmanager's configuration of a specific job.
- JobManagerJobConfigurationHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, ConfigurationInfo, JobMessageParameters>, Configuration) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobManagerJobConfigurationHandler
- JobManagerJobConfigurationHeaders - Class in org.apache.flink.runtime.rest.messages.job
-
Message headers for the
JobManagerJobConfigurationHandler. - JobManagerJobEnvironmentHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Handler which serves the jobmanager's environment variables of a specific job.
- JobManagerJobEnvironmentHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, EnvironmentInfo, JobMessageParameters>) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobManagerJobEnvironmentHandler
- JobManagerJobEnvironmentHeaders - Class in org.apache.flink.runtime.rest.messages.job
-
Message headers for the
JobManagerJobEnvironmentHandler. - jobManagerJobMetricGroup - Variable in class org.apache.flink.runtime.scheduler.SchedulerBase
- JobManagerJobMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
Special
MetricGrouprepresenting everything belonging to a specific job, running on the JobManager. - JobManagerJobMetricGroupFactory - Interface in org.apache.flink.runtime.jobmaster.factories
-
Factory interface for
JobManagerJobMetricGroup. - JobManagerJobScopeFormat - Class in org.apache.flink.runtime.metrics.scope
-
The scope format for the
JobMetricGroup. - JobManagerJobScopeFormat(String, JobManagerScopeFormat) - Constructor for class org.apache.flink.runtime.metrics.scope.JobManagerJobScopeFormat
- JobManagerLogFileHandler - Class in org.apache.flink.runtime.rest.handler.cluster
-
Rest handler which serves the log files from JobManager.
- JobManagerLogFileHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, UntypedResponseMessageHeaders<EmptyRequestBody, EmptyMessageParameters>, File) - Constructor for class org.apache.flink.runtime.rest.handler.cluster.JobManagerLogFileHandler
- JobManagerLogFileHeader - Class in org.apache.flink.runtime.rest.messages.cluster
-
Headers for the
JobManagerLogFileHandler. - JobManagerLogListHandler - Class in org.apache.flink.runtime.rest.handler.cluster
-
Handler which serves detailed JobManager log list information.
- JobManagerLogListHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, LogListInfo, EmptyMessageParameters>, File) - Constructor for class org.apache.flink.runtime.rest.handler.cluster.JobManagerLogListHandler
- JobManagerLogListHeaders - Class in org.apache.flink.runtime.rest.messages.cluster
-
Headers for the
JobManagerLogListHandler. - JobManagerLogUrlHeaders - Class in org.apache.flink.runtime.rest.messages
-
Headers for the log url retriever of JobManager.
- jobManagerLostLeadership(JobID, JobMasterId) - Method in interface org.apache.flink.runtime.taskexecutor.JobLeaderListener
-
Callback if the job leader for the job with the given job id lost its leadership.
- JobManagerMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
Special
MetricGrouprepresenting a JobManager. - JobManagerMetricGroupFactory - Interface in org.apache.flink.runtime.dispatcher
-
Factory interface for
JobManagerMetricGroup. - JobManagerMetricsHandler - Class in org.apache.flink.runtime.rest.handler.job.metrics
-
Handler that returns JobManager metrics.
- JobManagerMetricsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.JobManagerMetricsHandler
- JobManagerMetricsHeaders - Class in org.apache.flink.runtime.rest.messages.job.metrics
- JobManagerMetricsMessageParameters - Class in org.apache.flink.runtime.rest.messages.job.metrics
- JobManagerMetricsMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsMessageParameters
- JobManagerOperatorMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
Special
MetricGrouprepresenting everything belonging to the components running on the JobManager of an Operator. - JobManagerOperatorMetricGroup(MetricRegistry, JobManagerJobMetricGroup, AbstractID, String, OperatorID, String) - Constructor for class org.apache.flink.runtime.metrics.groups.JobManagerOperatorMetricGroup
- JobManagerOperatorMetricsHandler - Class in org.apache.flink.runtime.rest.handler.job.metrics
-
Handler that returns job manager operator metrics.
- JobManagerOperatorMetricsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.JobManagerOperatorMetricsHandler
- JobManagerOperatorMetricsHeaders - Class in org.apache.flink.runtime.rest.messages.job.metrics
- JobManagerOperatorMetricsMessageParameters - Class in org.apache.flink.runtime.rest.messages.job.metrics
- JobManagerOperatorMetricsMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerOperatorMetricsMessageParameters
- JobManagerOperatorQueryScopeInfo(String, String, String) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobManagerOperatorQueryScopeInfo
- JobManagerOperatorQueryScopeInfo(String, String, String, String) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobManagerOperatorQueryScopeInfo
- JobManagerOperatorScopeFormat - Class in org.apache.flink.runtime.metrics.scope
-
The scope format for the
JobManagerOperatorMetricGroup. - JobManagerOperatorScopeFormat(String, JobManagerJobScopeFormat) - Constructor for class org.apache.flink.runtime.metrics.scope.JobManagerOperatorScopeFormat
- JobManagerProcessSpec - Class in org.apache.flink.runtime.jobmanager
-
Describe the specifics of different resource dimensions of the JobManager process.
- JobManagerProcessSpec(MemorySize, MemorySize, MemorySize, MemorySize) - Constructor for class org.apache.flink.runtime.jobmanager.JobManagerProcessSpec
- JobManagerProcessUtils - Class in org.apache.flink.runtime.jobmanager
-
JobManager utils to calculate
JobManagerProcessSpecand JVM args. - JobManagerProfilingFileHandler - Class in org.apache.flink.runtime.rest.handler.cluster
-
Rest handler which serves the profiler result file from JobManager.
- JobManagerProfilingFileHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, UntypedResponseMessageHeaders<EmptyRequestBody, ProfilingFileMessageParameters>, Configuration) - Constructor for class org.apache.flink.runtime.rest.handler.cluster.JobManagerProfilingFileHandler
- JobManagerProfilingFileHeaders - Class in org.apache.flink.runtime.rest.messages.cluster
-
Headers for the
JobManagerProfilingFileHandler. - JobManagerProfilingHandler - Class in org.apache.flink.runtime.rest.handler.cluster
-
Rest handler which serves the profiling info from the JobManager.
- JobManagerProfilingHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<ProfilingRequestBody, ProfilingInfo, EmptyMessageParameters>, Configuration) - Constructor for class org.apache.flink.runtime.rest.handler.cluster.JobManagerProfilingHandler
- JobManagerProfilingHeaders - Class in org.apache.flink.runtime.rest.messages.cluster
-
Headers for the
JobManagerProfilingHandler. - JobManagerProfilingListHandler - Class in org.apache.flink.runtime.rest.handler.cluster
-
Rest handler which serves the profiling list from the JobManager.
- JobManagerProfilingListHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, ProfilingInfoList, EmptyMessageParameters>, Configuration) - Constructor for class org.apache.flink.runtime.rest.handler.cluster.JobManagerProfilingListHandler
- JobManagerProfilingListHeaders - Class in org.apache.flink.runtime.rest.messages.cluster
-
Headers for the
JobManagerProfilingHandler. - JobManagerQueryScopeInfo() - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobManagerQueryScopeInfo
- JobManagerQueryScopeInfo(String) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobManagerQueryScopeInfo
- JobManagerRegistration - Class in org.apache.flink.runtime.resourcemanager.registration
-
Container for JobManager related registration information, such as the leader id or the job id.
- JobManagerRegistration(JobID, ResourceID, JobMasterGateway) - Constructor for class org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
- jobManagerRejectedRegistration(JobID, String, JMTMRegistrationRejection) - Method in interface org.apache.flink.runtime.taskexecutor.JobLeaderListener
-
Callback if a job manager rejected the connection attempts of a task manager.
- JobManagerRunner - Interface in org.apache.flink.runtime.jobmaster
-
Interface for a runner which executes a
JobMaster. - JobManagerRunnerFactory - Interface in org.apache.flink.runtime.dispatcher
-
Factory for a
JobManagerRunner. - JobManagerRunnerRegistry - Interface in org.apache.flink.runtime.dispatcher
-
JobManagerRunnercollects running jobs represented byJobManagerRunner. - JobManagerRunnerResult - Class in org.apache.flink.runtime.jobmaster
-
The result of the
JobManagerRunner. - JobManagerScopeFormat - Class in org.apache.flink.runtime.metrics.scope
-
The scope format for the
JobManagerMetricGroup. - JobManagerScopeFormat(String) - Constructor for class org.apache.flink.runtime.metrics.scope.JobManagerScopeFormat
- JobManagerSharedServices - Class in org.apache.flink.runtime.jobmaster
-
Utility class which holds all auxiliary shared services used by the
JobMaster. - JobManagerSharedServices(ScheduledExecutorService, ExecutorService, LibraryCacheManager, ShuffleMaster<?>, BlobWriter) - Constructor for class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
- JobManagerStdoutFileHeader - Class in org.apache.flink.runtime.rest.messages.cluster
-
Headers for the
JobManagerStdoutFileHandler. - JobManagerTaskRestore - Class in org.apache.flink.runtime.checkpoint
-
This class encapsulates the data from the job manager to restore a task.
- JobManagerTaskRestore(long, TaskStateSnapshot) - Constructor for class org.apache.flink.runtime.checkpoint.JobManagerTaskRestore
- JobManagerThreadDumpHandler - Class in org.apache.flink.runtime.rest.handler.cluster
-
Rest handler which serves the thread dump info from the JobManager.
- JobManagerThreadDumpHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, ThreadDumpInfo, EmptyMessageParameters>) - Constructor for class org.apache.flink.runtime.rest.handler.cluster.JobManagerThreadDumpHandler
- JobManagerThreadDumpHeaders - Class in org.apache.flink.runtime.rest.messages.cluster
-
Headers for the
JobManagerThreadDumpHandler. - JobMaster - Class in org.apache.flink.runtime.jobmaster
-
JobMaster implementation.
- JobMaster(RpcService, JobMasterId, JobMasterConfiguration, ResourceID, JobGraph, HighAvailabilityServices, SlotPoolServiceSchedulerFactory, JobManagerSharedServices, HeartbeatServices, JobManagerJobMetricGroupFactory, OnCompletionActions, FatalErrorHandler, ClassLoader, ShuffleMaster<?>, PartitionTrackerFactory, ExecutionDeploymentTracker, ExecutionDeploymentReconciler.Factory, BlocklistHandler.Factory, Collection<FailureEnricher>, long) - Constructor for class org.apache.flink.runtime.jobmaster.JobMaster
- JobMasterConfiguration - Class in org.apache.flink.runtime.jobmaster
-
Configuration for the
JobMaster. - JobMasterConfiguration(Duration, Duration, String, RetryingRegistrationConfiguration, Configuration) - Constructor for class org.apache.flink.runtime.jobmaster.JobMasterConfiguration
- JobMasterException - Exception in org.apache.flink.runtime.jobmaster
-
Base class for
JobMasterrelated exceptions. - JobMasterException(String) - Constructor for exception org.apache.flink.runtime.jobmaster.JobMasterException
- JobMasterException(String, Throwable) - Constructor for exception org.apache.flink.runtime.jobmaster.JobMasterException
- JobMasterException(Throwable) - Constructor for exception org.apache.flink.runtime.jobmaster.JobMasterException
- jobMasterFailed(Throwable) - Method in interface org.apache.flink.runtime.jobmanager.OnCompletionActions
-
The
JobMasterfailed while executing the job. - jobMasterFailed(Throwable) - Method in class org.apache.flink.runtime.jobmaster.DefaultJobMasterServiceProcess
- JobMasterGateway - Interface in org.apache.flink.runtime.jobmaster
-
JobMasterrpc gateway interface. - JobMasterId - Class in org.apache.flink.runtime.jobmaster
-
The
JobMasterfencing token. - JobMasterId(UUID) - Constructor for class org.apache.flink.runtime.jobmaster.JobMasterId
-
Creates a JobMasterId that takes the bits from the given UUID.
- JobMasterOperatorEventGateway - Interface in org.apache.flink.runtime.jobmaster
-
Gateway to send an
OperatorEventorCoordinationRequestfrom the Task Manager to to theOperatorCoordinatoron the JobManager side. - JobMasterPartitionTracker - Interface in org.apache.flink.runtime.io.network.partition
-
Utility for tracking partitions and issuing release calls to task executors and shuffle masters.
- JobMasterPartitionTrackerImpl - Class in org.apache.flink.runtime.io.network.partition
-
Utility for tracking partitions and issuing release calls to task executors and shuffle masters.
- JobMasterPartitionTrackerImpl(JobID, ShuffleMaster<?>, PartitionTrackerFactory.TaskExecutorGatewayLookup) - Constructor for class org.apache.flink.runtime.io.network.partition.JobMasterPartitionTrackerImpl
- JobMasterRegistrationSuccess - Class in org.apache.flink.runtime.jobmaster
-
Base class for responses from the ResourceManager to a registration attempt by a JobMaster.
- JobMasterRegistrationSuccess(ResourceManagerId, ResourceID) - Constructor for class org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess
- JobMasterService - Interface in org.apache.flink.runtime.jobmaster
-
Interface which specifies the JobMaster service.
- JobMasterServiceFactory - Interface in org.apache.flink.runtime.jobmaster.factories
-
Factory for the
JobMasterService. - JobMasterServiceLeadershipRunner - Class in org.apache.flink.runtime.jobmaster
-
Leadership runner for the
JobMasterServiceProcess. - JobMasterServiceLeadershipRunner(JobMasterServiceProcessFactory, LeaderElection, JobResultStore, LibraryCacheManager.ClassLoaderLease, FatalErrorHandler) - Constructor for class org.apache.flink.runtime.jobmaster.JobMasterServiceLeadershipRunner
- JobMasterServiceLeadershipRunnerFactory - Enum in org.apache.flink.runtime.dispatcher
-
Factory which creates a
JobMasterServiceLeadershipRunner. - JobMasterServiceProcess - Interface in org.apache.flink.runtime.jobmaster
-
JobMasterServiceProcess is responsible for running a
JobMasterService. - JobMasterServiceProcess.WaitingForLeadership - Enum in org.apache.flink.runtime.jobmaster
- JobMasterServiceProcessFactory - Interface in org.apache.flink.runtime.jobmaster.factories
-
Factory for the
JobMasterServiceProcess. - JobMessageParameters - Class in org.apache.flink.runtime.rest.messages
-
Message parameters which require a job path parameter.
- JobMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.JobMessageParameters
- JobMetricGroup<C extends ComponentMetricGroup<C>> - Class in org.apache.flink.runtime.metrics.groups
-
Special abstract
MetricGrouprepresenting everything belonging to a specific job. - JobMetricGroup(MetricRegistry, C, JobID, String, String[]) - Constructor for class org.apache.flink.runtime.metrics.groups.JobMetricGroup
- JobMetricsHandler - Class in org.apache.flink.runtime.rest.handler.job.metrics
-
Request handler that returns for a given job a list of all available metrics or the values for a set of metrics.
- JobMetricsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.JobMetricsHandler
- JobMetricsHeaders - Class in org.apache.flink.runtime.rest.messages.job.metrics
- JobMetricsMessageParameters - Class in org.apache.flink.runtime.rest.messages.job.metrics
- JobMetricsMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsMessageParameters
- jobName - Variable in class org.apache.flink.runtime.metrics.groups.JobMetricGroup
-
The name of the job represented by this metrics group.
- jobName() - Method in class org.apache.flink.runtime.metrics.groups.JobMetricGroup
- JobNotFinishedException - Exception in org.apache.flink.runtime.jobmaster
-
Exception indicating that a Flink job has not been finished.
- JobNotFinishedException(JobID) - Constructor for exception org.apache.flink.runtime.jobmaster.JobNotFinishedException
- jobPathParameter - Variable in class org.apache.flink.runtime.rest.messages.job.coordination.ClientCoordinationMessageParameters
- jobPathParameter - Variable in class org.apache.flink.runtime.rest.messages.JobMessageParameters
- JobPermanentBlobService - Interface in org.apache.flink.runtime.blob
-
PermanentBlobServiceextension that gives access to register and release job artifacts. - JobPersistenceComponentFactory - Interface in org.apache.flink.runtime.jobmanager
-
Factory for components that are responsible for persisting a job for recovery.
- JobPlanHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Handler serving the job execution plan.
- JobPlanHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, JobPlanInfo, JobMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobPlanHandler
- JobPlanHeaders - Class in org.apache.flink.runtime.rest.messages
-
Message headers for the
JobPlanHandler. - JobPlanInfo - Class in org.apache.flink.runtime.rest.messages
-
Response type of the
JobPlanHandler. - JobPlanInfo(String) - Constructor for class org.apache.flink.runtime.rest.messages.JobPlanInfo
- JobPlanInfo(JobPlanInfo.RawJson) - Constructor for class org.apache.flink.runtime.rest.messages.JobPlanInfo
- JobPlanInfo.RawJson - Class in org.apache.flink.runtime.rest.messages
-
Simple wrapper around a raw JSON string.
- JobPlanInfo.RawJson.Deserializer - Class in org.apache.flink.runtime.rest.messages
-
Json deserializer for the
JobPlanInfo.RawJson. - JobPlanInfo.RawJson.Serializer - Class in org.apache.flink.runtime.rest.messages
-
Json serializer for the
JobPlanInfo.RawJson. - JobQueryScopeInfo(String) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobQueryScopeInfo
- JobQueryScopeInfo(String, String) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobQueryScopeInfo
- jobReachedGloballyTerminalState(ExecutionGraphInfo) - Method in interface org.apache.flink.runtime.jobmanager.OnCompletionActions
-
Job reached a globally terminal state.
- jobReachedGloballyTerminalState(ExecutionGraphInfo) - Method in class org.apache.flink.runtime.jobmaster.DefaultJobMasterServiceProcess
- jobReachedTerminalState(ExecutionGraphInfo) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- JobResourceRequirements - Class in org.apache.flink.runtime.jobgraph
-
Information about the parallelism of job vertices.
- JobResourceRequirements(Map<JobVertexID, JobVertexResourceRequirements>) - Constructor for class org.apache.flink.runtime.jobgraph.JobResourceRequirements
- JobResourceRequirements.Builder - Class in org.apache.flink.runtime.jobgraph
- JobResourceRequirementsBody - Class in org.apache.flink.runtime.rest.messages.job
-
Body for change job requests.
- JobResourceRequirementsBody() - Constructor for class org.apache.flink.runtime.rest.messages.job.JobResourceRequirementsBody
- JobResourceRequirementsBody(JobResourceRequirements) - Constructor for class org.apache.flink.runtime.rest.messages.job.JobResourceRequirementsBody
- JobResourceRequirementsHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Rest handler for reading current
resource requirementsof a given job. - JobResourceRequirementsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobResourceRequirementsHandler
- JobResourceRequirementsHeaders - Class in org.apache.flink.runtime.rest.messages.job
-
Headers for REST request to get details on job's resources.
- JobResourceRequirementsHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.job.JobResourceRequirementsHeaders
- JobResourceRequirementsUpdateHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Rest handler for updating
resource requirementsof a given job. - JobResourceRequirementsUpdateHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobResourceRequirementsUpdateHandler
- JobResourcesRequirementsUpdateHeaders - Class in org.apache.flink.runtime.rest.messages.job
-
Headers for REST request to patch a job.
- JobResourcesRequirementsUpdateHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.job.JobResourcesRequirementsUpdateHeaders
- JobRestEndpointFactory - Enum in org.apache.flink.runtime.rest
-
RestEndpointFactorywhich creates aMiniDispatcherRestEndpoint. - JobResult - Class in org.apache.flink.runtime.jobmaster
-
Similar to
JobExecutionResultbut with an optionalSerializedThrowablewhen the job failed. - JobResult.Builder - Class in org.apache.flink.runtime.jobmaster
-
Builder for
JobResult. - JobResultDeserializer - Class in org.apache.flink.runtime.rest.messages.json
-
JSON deserializer for
JobResult. - JobResultDeserializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.JobResultDeserializer
- JobResultEntry - Class in org.apache.flink.runtime.highavailability
-
JobResultEntryis the entity managed by theJobResultStore. - JobResultEntry(JobResult) - Constructor for class org.apache.flink.runtime.highavailability.JobResultEntry
- JobResultSerializer - Class in org.apache.flink.runtime.rest.messages.json
-
JSON serializer for
JobResult. - JobResultSerializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.JobResultSerializer
- JobResultStore - Interface in org.apache.flink.runtime.highavailability
-
A storage for the results of globally terminated jobs.
- JobResultStoreOptions - Class in org.apache.flink.runtime.highavailability
-
The set of configuration options relating to the Job Result Store.
- JobResultStoreOptions() - Constructor for class org.apache.flink.runtime.highavailability.JobResultStoreOptions
- JobSchedulingPlan - Class in org.apache.flink.runtime.scheduler.adaptive
-
A plan that describes how to execute
JobGraph. - JobSchedulingPlan(VertexParallelism, Collection<JobSchedulingPlan.SlotAssignment>) - Constructor for class org.apache.flink.runtime.scheduler.adaptive.JobSchedulingPlan
- JobSchedulingPlan.SlotAssignment - Class in org.apache.flink.runtime.scheduler.adaptive
-
Assignment of a slot to some target (e.g. a slot sharing group).
- JobsFilterQueryParameter - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
MessageQueryParameterfor selecting jobs when aggregating metrics. - JobShuffleContext - Interface in org.apache.flink.runtime.shuffle
-
Job level shuffle context which can offer some job information like job ID and through it, the shuffle plugin notify the job to stop tracking the lost result partitions.
- JobShuffleContextImpl - Class in org.apache.flink.runtime.shuffle
-
The default implementation of
JobShuffleContext. - JobShuffleContextImpl(JobID, JobMasterGateway) - Constructor for class org.apache.flink.runtime.shuffle.JobShuffleContextImpl
- JobsOverview - Class in org.apache.flink.runtime.messages.webmonitor
-
An overview of how many jobs are in which status.
- JobsOverview(int, int, int, int) - Constructor for class org.apache.flink.runtime.messages.webmonitor.JobsOverview
- JobsOverview(JobsOverview, JobsOverview) - Constructor for class org.apache.flink.runtime.messages.webmonitor.JobsOverview
- JobsOverviewHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Overview handler for jobs.
- JobsOverviewHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, MultipleJobsDetails, EmptyMessageParameters>) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobsOverviewHandler
- JobsOverviewHeaders - Class in org.apache.flink.runtime.rest.messages
-
Message headers for
JobsOverviewHandler. - jobStatusChanges(JobID, JobStatus, long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinatorDeActivator
- jobStatusChanges(JobID, JobStatus, long) - Method in interface org.apache.flink.runtime.executiongraph.JobStatusListener
-
This method is called whenever the status of the job changes.
- jobStatusChanges(JobID, JobStatus, long) - Method in class org.apache.flink.runtime.scheduler.JobStatusStore
- jobStatusChanges(JobID, JobStatus, long) - Method in class org.apache.flink.runtime.scheduler.metrics.JobStatusMetrics
- JobStatusHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Handler for requesting job status.
- JobStatusHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, JobStatusInfo, JobMessageParameters>) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobStatusHandler
- JobStatusInfo - Class in org.apache.flink.runtime.messages.webmonitor
-
The status of a specific job.
- JobStatusInfo(JobStatus) - Constructor for class org.apache.flink.runtime.messages.webmonitor.JobStatusInfo
- JobStatusInfoHeaders - Class in org.apache.flink.runtime.rest.messages.job
- JobStatusInfoHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.job.JobStatusInfoHeaders
- JobStatusListener - Interface in org.apache.flink.runtime.executiongraph
-
Interface for observers that monitor the status of a job.
- JobStatusMessage - Class in org.apache.flink.runtime.client
-
A simple message that holds the state of a job execution.
- JobStatusMessage(JobID, String, JobStatus, long) - Constructor for class org.apache.flink.runtime.client.JobStatusMessage
- JobStatusMetrics - Class in org.apache.flink.runtime.scheduler.metrics
-
Metrics that capture the time that a job spends in each
JobStatus. - JobStatusMetrics(long, MetricOptions.JobStatusMetricsSettings) - Constructor for class org.apache.flink.runtime.scheduler.metrics.JobStatusMetrics
- JobStatusProvider - Interface in org.apache.flink.runtime.executiongraph
-
Interface for querying the state of a job and the timestamps of state transitions.
- JobStatusStore - Class in org.apache.flink.runtime.scheduler
-
Listens for and exposes the current job state and state timestamps.
- JobStatusStore(long) - Constructor for class org.apache.flink.runtime.scheduler.JobStatusStore
- JobSubmissionException - Exception in org.apache.flink.runtime.client
-
This exception denotes an error while submitting a job to the JobManager.
- JobSubmissionException(JobID, String) - Constructor for exception org.apache.flink.runtime.client.JobSubmissionException
- JobSubmissionException(JobID, String, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobSubmissionException
- JobSubmitHandler - Class in org.apache.flink.runtime.rest.handler.job
-
This handler can be used to submit jobs to a Flink cluster.
- JobSubmitHandler(GatewayRetriever<? extends DispatcherGateway>, Duration, Map<String, String>, Executor, Configuration) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobSubmitHandler
- JobSubmitHeaders - Class in org.apache.flink.runtime.rest.messages.job
-
These headers define the protocol for submitting a job to a flink cluster.
- JobSubmitRequestBody - Class in org.apache.flink.runtime.rest.messages.job
-
Request for submitting a job.
- JobSubmitRequestBody(String, Collection<String>, Collection<JobSubmitRequestBody.DistributedCacheFile>) - Constructor for class org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody
- JobSubmitRequestBody.DistributedCacheFile - Class in org.apache.flink.runtime.rest.messages.job
-
Descriptor for a distributed cache file.
- JobSubmitResponseBody - Class in org.apache.flink.runtime.rest.messages.job
-
Response to the submission of a job, containing a URL from which the status of the job can be retrieved from.
- JobSubmitResponseBody(String) - Constructor for class org.apache.flink.runtime.rest.messages.job.JobSubmitResponseBody
- JobTable - Interface in org.apache.flink.runtime.taskexecutor
-
A
JobTable'stask is to manage the lifecycle of a job on theTaskExecutor. - JobTable.Connection - Interface in org.apache.flink.runtime.taskexecutor
-
A connection contains services bound to the lifetime of a connection with a JobManager.
- JobTable.Job - Interface in org.apache.flink.runtime.taskexecutor
-
A job contains services which are bound to the lifetime of a Flink job.
- JobTable.JobServices - Interface in org.apache.flink.runtime.taskexecutor
-
Services associated with a job.
- JobTaskManagerMessageParameters - Class in org.apache.flink.runtime.rest.messages
-
Message parameters which require a job path parameter and a TaskManager id path parameter.
- JobTaskManagerMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.JobTaskManagerMessageParameters
- JobType - Enum in org.apache.flink.runtime.jobgraph
-
Enum to distinguish JobGraphs between batch and streaming, currently used by the scheduler.
- jobUrl - Variable in class org.apache.flink.runtime.rest.messages.job.JobSubmitResponseBody
-
The URL under which the job status can monitored.
- JobVertex - Class in org.apache.flink.runtime.jobgraph
-
The base class for job vertexes.
- JobVertex(String) - Constructor for class org.apache.flink.runtime.jobgraph.JobVertex
-
Constructs a new job vertex and assigns it with the given name.
- JobVertex(String, JobVertexID) - Constructor for class org.apache.flink.runtime.jobgraph.JobVertex
-
Constructs a new job vertex and assigns it with the given name.
- JobVertex(String, JobVertexID, List<OperatorIDPair>) - Constructor for class org.apache.flink.runtime.jobgraph.JobVertex
-
Constructs a new job vertex and assigns it with the given name.
- JobVertex.FinalizeOnMasterContext - Interface in org.apache.flink.runtime.jobgraph
-
The context exposes some runtime infos for finalization.
- JobVertex.InitializeOnMasterContext - Interface in org.apache.flink.runtime.jobgraph
- JobVertexAccumulatorsHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Request handler for the job vertex accumulators.
- JobVertexAccumulatorsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, JobVertexAccumulatorsInfo, JobVertexMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobVertexAccumulatorsHandler
- JobVertexAccumulatorsHeaders - Class in org.apache.flink.runtime.rest.messages
-
Message headers for the
JobVertexAccumulatorsHandler. - JobVertexAccumulatorsInfo - Class in org.apache.flink.runtime.rest.messages
-
Response type of the
JobVertexAccumulatorsHandler. - JobVertexAccumulatorsInfo(String, Collection<UserAccumulator>) - Constructor for class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsInfo
- JobVertexBackPressureHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Request handler for the job vertex back pressure.
- JobVertexBackPressureHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, JobVertexBackPressureInfo, JobVertexMessageParameters>, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobVertexBackPressureHandler
- JobVertexBackPressureHeaders - Class in org.apache.flink.runtime.rest.messages
-
Message headers for the
JobVertexBackPressureHandler. - JobVertexBackPressureHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
- JobVertexBackPressureInfo - Class in org.apache.flink.runtime.rest.messages
-
Response type of the
JobVertexBackPressureHandler. - JobVertexBackPressureInfo(JobVertexBackPressureInfo.VertexBackPressureStatus, JobVertexBackPressureInfo.VertexBackPressureLevel, Long, List<JobVertexBackPressureInfo.SubtaskBackPressureInfo>) - Constructor for class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
- JobVertexBackPressureInfo.SubtaskBackPressureInfo - Class in org.apache.flink.runtime.rest.messages
-
Nested class to encapsulate the sub tasks back pressure.
- JobVertexBackPressureInfo.VertexBackPressureLevel - Enum in org.apache.flink.runtime.rest.messages
-
Level of vertex back-pressure.
- JobVertexBackPressureInfo.VertexBackPressureStatus - Enum in org.apache.flink.runtime.rest.messages
-
Status of vertex back-pressure.
- JobVertexDetailsHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Request handler for the job vertex details.
- JobVertexDetailsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, JobVertexDetailsInfo, JobVertexMessageParameters>, ExecutionGraphCache, Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobVertexDetailsHandler
- JobVertexDetailsHeaders - Class in org.apache.flink.runtime.rest.messages
-
Message headers for the
JobVertexDetailsHandler. - JobVertexDetailsHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
- JobVertexDetailsInfo - Class in org.apache.flink.runtime.rest.messages
-
Response type of the
JobVertexDetailsHandler. - JobVertexDetailsInfo(JobVertexID, String, int, int, long, List<SubtaskExecutionAttemptDetailsInfo>) - Constructor for class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
- JobVertexDetailsInfo(JobVertexID, SlotSharingGroupId, String, int, int, ExecutionState, long, long, long, Map<ExecutionState, Integer>, IOMetricsInfo) - Constructor for class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- jobVertexFinished() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
-
Called whenever a job vertex reaches state FINISHED (completed successfully).
- jobVertexFinished() - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
- JobVertexFlameGraphHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Request handler for the job vertex Flame Graph.
- JobVertexFlameGraphHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, ExecutionGraphCache, Executor, VertexStatsTracker<VertexThreadInfoStats>) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobVertexFlameGraphHandler
- JobVertexFlameGraphHeaders - Class in org.apache.flink.runtime.rest.messages
-
Message headers for the
JobVertexFlameGraphHandler. - JobVertexFlameGraphHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.JobVertexFlameGraphHeaders
- JobVertexFlameGraphParameters - Class in org.apache.flink.runtime.rest.messages
-
Message parameters for job vertex Flame Graph REST handler.
- JobVertexFlameGraphParameters() - Constructor for class org.apache.flink.runtime.rest.messages.JobVertexFlameGraphParameters
- jobVertexID - Variable in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
JobVertexID of the owning subtask.
- JobVertexID - Class in org.apache.flink.runtime.jobgraph
-
A class for statistically unique job vertex IDs.
- JobVertexID() - Constructor for class org.apache.flink.runtime.jobgraph.JobVertexID
- JobVertexID(byte[]) - Constructor for class org.apache.flink.runtime.jobgraph.JobVertexID
- JobVertexID(long, long) - Constructor for class org.apache.flink.runtime.jobgraph.JobVertexID
- JobVertexIDDeserializer - Class in org.apache.flink.runtime.rest.messages.json
-
Jackson deserializer for
JobVertexID. - JobVertexIDDeserializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.JobVertexIDDeserializer
- JobVertexIDKeyDeserializer - Class in org.apache.flink.runtime.rest.messages.json
-
Jackson deserializer for
JobVertexID. - JobVertexIDKeyDeserializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.JobVertexIDKeyDeserializer
- JobVertexIDKeySerializer - Class in org.apache.flink.runtime.rest.messages.json
-
Jackson serializer for
JobVertexIDused as a key serializer. - JobVertexIDKeySerializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.JobVertexIDKeySerializer
- jobVertexIdPathParameter - Variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointMessageParameters
- jobVertexIdPathParameter - Variable in class org.apache.flink.runtime.rest.messages.JobVertexMessageParameters
- JobVertexIdPathParameter - Class in org.apache.flink.runtime.rest.messages
-
Path parameter specifying a
JobVertexID. - JobVertexIdPathParameter() - Constructor for class org.apache.flink.runtime.rest.messages.JobVertexIdPathParameter
- JobVertexIDSerializer - Class in org.apache.flink.runtime.rest.messages.json
-
Jackson serializer for
JobVertexID. - JobVertexIDSerializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.JobVertexIDSerializer
- JobVertexInputInfo - Class in org.apache.flink.runtime.executiongraph
-
This class describe how a job vertex consume an input(intermediate result).
- JobVertexInputInfo(List<ExecutionVertexInputInfo>) - Constructor for class org.apache.flink.runtime.executiongraph.JobVertexInputInfo
- JobVertexMessageParameters - Class in org.apache.flink.runtime.rest.messages
-
Message parameters for job vertex REST handlers.
- JobVertexMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.JobVertexMessageParameters
- JobVertexMetricsHandler - Class in org.apache.flink.runtime.rest.handler.job.metrics
-
Deprecated.This class is subsumed by
SubtaskMetricsHandlerand is only kept for backwards-compatibility. - JobVertexMetricsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.JobVertexMetricsHandler
-
Deprecated.
- JobVertexMetricsHeaders - Class in org.apache.flink.runtime.rest.messages.job.metrics
- JobVertexMetricsMessageParameters - Class in org.apache.flink.runtime.rest.messages.job.metrics
- JobVertexMetricsMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexMetricsMessageParameters
- JobVertexResourceRequirements - Class in org.apache.flink.runtime.jobgraph
-
Information about the parallelism of job vertices.
- JobVertexResourceRequirements(JobVertexResourceRequirements.Parallelism) - Constructor for class org.apache.flink.runtime.jobgraph.JobVertexResourceRequirements
- JobVertexResourceRequirements.Parallelism - Class in org.apache.flink.runtime.jobgraph
- JobVertexTaskManagersHandler - Class in org.apache.flink.runtime.rest.handler.job
-
A request handler that provides the details of a job vertex, including id, name, and the runtime and metrics of all its subtasks aggregated by TaskManager.
- JobVertexTaskManagersHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, JobVertexTaskManagersInfo, JobVertexMessageParameters>, ExecutionGraphCache, Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobVertexTaskManagersHandler
- JobVertexTaskManagersHeaders - Class in org.apache.flink.runtime.rest.messages
-
Message headers for the
JobVertexTaskManagersHandler. - JobVertexTaskManagersInfo - Class in org.apache.flink.runtime.rest.messages
-
Response type of the
JobVertexTaskManagersHandler. - JobVertexTaskManagersInfo(JobVertexID, String, long, Collection<JobVertexTaskManagersInfo.TaskManagersInfo>) - Constructor for class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo
- JobVertexTaskManagersInfo.TaskManagersInfo - Class in org.apache.flink.runtime.rest.messages
-
Detailed information about task managers.
- jobVertexUnFinished() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- jobVertexUnFinished() - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
- JobVertexWatermarksHandler - Class in org.apache.flink.runtime.rest.handler.job.metrics
-
Handler that returns the watermarks given a
JobIDandJobVertexID. - JobVertexWatermarksHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MetricFetcher, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.JobVertexWatermarksHandler
- JobVertexWatermarksHeaders - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
MessageHeadersfor retrieving watermarks. - join(DataStream<T2>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Creates a join operation.
- JoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
-
The join driver implements the logic of a join operator at runtime.
- JoinDriver() - Constructor for class org.apache.flink.runtime.operators.JoinDriver
- JoinedStreams<T1,T2> - Class in org.apache.flink.streaming.api.datastream
-
JoinedStreamsrepresents twoDataStreamsthat have been joined. - JoinedStreams(DataStream<T1>, DataStream<T2>) - Constructor for class org.apache.flink.streaming.api.datastream.JoinedStreams
-
Creates new JoinedStreams data streams, which are the first step towards building a streaming co-group.
- JoinedStreams.Where<KEY> - Class in org.apache.flink.streaming.api.datastream
-
Joined streams that have the key for one side defined.
- JoinedStreams.Where.EqualTo - Class in org.apache.flink.streaming.api.datastream
-
A join operation that has
KeySelectorsdefined for both inputs. - JoinedStreams.WithWindow<T1,T2,KEY,W extends Window> - Class in org.apache.flink.streaming.api.datastream
-
A join operation that has
KeySelectorsdefined for both inputs as well as aWindowAssigner. - JoinTaskIterator<V1,V2,O> - Interface in org.apache.flink.runtime.operators.util
-
Interface of an iterator that performs the logic of a match task.
- JoinWithSolutionSetFirstDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
- JoinWithSolutionSetFirstDriver() - Constructor for class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
- JoinWithSolutionSetSecondDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
- JoinWithSolutionSetSecondDriver() - Constructor for class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
- JsonArchivist - Interface in org.apache.flink.runtime.webmonitor.history
-
Interface for all classes that want to participate in the archiving of job-related json responses.
- JsonFactory - Class in org.apache.flink.runtime.rest.handler.legacy
-
A holder for the singleton Jackson JSON factory.
- JSONGenerator - Class in org.apache.flink.streaming.api.graph
-
Helper class for generating a JSON representation from a
StreamGraph. - JSONGenerator(StreamGraph) - Constructor for class org.apache.flink.streaming.api.graph.JSONGenerator
- JsonPlanGenerator - Class in org.apache.flink.runtime.jobgraph.jsonplan
- JsonPlanGenerator() - Constructor for class org.apache.flink.runtime.jobgraph.jsonplan.JsonPlanGenerator
- JVM_SHUTDOWN - org.apache.flink.runtime.taskexecutor.TaskManagerRunner.Result
- JvmMetaspaceAndOverhead - Class in org.apache.flink.runtime.util.config.memory
-
JVM metaspace and overhead memory sizes.
- JvmMetaspaceAndOverhead(MemorySize, MemorySize) - Constructor for class org.apache.flink.runtime.util.config.memory.JvmMetaspaceAndOverhead
- JvmMetaspaceAndOverheadOptions - Class in org.apache.flink.runtime.util.config.memory
-
Options to calculate JVM Metaspace and Overhead.
- JvmMetaspaceAndOverheadOptions(ConfigOption<MemorySize>, ConfigOption<MemorySize>, ConfigOption<MemorySize>, ConfigOption<Float>) - Constructor for class org.apache.flink.runtime.util.config.memory.JvmMetaspaceAndOverheadOptions
- JvmShutdownSafeguard - Class in org.apache.flink.runtime.util
-
A utility that guards against blocking shutdown hooks that block JVM shutdown.
- JvmUtils - Class in org.apache.flink.runtime.util
-
Utilities for
ManagementFactory.
K
- KeepAliveWrite - Class in org.apache.flink.runtime.rest.handler.util
-
Utilities to write.
- KeepAliveWrite() - Constructor for class org.apache.flink.runtime.rest.handler.util.KeepAliveWrite
- keepBuildSidePartitions - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
If true, build side partitions are kept for multiple probe steps.
- KerberosLoginProvider - Class in org.apache.flink.runtime.security.token.hadoop
-
Provides Kerberos login functionality.
- KerberosLoginProvider(Configuration) - Constructor for class org.apache.flink.runtime.security.token.hadoop.KerberosLoginProvider
- KerberosLoginProvider(SecurityConfiguration) - Constructor for class org.apache.flink.runtime.security.token.hadoop.KerberosLoginProvider
- KerberosUtils - Class in org.apache.flink.runtime.security
-
Provides vendor-specific Kerberos
AppConfigurationEntryinstances. - KerberosUtils() - Constructor for class org.apache.flink.runtime.security.KerberosUtils
- key - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
- key - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
- key() - Method in class org.apache.flink.runtime.state.heap.HeapKeyValueStateIterator
- key() - Method in interface org.apache.flink.runtime.state.KeyValueStateIterator
- KEY - org.apache.flink.runtime.metrics.groups.AbstractMetricGroup.ChildType
- KEY - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointIdPathParameter
- KEY - Static variable in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetIdPathParameter
- KEY - Static variable in class org.apache.flink.runtime.rest.messages.FlameGraphTypeQueryParameter
- KEY - Static variable in class org.apache.flink.runtime.rest.messages.job.FailureLabelFilterParameter
- KEY - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskAttemptPathParameter
-
The constant subtask attempt KEY.
- KEY - Static variable in class org.apache.flink.runtime.rest.messages.job.UpperLimitExceptionParameter
- KEY - Static variable in class org.apache.flink.runtime.rest.messages.JobIDPathParameter
- KEY - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexIdPathParameter
- KEY - Static variable in class org.apache.flink.runtime.rest.messages.LogFileNamePathParameter
- KEY - Static variable in class org.apache.flink.runtime.rest.messages.OperatorUidPathParameter
-
This id must be defined to identify an operator on the client side before submit jobs.
- KEY - Static variable in class org.apache.flink.runtime.rest.messages.ProfilingFileNamePathParameter
- KEY - Static variable in class org.apache.flink.runtime.rest.messages.RescalingParallelismQueryParameter
- KEY - Static variable in class org.apache.flink.runtime.rest.messages.SubtaskIndexPathParameter
- KEY - Static variable in class org.apache.flink.runtime.rest.messages.SubtaskIndexQueryParameter
- KEY - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerIdPathParameter
- KEY - Static variable in class org.apache.flink.runtime.rest.messages.TriggerIdPathParameter
- KEY_EXTRACTOR_FUNCTION - Static variable in interface org.apache.flink.streaming.api.operators.InternalTimer
-
Function to extract the key from a
InternalTimer. - KEY_SERIALIZER - org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.CommonSerializerKeys
- KEY_VALUE - org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.BackendStateType
- KEY_VALUE_V2 - org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.BackendStateType
- KeyAccountingUnit<K> - Class in org.apache.flink.runtime.asyncprocessing
-
Key accounting unit holds the current in-flight key and tracks the corresponding ongoing records, which is used to preserve the ordering of independent chained
StateFuture. - KeyAccountingUnit(int) - Constructor for class org.apache.flink.runtime.asyncprocessing.KeyAccountingUnit
- keyBy(int[], int[]) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Deprecated.
- keyBy(int, int) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Deprecated.
- keyBy(String[], String[]) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Deprecated.
- keyBy(String, String) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Deprecated.
- keyBy(Keys<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
- keyBy(KeySelector<IN1, KEY>, KeySelector<IN2, KEY>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
KeyBy operation for connected data stream.
- keyBy(KeySelector<IN1, KEY>, KeySelector<IN2, KEY>, TypeInformation<KEY>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
KeyBy operation for connected data stream.
- keyBy(KeySelector<T, K>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
It creates a new
KeyedStreamthat uses the provided key for partitioning its operator states. - keyBy(KeySelector<T, K>, TypeInformation<K>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
It creates a new
KeyedStreamthat uses the provided key with explicit type information for partitioning its operator states. - keyContext - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
The key context for this backend.
- keyContext - Variable in class org.apache.flink.runtime.state.heap.StateTable
-
The key context view on the backend.
- keyContext - Variable in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
- KeyContext - Interface in org.apache.flink.streaming.api.operators
-
Interface for setting and querying the current key of keyed operations.
- KeyContextHandler - Interface in org.apache.flink.streaming.api.operators
-
This interface is used to optimize the calls of
Input.setKeyContextElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IN>),StreamOperator.setKeyContextElement1(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<?>)andStreamOperator.setKeyContextElement2(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<?>). - Keyed<K> - Interface in org.apache.flink.runtime.state
-
Interface for objects that have a key attribute.
- KEYED_STATE_TYPE - org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.CommonOptionsKeys
-
Key to define the
StateDescriptor.Typeof a key/value keyed-state - KeyedBackendSerializationProxy<K> - Class in org.apache.flink.runtime.state
-
Serialization proxy for all meta data in keyed state backends.
- KeyedBackendSerializationProxy(ClassLoader) - Constructor for class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
- KeyedBackendSerializationProxy(TypeSerializer<K>, List<StateMetaInfoSnapshot>, boolean) - Constructor for class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
- KeyedBroadcastProcessFunction<KS,IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
-
A function to be applied to a
BroadcastConnectedStreamthat connectsBroadcastStream, i.e. - KeyedBroadcastProcessFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction
- KeyedBroadcastProcessFunction.Context - Class in org.apache.flink.streaming.api.functions.co
-
A
contextavailable to the broadcast side of aBroadcastConnectedStream. - KeyedBroadcastProcessFunction.OnTimerContext - Class in org.apache.flink.streaming.api.functions.co
-
Information available in an invocation of
#onTimer(long, OnTimerContext, Collector). - KeyedBroadcastProcessFunction.ReadOnlyContext - Class in org.apache.flink.streaming.api.functions.co
-
A
contextavailable to the keyed stream side of aBroadcastConnectedStream(if any). - KeyedBroadcastStateTransformation<KEY,IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.transformations
-
A keyed
AbstractBroadcastStateTransformation. - KeyedBroadcastStateTransformation(String, Transformation<IN1>, Transformation<IN2>, KeyedBroadcastProcessFunction<KEY, IN1, IN2, OUT>, List<MapStateDescriptor<?, ?>>, TypeInformation<KEY>, KeySelector<IN1, KEY>, TypeInformation<OUT>, int, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.KeyedBroadcastStateTransformation
- KeyedBroadcastStateTransformationTranslator<KEY,IN1,IN2,OUT> - Class in org.apache.flink.streaming.runtime.translators
- KeyedBroadcastStateTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.KeyedBroadcastStateTransformationTranslator
- KeyedCoProcessFunction<K,IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
-
A function that processes elements of two keyed streams and produces a single output one.
- KeyedCoProcessFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction
- KeyedCoProcessFunction.Context - Class in org.apache.flink.streaming.api.functions.co
-
Information available in an invocation of
#processElement1(Object, Context, Collector)/#processElement2(Object, Context, Collector)or#onTimer(long, OnTimerContext, Collector). - KeyedCoProcessFunction.OnTimerContext - Class in org.apache.flink.streaming.api.functions.co
-
Information available in an invocation of
#onTimer(long, OnTimerContext, Collector). - KeyedCoProcessOperator<K,IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
A
StreamOperatorfor executing keyedKeyedCoProcessFunction. - KeyedCoProcessOperator(KeyedCoProcessFunction<K, IN1, IN2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
- KeyedMultipleInputTransformation<OUT> - Class in org.apache.flink.streaming.api.transformations
-
AbstractMultipleInputTransformationimplementation for keyed streams. - KeyedMultipleInputTransformation(String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int, TypeInformation<?>) - Constructor for class org.apache.flink.streaming.api.transformations.KeyedMultipleInputTransformation
- KeyedPartitionWindowedStream<T,KEY> - Class in org.apache.flink.streaming.api.datastream
-
KeyedPartitionWindowedStreamrepresents a data stream that collects all records with the same key separately into a full window. - KeyedPartitionWindowedStream(StreamExecutionEnvironment, KeyedStream<T, KEY>) - Constructor for class org.apache.flink.streaming.api.datastream.KeyedPartitionWindowedStream
- KeyedProcessFunction<K,I,O> - Class in org.apache.flink.streaming.api.functions
-
A keyed function that processes elements of a stream.
- KeyedProcessFunction() - Constructor for class org.apache.flink.streaming.api.functions.KeyedProcessFunction
- KeyedProcessFunction.Context - Class in org.apache.flink.streaming.api.functions
-
Information available in an invocation of
#processElement(Object, Context, Collector)or#onTimer(long, OnTimerContext, Collector). - KeyedProcessFunction.OnTimerContext - Class in org.apache.flink.streaming.api.functions
-
Information available in an invocation of
#onTimer(long, OnTimerContext, Collector). - KeyedProcessOperator<K,IN,OUT> - Class in org.apache.flink.streaming.api.operators
-
A
StreamOperatorfor executingKeyedProcessFunctions. - KeyedProcessOperator(KeyedProcessFunction<K, IN, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.KeyedProcessOperator
- KeyedSortPartitionOperator<INPUT,KEY> - Class in org.apache.flink.streaming.api.operators.sortpartition
-
The
KeyedSortPartitionOperatorsorts records of a partition onKeyedStream. - KeyedSortPartitionOperator(TypeInformation<INPUT>, int, Order) - Constructor for class org.apache.flink.streaming.api.operators.sortpartition.KeyedSortPartitionOperator
- KeyedSortPartitionOperator(TypeInformation<INPUT>, String, Order) - Constructor for class org.apache.flink.streaming.api.operators.sortpartition.KeyedSortPartitionOperator
- KeyedSortPartitionOperator(TypeInformation<INPUT>, KeySelector<INPUT, K>, Order) - Constructor for class org.apache.flink.streaming.api.operators.sortpartition.KeyedSortPartitionOperator
- keyedStateBackend - Variable in class org.apache.flink.runtime.state.DefaultKeyedStateStore
- keyedStateBackend() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
-
Returns the keyed state backend for the stream operator.
- KeyedStateBackend<K> - Interface in org.apache.flink.runtime.state
-
A keyed state backend provides methods for managing keyed state.
- KeyedStateBackend.KeySelectionListener<K> - Interface in org.apache.flink.runtime.state
-
Listener is given a callback when
KeyedStateBackend.setCurrentKey(K)is called (key context changes). - KeyedStateBackendParametersImpl<K> - Class in org.apache.flink.runtime.state
-
Internal POJO implementing
StateBackend.KeyedStateBackendParameters - KeyedStateBackendParametersImpl(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry, TtlTimeProvider, MetricGroup, Collection<KeyedStateHandle>, CloseableRegistry) - Constructor for class org.apache.flink.runtime.state.KeyedStateBackendParametersImpl
- KeyedStateBackendParametersImpl(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry, TtlTimeProvider, MetricGroup, StateBackend.CustomInitializationMetrics, Collection<KeyedStateHandle>, CloseableRegistry, double) - Constructor for class org.apache.flink.runtime.state.KeyedStateBackendParametersImpl
- KeyedStateBackendParametersImpl(StateBackend.KeyedStateBackendParameters<K>) - Constructor for class org.apache.flink.runtime.state.KeyedStateBackendParametersImpl
- keyedStateCheckpointClosingFuture - Variable in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
- KeyedStateCheckpointOutputStream - Class in org.apache.flink.runtime.state
-
Checkpoint output stream that allows to write raw keyed state in a partitioned way, split into key-groups.
- KeyedStateCheckpointOutputStream(CheckpointStateOutputStream, KeyGroupRange) - Constructor for class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
- keyedStatedBackend(TypeSerializer<K>, String, PrioritizedOperatorSubtaskState, CloseableRegistry, MetricGroup, double, StateObject.StateObjectSizeStatsCollector, StreamTaskStateInitializerImpl.KeyedStateBackendCreator<K, R>) - Method in class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
- KeyedStateFactory - Interface in org.apache.flink.runtime.state
-
This factory produces concrete internal state objects.
- KeyedStateFunction<K,S extends org.apache.flink.api.common.state.State> - Interface in org.apache.flink.runtime.state
-
A function to be applied to all keyed states.
- KeyedStateHandle - Interface in org.apache.flink.runtime.state
-
Base for the handles of the checkpointed states in keyed streams.
- KeyedStateStoreV2 - Interface in org.apache.flink.runtime.state.v2
-
This interface contains methods for registering
State. - KeyedStream<T,KEY> - Class in org.apache.flink.streaming.api.datastream
-
A
KeyedStreamrepresents aDataStreamon which operator state is partitioned by key using a providedKeySelector. - KeyedStream(DataStream<T>, KeySelector<T, KEY>) - Constructor for class org.apache.flink.streaming.api.datastream.KeyedStream
-
Creates a new
KeyedStreamusing the givenKeySelectorto partition operator state by key. - KeyedStream(DataStream<T>, KeySelector<T, KEY>, TypeInformation<KEY>) - Constructor for class org.apache.flink.streaming.api.datastream.KeyedStream
-
Creates a new
KeyedStreamusing the givenKeySelectorto partition operator state by key. - KeyedStream.IntervalJoin<T1,T2,KEY> - Class in org.apache.flink.streaming.api.datastream
-
Perform a join over a time interval.
- KeyedStream.IntervalJoined<IN1,IN2,KEY> - Class in org.apache.flink.streaming.api.datastream
-
IntervalJoined is a container for two streams that have keys for both sides as well as the time boundaries over which elements should be joined.
- KeyExtractorFunction<T> - Interface in org.apache.flink.runtime.state
-
Function to extract a key from a given object.
- keyGroup() - Method in class org.apache.flink.runtime.state.heap.HeapKeyValueStateIterator
- keyGroup() - Method in interface org.apache.flink.runtime.state.KeyValueStateIterator
-
Returns the key-group for the current key.
- KeyGroup - Class in org.apache.flink.runtime.state.restore
-
Part of a savepoint representing data for a single key group.
- keyGroupCompressionDecorator - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
Decorates the input and output streams to write key-groups compressed.
- keyGroupCompressionDecorator - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
- KeyGroupedInternalPriorityQueue<T> - Interface in org.apache.flink.runtime.state
-
This interface exists as (temporary) adapter between the new
InternalPriorityQueueand the old way in which timers are written in a snapshot. - KeyGroupedIterator<E> - Interface in org.apache.flink.runtime.util
- keyGroupedStateMaps - Variable in class org.apache.flink.runtime.state.heap.StateTable
-
Map for holding the actual state objects.
- KeyGroupEntry - Class in org.apache.flink.runtime.state.restore
-
Part of a savepoint representing data for a single state entry in a key group.
- KeyGroupPartitionedPriorityQueue<T,PQ extends InternalPriorityQueue<T> & HeapPriorityQueueElement> - Class in org.apache.flink.runtime.state.heap
-
This implementation of
InternalPriorityQueueis internally partitioned into sub-queues per key-group and essentially works as a heap-of-heaps. - KeyGroupPartitionedPriorityQueue(KeyExtractorFunction<T>, PriorityComparator<T>, KeyGroupPartitionedPriorityQueue.PartitionQueueSetFactory<T, PQ>, KeyGroupRange, int) - Constructor for class org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
- KeyGroupPartitionedPriorityQueue.PartitionQueueSetFactory<T,PQS extends InternalPriorityQueue<T> & HeapPriorityQueueElement> - Interface in org.apache.flink.runtime.state.heap
-
Factory that produces the sub-queues that represent the partitions of a
KeyGroupPartitionedPriorityQueue. - KeyGroupPartitioner<T> - Class in org.apache.flink.runtime.state
-
Class that contains the base algorithm for partitioning data into key-groups.
- KeyGroupPartitioner(T[], int, T[], KeyGroupRange, int, KeyExtractorFunction<T>, KeyGroupPartitioner.ElementWriterFunction<T>) - Constructor for class org.apache.flink.runtime.state.KeyGroupPartitioner
-
Creates a new
KeyGroupPartitioner. - KeyGroupPartitioner.ElementReaderFunction<T> - Interface in org.apache.flink.runtime.state
-
This functional interface defines how one element is read from a
DataInputView. - KeyGroupPartitioner.ElementWriterFunction<T> - Interface in org.apache.flink.runtime.state
-
This functional interface defines how one element is written to a
DataOutputView. - KeyGroupPartitioner.KeyGroupElementsConsumer<T> - Interface in org.apache.flink.runtime.state
-
Functional interface to consume elements from a key group.
- KeyGroupPartitioner.PartitioningResult<T> - Interface in org.apache.flink.runtime.state
-
This represents the result of key-group partitioning.
- keyGroupRange - Variable in class org.apache.flink.runtime.state.AbstractIncrementalStateHandle
-
The key-group range covered by this state handle.
- keyGroupRange - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
Range of key-groups for which this backend is responsible.
- keyGroupRange - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
- keyGroupRange - Variable in class org.apache.flink.runtime.state.heap.StateTable
-
The current key group range.
- KeyGroupRange - Class in org.apache.flink.runtime.state
-
This class defines a range of key-group indexes.
- KeyGroupRange(int, int) - Constructor for class org.apache.flink.runtime.state.KeyGroupRange
-
Defines the range [startKeyGroup, endKeyGroup]
- KeyGroupRangeAssignment - Class in org.apache.flink.runtime.state
- KeyGroupRangeOffsets - Class in org.apache.flink.runtime.state
-
This class combines a key-group range with offsets that correspond to the key-groups in the range.
- KeyGroupRangeOffsets(int, int) - Constructor for class org.apache.flink.runtime.state.KeyGroupRangeOffsets
-
Creates key-group range with offsets from the given start key-group to end key-group.
- KeyGroupRangeOffsets(int, int, long[]) - Constructor for class org.apache.flink.runtime.state.KeyGroupRangeOffsets
-
Creates key-group range with offsets from the given start key-group to end key-group.
- KeyGroupRangeOffsets(KeyGroupRange) - Constructor for class org.apache.flink.runtime.state.KeyGroupRangeOffsets
-
Creates key-group range with offsets for the given key-group range, where all offsets are initially zero.
- KeyGroupRangeOffsets(KeyGroupRange, long[]) - Constructor for class org.apache.flink.runtime.state.KeyGroupRangeOffsets
-
Creates key-group range with offsets from the given key-group range.
- keyGroupReader(int) - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueSnapshotRestoreWrapper
- keyGroupReader(int) - Method in class org.apache.flink.runtime.state.heap.StateTable
- keyGroupReader(int) - Method in interface org.apache.flink.runtime.state.StateSnapshotRestore
-
This method returns a
StateSnapshotKeyGroupReaderthat can be used to restore the state on a per-key-group basis. - KeyGroupsList - Interface in org.apache.flink.runtime.state
-
This interface offers ordered random read access to multiple key group ids.
- KeyGroupsSavepointStateHandle - Class in org.apache.flink.runtime.state
-
A
KeyGroupsStateHandlethat describes a savepoint in the unified format. - KeyGroupsSavepointStateHandle(KeyGroupRangeOffsets, StreamStateHandle) - Constructor for class org.apache.flink.runtime.state.KeyGroupsSavepointStateHandle
- KeyGroupsStateHandle - Class in org.apache.flink.runtime.state
-
A handle to the partitioned stream operator state after it has been checkpointed.
- KeyGroupsStateHandle(KeyGroupRangeOffsets, StreamStateHandle) - Constructor for class org.apache.flink.runtime.state.KeyGroupsStateHandle
- KeyGroupStatePartitionStreamProvider - Class in org.apache.flink.runtime.state
-
This class provides access to an input stream that contains state data for one key group and the key group id.
- KeyGroupStatePartitionStreamProvider(InputStream, int) - Constructor for class org.apache.flink.runtime.state.KeyGroupStatePartitionStreamProvider
- KeyGroupStatePartitionStreamProvider(IOException, int) - Constructor for class org.apache.flink.runtime.state.KeyGroupStatePartitionStreamProvider
- KeyGroupStreamPartitioner<T,K> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner selects the target channel based on the key group index.
- KeyGroupStreamPartitioner(KeySelector<T, K>, int) - Constructor for class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
- keys() - Method in class org.apache.flink.runtime.state.v2.AbstractMapState
- keys() - Method in class org.apache.flink.runtime.state.v2.adaptor.MapStateAdaptor
- keySelected(K) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend.KeySelectionListener
-
Callback when key context is switched.
- keySelected(K) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeServiceManager
- keySelector - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorFactory
- KeySelectorUtil - Class in org.apache.flink.streaming.util.keys
-
Utility class that contains helper methods to manipulating
KeySelectorfor streaming. - KeySelectorUtil.ArrayKeySelector<IN> - Class in org.apache.flink.streaming.util.keys
-
A key selector for selecting individual array fields as keys and returns them as a Tuple.
- KeySelectorUtil.ComparableKeySelector<IN> - Class in org.apache.flink.streaming.util.keys
-
A key selector for selecting key fields via a TypeComparator.
- KeySelectorUtil.OneKeySelector<IN,K> - Class in org.apache.flink.streaming.util.keys
-
Key extractor that extracts a single field via a generic comparator.
- keySerializer - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
The key serializer.
- keySerializer - Variable in class org.apache.flink.runtime.state.heap.AbstractHeapState
- keySerializer - Variable in class org.apache.flink.runtime.state.heap.StateTable
-
The serializer of the key.
- keySerializer - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
For serializing the key in checkpoints.
- keySerializer - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorFactory
- keySerializerProvider - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
- keySetA() - Method in class org.apache.flink.runtime.util.DualKeyLinkedMap
- keySetB() - Method in class org.apache.flink.runtime.util.DualKeyLinkedMap
- keytabEntry(String, String) - Static method in class org.apache.flink.runtime.security.KerberosUtils
- KeyValueStateIterator - Interface in org.apache.flink.runtime.state
-
Iterator that over all key-value state entries in a
KeyedStateBackend. - known(UUID, String) - Static method in class org.apache.flink.runtime.leaderelection.LeaderInformation
- KUBERNETES - org.apache.flink.runtime.jobmanager.HighAvailabilityMode
- KvStateClientProxy - Interface in org.apache.flink.runtime.query
-
An interface for the Queryable State Client Proxy running on each Task Manager in the cluster.
- KvStateEntry<K,N,V> - Class in org.apache.flink.runtime.query
-
An entry holding the
InternalKvStatealong with itsKvStateInfo. - KvStateEntry(InternalKvState<K, N, V>, ClassLoader) - Constructor for class org.apache.flink.runtime.query.KvStateEntry
- KvStateHandler - Class in org.apache.flink.runtime.scheduler
-
Handler for common queryable state logic.
- KvStateHandler(ExecutionGraph) - Constructor for class org.apache.flink.runtime.scheduler.KvStateHandler
- kvStateId() - Method in class org.apache.flink.runtime.state.heap.HeapKeyValueStateIterator
- kvStateId() - Method in interface org.apache.flink.runtime.state.KeyValueStateIterator
-
Returns the Id of the K/V state to which the current key belongs.
- KvStateInfo<K,N,V> - Class in org.apache.flink.runtime.query
-
Metadata about a
InternalKvState. - KvStateInfo(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<V>) - Constructor for class org.apache.flink.runtime.query.KvStateInfo
- KvStateLocation - Class in org.apache.flink.runtime.query
-
Location information for all key groups of a
InternalKvStateinstance. - KvStateLocation(JobID, JobVertexID, int, String) - Constructor for class org.apache.flink.runtime.query.KvStateLocation
-
Creates the location information.
- KvStateLocationOracle - Interface in org.apache.flink.runtime.jobmaster
-
Oracle for
KvStateLocationin the cluster. - KvStateLocationRegistry - Class in org.apache.flink.runtime.query
-
Simple registry, which maps
InternalKvStateregistration notifications toKvStateLocationinstances. - KvStateLocationRegistry(JobID, Map<JobVertexID, ExecutionJobVertex>) - Constructor for class org.apache.flink.runtime.query.KvStateLocationRegistry
-
Creates the registry for the job.
- kvStateRegistry - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
KvStateRegistry helper for this task.
- kvStateRegistry - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
- KvStateRegistry - Class in org.apache.flink.runtime.query
-
A registry for
InternalKvStateinstances per task manager. - KvStateRegistry() - Constructor for class org.apache.flink.runtime.query.KvStateRegistry
- KvStateRegistryGateway - Interface in org.apache.flink.runtime.jobmaster
-
Gateway to report key-value state registration and deregistrations.
- KvStateRegistryListener - Interface in org.apache.flink.runtime.query
-
A listener for a
KvStateRegistry. - KvStateServer - Interface in org.apache.flink.runtime.query
-
An interface for the Queryable State Server running on each Task Manager in the cluster.
- KvStateService - Class in org.apache.flink.runtime.taskexecutor
-
KvState related components of each
TaskExecutorinstance. - KvStateService(KvStateRegistry, KvStateServer, KvStateClientProxy) - Constructor for class org.apache.flink.runtime.taskexecutor.KvStateService
L
- LabeledGlobalFailureHandler - Interface in org.apache.flink.runtime.scheduler.adaptive
-
An interface for handling and associating global failures with labels from
FailureEnricher. - labelFailure(Throwable, FailureEnricher.Context, Executor, Collection<FailureEnricher>) - Static method in class org.apache.flink.runtime.failure.FailureEnricherUtils
-
Enriches a Throwable by returning the merged label output of a Set of FailureEnrichers.
- LargeRecordHandler<T> - Class in org.apache.flink.runtime.operators.sort
- LargeRecordHandler(TypeSerializer<T>, TypeComparator<T>, IOManager, MemoryManager, List<MemorySegment>, TaskInvokable, int, ExecutionConfig) - Constructor for class org.apache.flink.runtime.operators.sort.LargeRecordHandler
- largeRecords(boolean) - Method in class org.apache.flink.runtime.operators.sort.ExternalSorterBuilder
- LAST_RECORD_FROM_BUFFER - org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
- lastIndexEntryAddresses - Variable in class org.apache.flink.runtime.io.network.partition.SortBuffer
-
Addresses of the last record's index entry for each subpartition.
- lastRecordAttributes - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- lastRecordAttributes1 - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- lastRecordAttributes2 - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- LastStateConnectionStateListener - Interface in org.apache.flink.runtime.checkpoint
-
ConnectionStateListenerwhich records the last state it was notified about. - lateDataOutputTag - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
OutputTagto use for late arriving events. - lateDataOutputTag - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorFactory
- LatencyMarker - Class in org.apache.flink.streaming.runtime.streamrecord
-
Special record type carrying a timestamp of its creation time at a source operator and the vertexId and subtask index of the operator.
- LatencyMarker(long, OperatorID, int) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
-
Creates a latency mark with the given timestamp.
- latencyStats - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- latencyStats - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- LatencyStats - Class in org.apache.flink.streaming.util
-
The
LatencyStatsobjects are used to track and report on the behavior of latencies across measurements. - LatencyStats(MetricGroup, int, int, OperatorID, LatencyStats.Granularity) - Constructor for class org.apache.flink.streaming.util.LatencyStats
- LatencyStats.Granularity - Enum in org.apache.flink.streaming.util
-
Granularity for latency metrics.
- latencyTrackingConfigBuilder - Variable in class org.apache.flink.runtime.state.AbstractStateBackend
- latencyTrackingStateConfig - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- latencyTrackingStateConfig - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
- LatencyTrackingStateConfig - Class in org.apache.flink.runtime.state.metrics
-
Config to create latency tracking state metric.
- LatencyTrackingStateConfig.Builder - Class in org.apache.flink.runtime.state.metrics
- LatencyTrackingStateFactory<K,N,V,S extends org.apache.flink.api.common.state.State,IS extends InternalKvState<K,N,?>> - Class in org.apache.flink.runtime.state.metrics
-
Factory to create
AbstractLatencyTrackState. - LATEST_LOAD_TIME - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- LatestCheckpoints(CheckpointStatistics.CompletedCheckpointStatistics, CheckpointStatistics.CompletedCheckpointStatistics, CheckpointStatistics.FailedCheckpointStatistics, CheckpointingStatistics.RestoredCheckpointStatistics) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
- latestLoadTimeGauge(Gauge<Long>) - Method in class org.apache.flink.runtime.metrics.groups.InternalCacheMetricGroup
- lazyDestroy() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
Destroys this buffer pool.
- lazyDestroy() - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
-
Destroy is called after the produce or consume phase of a task finishes.
- lazyInitialize(GlobalFailureHandler, ComponentMainThreadExecutor, CheckpointCoordinator) - Method in class org.apache.flink.runtime.operators.coordination.OperatorCoordinatorHolder
- lazyInitialize(GlobalFailureHandler, ComponentMainThreadExecutor, CheckpointCoordinator, int) - Method in class org.apache.flink.runtime.operators.coordination.OperatorCoordinatorHolder
- LeaderConnectingAddressListener(RpcSystemUtils) - Constructor for class org.apache.flink.runtime.net.ConnectionUtils.LeaderConnectingAddressListener
- LeaderContender - Interface in org.apache.flink.runtime.leaderelection
-
Interface which has to be implemented to take part in the leader election process of the
LeaderElectionService. - LeaderElection - Interface in org.apache.flink.runtime.leaderelection
- LeaderElectionDriver - Interface in org.apache.flink.runtime.leaderelection
-
A leader election driver that allows to write
LeaderInformationfor multiple components. - LeaderElectionDriver.Listener - Interface in org.apache.flink.runtime.leaderelection
-
Listener interface for state changes of the
LeaderElectionDriver. - LeaderElectionDriverFactory - Interface in org.apache.flink.runtime.leaderelection
-
Factory for
LeaderElectionDriver. - LeaderElectionException - Exception in org.apache.flink.runtime.leaderelection
-
This exception is used in leader election-related scenarios.
- LeaderElectionException(String) - Constructor for exception org.apache.flink.runtime.leaderelection.LeaderElectionException
- LeaderElectionException(String, Throwable) - Constructor for exception org.apache.flink.runtime.leaderelection.LeaderElectionException
- LeaderElectionException(Throwable) - Constructor for exception org.apache.flink.runtime.leaderelection.LeaderElectionException
- LeaderElectionService - Interface in org.apache.flink.runtime.leaderelection
-
Interface for a service which allows to elect a leader among a group of contenders.
- LeaderElectionUtils - Class in org.apache.flink.runtime.leaderelection
-
LeaderElectionUtilscollects helper methods to handle LeaderElection-related issues. - LeaderElectionUtils() - Constructor for class org.apache.flink.runtime.leaderelection.LeaderElectionUtils
- LeaderGatewayRetriever<T extends org.apache.flink.runtime.rpc.RpcGateway> - Class in org.apache.flink.runtime.webmonitor.retriever
-
Retrieves and stores the leading
RpcGateway. - LeaderGatewayRetriever() - Constructor for class org.apache.flink.runtime.webmonitor.retriever.LeaderGatewayRetriever
- LeaderInformation - Class in org.apache.flink.runtime.leaderelection
-
Information about leader including the confirmed leader session id and leader address.
- LeaderInformationListener() - Constructor for class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderInformationListener
- LeaderInformationRegister - Class in org.apache.flink.runtime.leaderelection
-
A register containing the
LeaderInformationfor multiple contenders based on theircomponentId. - LeaderInformationRegister(Map<String, LeaderInformation>) - Constructor for class org.apache.flink.runtime.leaderelection.LeaderInformationRegister
-
Creates a
LeaderInformationRegisterbased on the passed leader information. - LeaderRetrievalDriver - Interface in org.apache.flink.runtime.leaderretrieval
-
A
LeaderRetrievalDriveris responsible for retrieves the current leader which has been elected by theLeaderElectionDriver. - LeaderRetrievalDriverFactory - Interface in org.apache.flink.runtime.leaderretrieval
-
Factory for creating
LeaderRetrievalDriverwith different implementation. - LeaderRetrievalEventHandler - Interface in org.apache.flink.runtime.leaderretrieval
-
Interface which should be implemented to notify to
LeaderInformationchanges inLeaderRetrievalDriver. - LeaderRetrievalException - Exception in org.apache.flink.runtime.leaderretrieval
-
This exception is thrown by the
LeaderRetrievalUtilswhen the method retrieveLeaderGateway fails to retrieve the current leader's gateway. - LeaderRetrievalException(String) - Constructor for exception org.apache.flink.runtime.leaderretrieval.LeaderRetrievalException
- LeaderRetrievalException(String, Throwable) - Constructor for exception org.apache.flink.runtime.leaderretrieval.LeaderRetrievalException
- LeaderRetrievalException(Throwable) - Constructor for exception org.apache.flink.runtime.leaderretrieval.LeaderRetrievalException
- LeaderRetrievalHandler<T extends RestfulGateway> - Class in org.apache.flink.runtime.rest.handler
-
SimpleChannelInboundHandlerwhich encapsulates the leader retrieval logic for the REST endpoints. - LeaderRetrievalHandler(GatewayRetriever<? extends T>, Duration, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.LeaderRetrievalHandler
- LeaderRetrievalListener - Interface in org.apache.flink.runtime.leaderretrieval
-
Classes which want to be notified about a changing leader by the
LeaderRetrievalServicehave to implement this interface. - LeaderRetrievalService - Interface in org.apache.flink.runtime.leaderretrieval
-
This interface has to be implemented by a service which retrieves the current leader and notifies a listener about it.
- LeaderRetrievalUtils - Class in org.apache.flink.runtime.util
-
Utility class to work with
LeaderRetrievalServiceclass. - LeaderRetrievalUtils.LeaderInformationListener - Class in org.apache.flink.runtime.util
-
Helper class which is used by the retrieveLeaderInformation method to retrieve the leader's rpc URL and the current leader session ID.
- leaderRetriever - Variable in class org.apache.flink.runtime.rest.handler.LeaderRetrievalHandler
- leaderRetriever - Variable in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
- LeaderRetriever - Class in org.apache.flink.runtime.webmonitor.retriever
-
Retrieves and stores the current leader address.
- LeaderRetriever() - Constructor for class org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
- LeadershipLostException - Exception in org.apache.flink.runtime.leaderelection
-
This exception is used in the scenario that the leadership is lost.
- LeadershipLostException(String) - Constructor for exception org.apache.flink.runtime.leaderelection.LeadershipLostException
- LeadershipLostException(String, Throwable) - Constructor for exception org.apache.flink.runtime.leaderelection.LeadershipLostException
- LeadershipLostException(Throwable) - Constructor for exception org.apache.flink.runtime.leaderelection.LeadershipLostException
- LEFT_HYBRIDHASH_BUILD_FIRST - org.apache.flink.runtime.operators.DriverStrategy
- LEFT_HYBRIDHASH_BUILD_SECOND - org.apache.flink.runtime.operators.DriverStrategy
- LEFT_OUTER_MERGE - org.apache.flink.runtime.operators.DriverStrategy
- LeftOuterJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
-
The left outer join driver implements the logic of an outer join operator at runtime.
- LeftOuterJoinDriver() - Constructor for class org.apache.flink.runtime.operators.LeftOuterJoinDriver
- leftOverElement - Variable in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
- LegacyKeyedCoProcessOperator<K,IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
-
Deprecated.Replaced by
KeyedCoProcessOperatorwhich takesKeyedCoProcessFunction - LegacyKeyedCoProcessOperator(CoProcessFunction<IN1, IN2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
-
Deprecated.
- LegacyKeyedProcessOperator<K,IN,OUT> - Class in org.apache.flink.streaming.api.operators
-
Deprecated.Replaced by
KeyedProcessOperatorwhich takesKeyedProcessFunction - LegacyKeyedProcessOperator(ProcessFunction<IN, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator
-
Deprecated.
- LegacySinkTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This Transformation represents a stream Sink.
- LegacySinkTransformation(Transformation<T>, String, StreamOperatorFactory<Object>, int) - Constructor for class org.apache.flink.streaming.api.transformations.LegacySinkTransformation
- LegacySinkTransformation(Transformation<T>, String, StreamOperatorFactory<Object>, int, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.LegacySinkTransformation
- LegacySinkTransformation(Transformation<T>, String, StreamSink<T>, int, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.LegacySinkTransformation
-
Creates a new
LegacySinkTransformationfrom the given inputTransformation. - LegacySinkTransformationTranslator<IN> - Class in org.apache.flink.streaming.runtime.translators
-
A
TransformationTranslatorfor theLegacySinkTransformation. - LegacySinkTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.LegacySinkTransformationTranslator
- LegacySourceTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This represents a Source.
- LegacySourceTransformation(String, StreamSource<T, ?>, TypeInformation<T>, int, Boundedness, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.LegacySourceTransformation
-
Creates a new
LegacySourceTransformationfrom the given operator. - LegacySourceTransformationTranslator<OUT> - Class in org.apache.flink.streaming.runtime.translators
- LegacySourceTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.LegacySourceTransformationTranslator
- LibraryCacheManager - Interface in org.apache.flink.runtime.execution.librarycache
-
The LibraryCacheManager is responsible for creating and managing the user code class loaders.
- LibraryCacheManager.ClassLoaderHandle - Interface in org.apache.flink.runtime.execution.librarycache
-
Handle to retrieve a user code class loader for the associated job.
- LibraryCacheManager.ClassLoaderLease - Interface in org.apache.flink.runtime.execution.librarycache
-
Lease which allows to signal when the user code class loader is no longer needed.
- LineageDataset - Interface in org.apache.flink.streaming.api.lineage
-
Lineage dataset represents the source or sink in the job.
- LineageDatasetFacet - Interface in org.apache.flink.streaming.api.lineage
-
Facet interface for dataset.
- LineageEdge - Interface in org.apache.flink.streaming.api.lineage
-
Lineage edge from source to sink.
- LineageGraph - Interface in org.apache.flink.streaming.api.lineage
-
Job lineage graph that users can get sources, sinks and relationships from lineage and manage the relationship between jobs and tables.
- LineageGraphUtils - Class in org.apache.flink.streaming.api.lineage
-
Utils for building lineage graph from transformations.
- LineageGraphUtils() - Constructor for class org.apache.flink.streaming.api.lineage.LineageGraphUtils
- LineageVertex - Interface in org.apache.flink.streaming.api.lineage
-
Lineage vertex represents the connectors in lineage graph, including source
SourceLineageVertexand sink. - LineageVertexProvider - Interface in org.apache.flink.streaming.api.lineage
-
Create lineage vertex for source and sink in DataStream.
- LIST - org.apache.flink.runtime.state.v2.StateDescriptor.Type
- LIST_ADD - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Add value to list state,
AppendingState.asyncAdd(Object). - LIST_ADD_ALL - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Add multiple value to list of current partition,
ListState.asyncAddAll(List). - LIST_GET - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Get from list state,
AppendingState.asyncGet(). - LIST_UPDATE - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Put a list to current partition,
ListState.asyncUpdate(List). - ListCheckpointed<T extends Serializable> - Interface in org.apache.flink.streaming.api.checkpoint
-
Deprecated.If you need to do non-keyed state snapshots of your operator, use
CheckpointedFunction. This should only be needed in rare cases, though. - listCompletedClusterDatasetIds() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- listCompletedClusterDatasets() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
- listDataSets() - Method in interface org.apache.flink.runtime.io.network.partition.ClusterPartitionManager
-
Returns all datasets for which partitions are being tracked.
- listDataSets() - Method in interface org.apache.flink.runtime.io.network.partition.ResourceManagerPartitionTracker
-
Returns all data sets for which partitions are being tracked.
- listDataSets() - Method in class org.apache.flink.runtime.io.network.partition.ResourceManagerPartitionTrackerImpl
- listDataSets() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- ListDelimitedSerializer - Class in org.apache.flink.runtime.state
-
Encapsulates a logic of serialization and deserialization of a list with a delimiter.
- ListDelimitedSerializer() - Constructor for class org.apache.flink.runtime.state.ListDelimitedSerializer
- listDirectory() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
-
List the files in the snapshot directory.
- listenBufferReclaimRequest(Runnable) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemoryManager
-
Register a listener to listen the buffer reclaim request from the
TieredStorageMemoryManager. - listenBufferReclaimRequest(Runnable) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemoryManagerImpl
- listJobs() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- listJobs(Duration) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- listJobs(Duration) - Method in interface org.apache.flink.runtime.dispatcher.DispatcherGateway
-
List the current set of submitted jobs.
- ListMemorySegmentSource - Class in org.apache.flink.runtime.memory
-
Simple memory segment source that draws segments from a list.
- ListMemorySegmentSource(List<MemorySegment>) - Constructor for class org.apache.flink.runtime.memory.ListMemorySegmentSource
- ListStateAdaptor<K,N,V> - Class in org.apache.flink.runtime.state.v2.adaptor
-
An adaptor that transforms
InternalListStateintoInternalListState. - ListStateAdaptor(InternalListState<K, N, V>) - Constructor for class org.apache.flink.runtime.state.v2.adaptor.ListStateAdaptor
- ListStateDescriptor<T> - Class in org.apache.flink.runtime.state.v2
-
StateDescriptorforListState. - ListStateDescriptor(String, TypeInformation<T>) - Constructor for class org.apache.flink.runtime.state.v2.ListStateDescriptor
-
Creates a new
ListStateDescriptorwith the given stateId and type. - ListStateDescriptor(String, TypeInformation<T>, SerializerConfig) - Constructor for class org.apache.flink.runtime.state.v2.ListStateDescriptor
-
Creates a new
ListStateDescriptorwith the given stateId and type. - ListStateSnapshotTransformer(StateSnapshotTransformer<T>) - Constructor for class org.apache.flink.runtime.state.StateSnapshotTransformers.ListStateSnapshotTransformer
- ListStateSnapshotTransformFactory(StateSnapshotTransformer.StateSnapshotTransformFactory<T>) - Constructor for class org.apache.flink.runtime.state.StateSnapshotTransformers.ListStateSnapshotTransformFactory
- load(JobID, Configuration, TaskManagerJobMetricGroup, LocalRecoveryConfig) - Static method in class org.apache.flink.runtime.state.changelog.StateChangelogStorageLoader
- load(CheckpointStorage, StateBackend, Configuration, Configuration, ClassLoader, Logger) - Static method in class org.apache.flink.runtime.state.CheckpointStorageLoader
-
Loads the configured
CheckpointStoragefor the job based on the following precedent rules: - load(Logger) - Static method in interface org.apache.flink.streaming.util.typeutils.ScalaProductFieldAccessorFactory
-
Loads the implementation, if it is accessible.
- LOAD_COUNT - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- loadAllocationSnapshots() - Method in class org.apache.flink.runtime.taskexecutor.slot.FileSlotAllocationSnapshotPersistenceService
- loadAllocationSnapshots() - Method in enum org.apache.flink.runtime.taskexecutor.slot.NoOpSlotAllocationSnapshotPersistenceService
- loadAllocationSnapshots() - Method in interface org.apache.flink.runtime.taskexecutor.slot.SlotAllocationSnapshotPersistenceService
-
Load all persisted slot allocation snapshots.
- loadAndModifyConfiguration(String[]) - Static method in class org.apache.flink.runtime.util.bash.FlinkConfigLoader
- loadAndModifyConfiguration(String[], String) - Static method in class org.apache.flink.runtime.util.ConfigurationParserUtils
- loadAndValidateCheckpoint(JobID, Map<JobVertexID, ExecutionJobVertex>, CompletedCheckpointStorageLocation, ClassLoader, boolean, CheckpointProperties) - Static method in class org.apache.flink.runtime.checkpoint.Checkpoints
- loadBigData(PermanentBlobService, GroupCache<JobID, PermanentBlobKey, JobInformation>, GroupCache<JobID, PermanentBlobKey, TaskInformation>, GroupCache<JobID, PermanentBlobKey, TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup>) - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Loads externalized data from the BLOB store back to the object.
- loadBlocklistHandlerFactory(Configuration) - Static method in class org.apache.flink.runtime.blocklist.BlocklistUtils
- loadCheckpointMetadata(DataInputStream, ClassLoader, String) - Static method in class org.apache.flink.runtime.checkpoint.Checkpoints
- loadCheckpointStorage(Configuration, Configuration, ClassLoader, Logger) - Static method in class org.apache.flink.runtime.checkpoint.Checkpoints
- loadCommonConfiguration(String[], String) - Static method in class org.apache.flink.runtime.util.ConfigurationParserUtils
-
Generate configuration from only the config file and dynamic properties.
- loadConfiguration(String[]) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
- loadConfiguration(String[]) - Static method in class org.apache.flink.runtime.util.bash.FlinkConfigLoader
- loadConfiguration(EntrypointClusterConfiguration) - Static method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
- loadCounter(Counter) - Method in class org.apache.flink.runtime.metrics.groups.InternalCacheMetricGroup
- loadFailoverStrategyFactory(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategyFactoryLoader
-
Loads a
FailoverStrategy.Factoryfrom the given configuration. - loadFromStateHandle(Configuration, ChangelogStateHandle) - Static method in class org.apache.flink.runtime.state.changelog.StateChangelogStorageLoader
- loadInputConsumableDeciderFactory(JobManagerOptions.HybridPartitionDataConsumeConstraint) - Static method in class org.apache.flink.runtime.scheduler.adaptivebatch.AdaptiveBatchSchedulerFactory
- loadPartitionGroupReleaseStrategyFactory(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.failover.partitionrelease.PartitionGroupReleaseStrategyFactoryLoader
- loadReporterConfigurations(Configuration, Set<String>, String) - Static method in class org.apache.flink.runtime.metrics.ReporterSetup
- loadShuffleServiceFactory(Configuration) - Static method in enum org.apache.flink.runtime.shuffle.ShuffleServiceLoader
- loadStateBackend(Configuration, Configuration, ClassLoader, Logger) - Static method in class org.apache.flink.runtime.checkpoint.Checkpoints
- loadStateBackendFromConfig(ReadableConfig, ClassLoader, Logger) - Static method in class org.apache.flink.runtime.state.StateBackendLoader
-
Loads the unwrapped state backend from the configuration, from the parameter 'state.backend', as defined in
StateBackendOptions.STATE_BACKEND. - loadStateBackendFromKeyedStateHandles(StateBackend, ClassLoader, Collection<KeyedStateHandle>) - Static method in class org.apache.flink.runtime.state.StateBackendLoader
-
Load state backend which may wrap the original state backend for recovery.
- loadWebSubmissionExtension(GatewayRetriever<? extends DispatcherGateway>, Duration, Map<String, String>, CompletableFuture<String>, Path, Executor, Configuration) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
-
Loads the
WebMonitorExtensionwhich enables web submission. - LOCAL - org.apache.flink.runtime.jobmanager.scheduler.Locality
-
The task was scheduled into the same TaskManager as requested
- LOCAL_DISK - org.apache.flink.runtime.state.StateObject.StateObjectLocation
- LOCAL_MEMORY - org.apache.flink.runtime.state.StateObject.StateObjectLocation
- LocalBufferPool - Class in org.apache.flink.runtime.io.network.buffer
-
A buffer pool used to manage a number of
Bufferinstances from theNetworkBufferPool. - LocalChangelogRegistry - Interface in org.apache.flink.runtime.state.changelog
-
This registry is responsible for deleting changlog's local handles which are not in use.
- LocalChangelogRegistryImpl - Class in org.apache.flink.runtime.state.changelog
- LocalChangelogRegistryImpl(ExecutorService) - Constructor for class org.apache.flink.runtime.state.changelog.LocalChangelogRegistryImpl
- localCleanupAsync(JobID, Executor) - Method in class org.apache.flink.runtime.blob.BlobServer
-
Deletes locally stored artifacts for the job represented by the given
JobID. - localCleanupAsync(JobID, Executor) - Method in interface org.apache.flink.runtime.dispatcher.cleanup.LocallyCleanableResource
-
localCleanupAsyncis expected to be called from the main thread. - localCleanupAsync(JobID, Executor) - Method in class org.apache.flink.runtime.dispatcher.DefaultJobManagerRunnerRegistry
- localCleanupAsync(JobID, Executor) - Method in class org.apache.flink.runtime.dispatcher.OnMainThreadJobManagerRunnerRegistry
- localCleanupAsync(JobID, Executor) - Method in class org.apache.flink.runtime.jobmanager.DefaultJobGraphStore
-
Releases the locks on the specified
JobGraph. - localCleanupAsync(JobID, Executor) - Method in interface org.apache.flink.runtime.jobmanager.JobGraphWriter
- localCleanupAsync(JobID, Executor) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
- LocalConnectionManager - Class in org.apache.flink.runtime.io.network
-
A connection manager implementation to bypass setup overhead for task managers running in local execution mode.
- LocalConnectionManager() - Constructor for class org.apache.flink.runtime.io.network.LocalConnectionManager
- LocalInputChannel - Class in org.apache.flink.runtime.io.network.partition.consumer
-
An input channel, which requests a local subpartition.
- LocalInputChannel(SingleInputGate, int, ResultPartitionID, ResultSubpartitionIndexSet, ResultPartitionManager, TaskEventPublisher, int, int, Counter, Counter, ChannelStateWriter) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
- Locality - Enum in org.apache.flink.runtime.jobmanager.scheduler
- LocallyCleanableResource - Interface in org.apache.flink.runtime.dispatcher.cleanup
-
LocallyCleanableResourceis supposed to be implemented by any class that provides artifacts for a given job that need to be cleaned up after the job reached a local terminal state. - LocalRecoveredInputChannel - Class in org.apache.flink.runtime.io.network.partition.consumer
-
An input channel reads recovered state from previous unaligned checkpoint snapshots and then converts into
LocalInputChannelfinally. - localRecoveryConfig - Variable in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
The configured mode for local recovery.
- LocalRecoveryConfig - Class in org.apache.flink.runtime.state
-
This class encapsulates the completed configuration for local recovery, i.e. the root directories into which all file-based snapshots can be written and the general mode for the local recover feature.
- LocalRecoveryConfig(boolean, boolean, LocalSnapshotDirectoryProvider) - Constructor for class org.apache.flink.runtime.state.LocalRecoveryConfig
- localRecoveryNotEnabled() - Static method in class org.apache.flink.runtime.state.LocalRecoveryConfig
- LocalSnapshotDirectoryProvider - Interface in org.apache.flink.runtime.state
-
Provides directories for local backup or local recovery.
- LocalSnapshotDirectoryProviderImpl - Class in org.apache.flink.runtime.state
-
Implementation of
LocalSnapshotDirectoryProvider. - LocalSnapshotDirectoryProviderImpl(File[], JobID, JobVertexID, int) - Constructor for class org.apache.flink.runtime.state.LocalSnapshotDirectoryProviderImpl
- LocalSnapshotDirectoryProviderImpl(File, JobID, JobVertexID, int) - Constructor for class org.apache.flink.runtime.state.LocalSnapshotDirectoryProviderImpl
- localStateStoreForSubtask(JobID, AllocationID, JobVertexID, int, Configuration, Configuration) - Method in class org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager
- localStrategies - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The local strategies that are applied on the inputs.
- LocalStrategy - Enum in org.apache.flink.runtime.operators.util
-
Enumeration of all available local processing strategies tasks.
- LocalStreamEnvironment - Class in org.apache.flink.streaming.api.environment
-
The LocalStreamEnvironment is a StreamExecutionEnvironment that runs the program locally, multi-threaded, in the JVM where the environment is instantiated.
- LocalStreamEnvironment() - Constructor for class org.apache.flink.streaming.api.environment.LocalStreamEnvironment
-
Creates a new mini cluster stream environment that uses the default configuration.
- LocalStreamEnvironment(Configuration) - Constructor for class org.apache.flink.streaming.api.environment.LocalStreamEnvironment
-
Creates a new mini cluster stream environment that configures its local executor with the given configuration.
- LocalTransportException - Exception in org.apache.flink.runtime.io.network.netty.exception
- LocalTransportException(String, SocketAddress) - Constructor for exception org.apache.flink.runtime.io.network.netty.exception.LocalTransportException
- LocalTransportException(String, SocketAddress, Throwable) - Constructor for exception org.apache.flink.runtime.io.network.netty.exception.LocalTransportException
- location() - Method in class org.apache.flink.runtime.source.event.ReaderRegistrationEvent
- LocationPreferenceConstraint - Enum in org.apache.flink.runtime.jobmanager.scheduler
-
Defines the location preference constraint.
- LocationPreferenceSlotSelectionStrategy - Class in org.apache.flink.runtime.jobmaster.slotpool
-
This class implements a
SlotSelectionStrategythat is based on location preference hints. - lock - Variable in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
-
Guard for
FileMergingSnapshotManagerBase.initFileSystem(org.apache.flink.core.fs.FileSystem, org.apache.flink.core.fs.Path, org.apache.flink.core.fs.Path, org.apache.flink.core.fs.Path, int),FileMergingSnapshotManagerBase.restoreStateHandles(long, org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager.SubtaskKey, java.util.stream.Stream<org.apache.flink.runtime.state.filemerging.SegmentFileStateHandle>)and uploadedStates. - lock - Variable in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
- lock - Variable in class org.apache.flink.runtime.jobmaster.slotpool.AbstractServiceConnectionManager
- lock - Variable in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
Lock for synchronisation on the storage map and the discarded status.
- lock - Variable in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator
- LOCK - org.apache.flink.runtime.rest.messages.ProfilingInfo.ProfilingMode
- log - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
-
The log object used for debugging.
- log - Variable in class org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess
- log - Variable in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolService
- log - Variable in class org.apache.flink.runtime.jobmaster.slotpool.DefaultDeclarativeSlotPool
- log - Variable in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
The logger for all log messages of this class.
- log - Variable in class org.apache.flink.runtime.resourcemanager.active.AbstractResourceManagerDriver
- log - Variable in class org.apache.flink.runtime.resourcemanager.ResourceManagerFactory
- log - Variable in class org.apache.flink.runtime.rest.handler.AbstractHandler
- log - Variable in class org.apache.flink.runtime.rest.RestServerEndpoint
- log - Variable in class org.apache.flink.runtime.scheduler.DefaultScheduler
- log - Variable in class org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
- log - Variable in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator
- LOG - org.apache.flink.runtime.rest.handler.RestHandlerException.LoggingBehavior
- LOG - org.apache.flink.runtime.taskexecutor.FileType
-
The log file type for taskmanager.
- LOG - Static variable in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
- LOG - Static variable in interface org.apache.flink.runtime.blob.BlobWriter
- LOG - Static variable in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
- LOG - Static variable in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
- LOG - Static variable in class org.apache.flink.runtime.entrypoint.ClusterEntrypointUtils
- LOG - Static variable in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
-
Logger object for channel and its subclasses
- LOG - Static variable in class org.apache.flink.runtime.io.disk.iomanager.IOManager
- LOG - Static variable in class org.apache.flink.runtime.io.network.partition.ResultPartition
- LOG - Static variable in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
- LOG - Static variable in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
- LOG - Static variable in class org.apache.flink.runtime.operators.BatchTask
- LOG - Static variable in class org.apache.flink.runtime.operators.JoinDriver
- LOG - Static variable in class org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
- LOG - Static variable in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
- LOG - Static variable in class org.apache.flink.runtime.operators.resettable.ReusingBlockResettableIterator
- LOG - Static variable in class org.apache.flink.runtime.security.DynamicConfiguration
- LOG - Static variable in interface org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
- LOG - Static variable in class org.apache.flink.runtime.util.profiler.ProfilingService
- LOG - Static variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
The logger used by the operator class and its subclasses.
- LOG - Static variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
The logger used by the operator class and its subclasses.
- LOG - Static variable in class org.apache.flink.streaming.api.operators.InternalTimeServiceManagerImpl
- LOG - Static variable in class org.apache.flink.streaming.api.operators.MailboxWatermarkProcessor
- LOG - Static variable in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
- LOG - Static variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
The logger used by the StreamTask and its subclasses.
- logAndThrowException(Exception, AbstractInvokable) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Prints an error message and throws the given exception.
- logAsyncSnapshotComplete(long) - Method in class org.apache.flink.runtime.state.AsyncSnapshotCallable
-
This method is invoked after completion of the snapshot and can be overridden to output a logging about the duration of the async part.
- logDir - Variable in class org.apache.flink.runtime.webmonitor.WebMonitorUtils.LogFileLocation
- logEnvironmentInfo(Logger, String, String[]) - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Logs information about the environment, like code revision, current user, Java version, and JVM parameters.
- logException() - Method in exception org.apache.flink.runtime.rest.handler.RestHandlerException
- logFile - Variable in class org.apache.flink.runtime.webmonitor.WebMonitorUtils.LogFileLocation
- logFileNamePathParameter - Variable in class org.apache.flink.runtime.rest.messages.cluster.FileMessageParameters
- logFileNamePathParameter - Variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerFileMessageParameters
- LogFileNamePathParameter - Class in org.apache.flink.runtime.rest.messages
-
Parameters used by
TaskManagerCustomLogHandlerandJobManagerCustomLogHandler. - LogFileNamePathParameter() - Constructor for class org.apache.flink.runtime.rest.messages.LogFileNamePathParameter
- logger - Variable in class org.apache.flink.runtime.highavailability.AbstractHaServices
- logger - Variable in class org.apache.flink.runtime.rest.handler.LeaderRetrievalHandler
- logger - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
- LOGICAL_FILE_COUNT - Static variable in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingMetricGroup
- LOGICAL_FILE_SIZE - Static variable in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingMetricGroup
- LogicalEdge - Interface in org.apache.flink.runtime.jobgraph.topology
-
Represents an edge in
LogicalTopology, i.e. - LogicalFile - Class in org.apache.flink.runtime.checkpoint.filemerging
-
An abstraction of logical files in file-merging checkpoints.
- LogicalFile(LogicalFile.LogicalFileId, PhysicalFile, long, long, FileMergingSnapshotManager.SubtaskKey) - Constructor for class org.apache.flink.runtime.checkpoint.filemerging.LogicalFile
- LogicalFile.LogicalFileId - Class in org.apache.flink.runtime.checkpoint.filemerging
-
ID for
LogicalFile. - LogicalFileId(String) - Constructor for class org.apache.flink.runtime.checkpoint.filemerging.LogicalFile.LogicalFileId
- LogicalPipelinedRegion - Interface in org.apache.flink.runtime.jobgraph.topology
-
Pipelined region on logical level, i.e.,
JobVertexlevel. - LogicalPipelinedRegionComputeUtil - Class in org.apache.flink.runtime.executiongraph.failover
-
Utils for computing
LogicalPipelinedRegions. - LogicalResult - Interface in org.apache.flink.runtime.jobgraph.topology
-
Represents a data set produced by a
LogicalVertex, i.e. - LogicalSlot - Interface in org.apache.flink.runtime.jobmaster
-
A logical slot represents a resource on a TaskManager into which a single task can be deployed.
- LogicalSlot.Payload - Interface in org.apache.flink.runtime.jobmaster
-
Payload for a logical slot.
- LogicalTopology - Interface in org.apache.flink.runtime.jobgraph.topology
-
Represents a logical topology, i.e.
- LogicalVertex - Interface in org.apache.flink.runtime.jobgraph.topology
-
Represents a vertex in
LogicalTopology, i.e. - LogInfo - Class in org.apache.flink.runtime.rest.messages
-
Contains information about one log of TaskManager.
- LogInfo(String, long, long) - Constructor for class org.apache.flink.runtime.rest.messages.LogInfo
- LogListInfo - Class in org.apache.flink.runtime.rest.messages
-
Class containing a collection of
LogInfo. - LogListInfo(Collection<LogInfo>) - Constructor for class org.apache.flink.runtime.rest.messages.LogListInfo
- logTaskThreadStackTrace(Thread, String, long, String) - Static method in class org.apache.flink.runtime.taskmanager.Task
- LogUrlResponse - Class in org.apache.flink.runtime.rest.messages
-
Response of log URLs.
- LogUrlResponse(String) - Constructor for class org.apache.flink.runtime.rest.messages.LogUrlResponse
- LongArrayList - Class in org.apache.flink.runtime.util
-
Minimal implementation of an array-backed list of longs
- LongArrayList(int) - Constructor for class org.apache.flink.runtime.util.LongArrayList
- lookup(ResourceID) - Method in interface org.apache.flink.runtime.io.network.partition.PartitionTrackerFactory.TaskExecutorGatewayLookup
-
Returns a
TaskExecutorGatewaycorresponding to the given ResourceID. - LOW - org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureLevel
- lowerBoundExclusive() - Method in class org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoined
-
Set the lower bound to be exclusive.
- Lz4BlockCompressionFactory - Class in org.apache.flink.runtime.io.compression
-
Implementation of
BlockCompressionFactoryfor Lz4 codec. - Lz4BlockCompressionFactory() - Constructor for class org.apache.flink.runtime.io.compression.Lz4BlockCompressionFactory
- Lz4BlockCompressor - Class in org.apache.flink.runtime.io.compression
-
Encode data into LZ4 format (not compatible with the LZ4 Frame format).
- Lz4BlockCompressor() - Constructor for class org.apache.flink.runtime.io.compression.Lz4BlockCompressor
- Lz4BlockDecompressor - Class in org.apache.flink.runtime.io.compression
-
Decode data written with
Lz4BlockCompressor. - Lz4BlockDecompressor() - Constructor for class org.apache.flink.runtime.io.compression.Lz4BlockDecompressor
M
- MAGIC_NUMBER - Static variable in class org.apache.flink.streaming.runtime.operators.sink.committables.SinkV1CommittableDeserializer
-
It is important to keep this number consistent with the number used by the
StreamingCommitterStateSerializerin Flink 1.13 and 1.14. - Mail - Class in org.apache.flink.streaming.runtime.tasks.mailbox
-
An executable bound to a specific operator in the chain, such that it can be picked for downstream mailbox.
- Mail(MailboxExecutor.MailOptions, ThrowingRunnable<? extends Exception>, int, StreamTaskActionExecutor, String, Object...) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.Mail
- Mail(ThrowingRunnable<? extends Exception>, int, String, Object...) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.Mail
- mailbox - Variable in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
The mailbox data-structure that manages request for special actions, like timers, checkpoints, ...
- MAILBOX_LATENCY - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- MAILBOX_SIZE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- MAILBOX_START_DURATION - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- MAILBOX_THROUGHPUT - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- MailboxClosedException(String) - Constructor for exception org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox.MailboxClosedException
- MailboxController(MailboxProcessor) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.MailboxController
- mailboxDefaultAction - Variable in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
Action that is repeatedly executed if no action request is in the mailbox.
- MailboxDefaultAction - Interface in org.apache.flink.streaming.runtime.tasks.mailbox
-
Interface for the default action that is repeatedly invoked in the mailbox-loop.
- MailboxDefaultAction.Controller - Interface in org.apache.flink.streaming.runtime.tasks.mailbox
-
This controller is a feedback interface for the default action to interact with the mailbox execution.
- MailboxDefaultAction.Suspension - Interface in org.apache.flink.streaming.runtime.tasks.mailbox
-
Represents the suspended state of a
MailboxDefaultAction, ready to resume. - MailboxExecutorFactory - Interface in org.apache.flink.streaming.runtime.tasks.mailbox
-
A factory for creating mailbox executors with a given priority.
- MailboxExecutorImpl - Class in org.apache.flink.streaming.runtime.tasks.mailbox
-
Implementation of an executor service build around a mailbox-based execution model.
- MailboxExecutorImpl(TaskMailbox, int, StreamTaskActionExecutor) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
- MailboxExecutorImpl(TaskMailbox, int, StreamTaskActionExecutor, MailboxProcessor) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
- MailboxMetricsController - Class in org.apache.flink.streaming.runtime.tasks.mailbox
-
Mailbox metrics controller class.
- MailboxMetricsController(Histogram, Counter) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
-
Creates instance of
MailboxMetricsControllerwith references to metrics provided as parameters. - mailboxProcessor - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
- MailboxProcessor - Class in org.apache.flink.streaming.runtime.tasks.mailbox
-
This class encapsulates the logic of the mailbox-based execution model.
- MailboxProcessor() - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
- MailboxProcessor(MailboxDefaultAction) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
- MailboxProcessor(MailboxDefaultAction, TaskMailbox, StreamTaskActionExecutor) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
- MailboxProcessor(MailboxDefaultAction, TaskMailbox, StreamTaskActionExecutor, MailboxMetricsController) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
- MailboxProcessor(MailboxDefaultAction, StreamTaskActionExecutor) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
- MailboxProcessor.MailboxController - Class in org.apache.flink.streaming.runtime.tasks.mailbox
-
Implementation of
MailboxDefaultAction.Controllerthat is connected to aMailboxProcessorinstance. - MailboxWatermarkProcessor<OUT> - Class in org.apache.flink.streaming.api.operators
-
A helper class to let operators emit watermarks incrementally from mailbox.
- MailboxWatermarkProcessor(Output<StreamRecord<OUT>>, MailboxExecutor, InternalTimeServiceManager<?>) - Constructor for class org.apache.flink.streaming.api.operators.MailboxWatermarkProcessor
- main(String[]) - Static method in class org.apache.flink.runtime.entrypoint.StandaloneSessionClusterEntrypoint
- main(String[]) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
- main(String[]) - Static method in class org.apache.flink.runtime.util.bash.BashJavaUtils
- main(String[]) - Static method in class org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
- mainOperator - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
the main operator that consumes the input streams of this task.
- mainOperatorOutput - Variable in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- mainOperatorWrapper - Variable in class org.apache.flink.streaming.runtime.tasks.OperatorChain
-
For iteration,
StreamIterationHeadandStreamIterationTailused for executing feedback edges do not contain any operators, in which case,mainOperatorWrapperandtailOperatorWrapperare null. - maintainVisibility(long, long) - Method in class org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
- maintainVisibility(long, long) - Method in class org.apache.flink.streaming.api.operators.collect.CheckpointedCollectResultBuffer
- maintainVisibility(long, long) - Method in class org.apache.flink.streaming.api.operators.collect.UncheckpointedCollectResultBuffer
- makeNewStateFuture() - Method in class org.apache.flink.runtime.asyncprocessing.ContextStateFutureImpl
- makeRecordProcessor(AsyncStateProcessingOperator, KeySelector<T, ?>, ThrowingConsumer<StreamRecord<T>, Exception>) - Static method in interface org.apache.flink.streaming.runtime.operators.asyncprocessing.AsyncStateProcessing
-
Static method helper to make a record processor with given infos.
- makeResultsVisible(long) - Method in class org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
- managedExclusiveStateDir - Variable in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
-
The private state files are merged across subtasks, there is only one directory for merged-files within one TM per job.
- managedExclusiveStateDirHandle - Variable in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
-
The
DirectoryStreamStateHandlewith it ongoing checkpoint reference count for private state directory, one for each taskmanager and job. - ManagedInitializationContext - Interface in org.apache.flink.runtime.state
-
This interface provides a context in which operators can initialize by registering to managed state (i.e. state that is managed by state backends).
- ManagedMemoryUtils - Enum in org.apache.flink.runtime.util.config.memory
-
Utils for configuration and calculations related to managed memory and its various use cases.
- ManagedSnapshotContext - Interface in org.apache.flink.runtime.state
-
This interface provides a context in which operators that use managed state (i.e. state that is managed by state backends) can perform a snapshot.
- MANDATORY - org.apache.flink.runtime.rest.messages.MessageParameter.MessageParameterRequisiteness
- map() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableSummary
- map(Function<CommT, NewCommT>) - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableWithLineage
- map(MapFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Applies a Map transformation on a
DataStream. - map(MapFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Applies a Map transformation on a
DataStream. - map(Tuple2<Integer, T>) - Method in class org.apache.flink.runtime.operators.udf.RemoveRangeIndex
- map(CoMapFunction<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies a CoMap transformation on a
ConnectedStreamsand maps the output to a common type. - map(CoMapFunction<IN1, IN2, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies a CoMap transformation on a
ConnectedStreamsand maps the output to a common type. - map(FunctionWithException<? super T, ? extends V, E>) - Method in class org.apache.flink.runtime.entrypoint.DeterminismEnvelope
- MAP - org.apache.flink.runtime.operators.DriverStrategy
- MAP - org.apache.flink.runtime.state.v2.StateDescriptor.Type
- MAP_CONTAINS - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Check key existence of current partition,
MapState.asyncContains(Object)}. - MAP_GET - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Get a value by a key from current partition,
MapState.asyncGet(Object). - MAP_IS_EMPTY - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Check the existence of any key-value mapping within current partition,
MapState.asyncIsEmpty(). - MAP_ITER - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Get an iterator of key-value mapping within current partition,
MapState.asyncEntries(). - MAP_ITER_KEY - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Get an iterator of keys within current partition,
MapState.asyncKeys(). - MAP_ITER_VALUE - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Get an iterator of values within current partition,
MapState.asyncValues(). - MAP_PARTITION - org.apache.flink.runtime.operators.DriverStrategy
- MAP_PUT - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Update a key-value pair of current partition,
MapState.asyncPut(Object, Object). - MAP_PUT_ALL - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Update multiple key-value pairs of current partition,
MapState.asyncPutAll(Map). - MAP_REMOVE - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Remove a key-value mapping within current partition,
MapState.asyncRemove(Object). - map1(IN1) - Method in interface org.apache.flink.streaming.api.functions.co.CoMapFunction
-
This method is called for each element in the first of the connected streams.
- map2(IN2) - Method in interface org.apache.flink.streaming.api.functions.co.CoMapFunction
-
This method is called for each element in the second of the connected streams.
- MapDriver<IT,OT> - Class in org.apache.flink.runtime.operators
-
Map task which is executed by a Task Manager.
- MapDriver() - Constructor for class org.apache.flink.runtime.operators.MapDriver
- mapPartition(Iterable<IN>, Collector<Tuple2<Integer, IN>>) - Method in class org.apache.flink.runtime.operators.udf.AssignRangeIndex
- mapPartition(Iterable<T>, Collector<Object[][]>) - Method in class org.apache.flink.runtime.operators.udf.RangeBoundaryBuilder
- mapPartition(MapPartitionFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedPartitionWindowedStream
- mapPartition(MapPartitionFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.NonKeyedPartitionWindowedStream
- mapPartition(MapPartitionFunction<T, R>) - Method in interface org.apache.flink.streaming.api.datastream.PartitionWindowedStream
-
Process the records of the window by
MapPartitionFunction. - MapPartitionDriver<IT,OT> - Class in org.apache.flink.runtime.operators
-
MapPartition task which is executed by a Task Manager.
- MapPartitionDriver() - Constructor for class org.apache.flink.runtime.operators.MapPartitionDriver
- MapPartitionIterator<IN> - Class in org.apache.flink.streaming.api.operators
-
The
MapPartitionIteratoris an iterator used in theMapPartitionOperator.The task main thread will add records to it. - MapPartitionIterator(Consumer<Iterator<IN>>) - Constructor for class org.apache.flink.streaming.api.operators.MapPartitionIterator
- MapPartitionOperator<IN,OUT> - Class in org.apache.flink.streaming.api.operators
-
The
MapPartitionOperatoris used to process all records in each partition on non-keyed stream. - MapPartitionOperator(MapPartitionFunction<IN, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.MapPartitionOperator
- MAPPER - Static variable in class org.apache.flink.runtime.rest.handler.AbstractHandler
- MappingBasedRepartitioner<T> - Class in org.apache.flink.runtime.checkpoint
-
A repartitioner that assigns the same channel state to multiple subtasks according to some mapping.
- MappingBasedRepartitioner(RescaleMappings) - Constructor for class org.apache.flink.runtime.checkpoint.MappingBasedRepartitioner
- MapStateAdaptor<K,N,UK,UV> - Class in org.apache.flink.runtime.state.v2.adaptor
-
An adaptor that transforms
InternalMapStateintoInternalMapState. - MapStateAdaptor(InternalMapState<K, N, UK, UV>) - Constructor for class org.apache.flink.runtime.state.v2.adaptor.MapStateAdaptor
- MapStateDescriptor<UK,UV> - Class in org.apache.flink.runtime.state.v2
-
StateDescriptorforMapState. - MapStateDescriptor(String, TypeInformation<UK>, TypeInformation<UV>) - Constructor for class org.apache.flink.runtime.state.v2.MapStateDescriptor
-
Creates a new
MapStateDescriptorwith the given stateId and type. - MapStateDescriptor(String, TypeInformation<UK>, TypeInformation<UV>, SerializerConfig) - Constructor for class org.apache.flink.runtime.state.v2.MapStateDescriptor
-
Creates a new
MapStateDescriptorwith the given stateId and type. - MapStateSnapshotTransformer(StateSnapshotTransformer<V>) - Constructor for class org.apache.flink.runtime.state.StateSnapshotTransformers.MapStateSnapshotTransformer
- MapStateSnapshotTransformFactory(StateSnapshotTransformer.StateSnapshotTransformFactory<V>) - Constructor for class org.apache.flink.runtime.state.StateSnapshotTransformers.MapStateSnapshotTransformFactory
- mark(int) - Method in class org.apache.flink.runtime.state.BoundedInputStream
- mark(int) - Method in class org.apache.flink.runtime.state.filesystem.FsSegmentDataInputStream
- mark(int) - Method in class org.apache.flink.runtime.util.ForwardingInputStream
- markActive() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
Mark this slot as active.
- markActive() - Method in class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
- markActive() - Method in class org.apache.flink.streaming.api.operators.source.WatermarkToDataOutput
- markActive() - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator.WatermarkEmitter
- markAlignmentEnd() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
- markAlignmentEnd(long) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
- markAlignmentStart(long, long) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
- markAlignmentStartAndEnd(long, long) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
- markAsDiscarded() - Method in interface org.apache.flink.runtime.checkpoint.Checkpoint
-
This method precede the
Checkpoint.DiscardObject.discard()method and should be called from theCheckpointCoordinator(under the lock) whileCheckpoint.DiscardObject.discard()can be called from any thread/place. - markAsDiscarded() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
- markAsDiscarded() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
- markAsDiscardedOnShutdown(JobStatus) - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
- markAsDiscardedOnSubsume() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
- markAsTemporarilyIdle() - Method in interface org.apache.flink.streaming.api.functions.source.legacy.SourceFunction.SourceContext
-
Deprecated.Marks the source to be temporarily idle.
- markCanceledOrStopped() - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
Deprecated.Marks this source as canceled or stopped.
- markCheckpointAlignedAndTransformState(InputChannelInfo, CheckpointBarrier, FunctionWithException<BarrierHandlerState, BarrierHandlerState, Exception>) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
- markEnd() - Method in class org.apache.flink.runtime.metrics.TimerGauge
- markEnd() - Method in interface org.apache.flink.runtime.metrics.TimerGauge.StartStopListener
- markEnd() - Method in class org.apache.flink.streaming.api.operators.util.PausableRelativeClock
- markEnd() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.GaugePeriodTimer
- markEnd() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.PeriodTimer
- markEvent() - Method in class org.apache.flink.runtime.metrics.ThresholdMeter
- markEvent(long) - Method in class org.apache.flink.runtime.metrics.ThresholdMeter
- markFailed(Throwable) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
This method marks the task as failed, but will make no attempt to remove task execution from the task manager.
- markFailed(Throwable) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
This method marks the task as failed, but will make no attempt to remove task execution from the task manager.
- markFailed(Throwable) - Method in class org.apache.flink.runtime.executiongraph.SpeculativeExecutionVertex
- markFailed(Execution, Throwable) - Method in class org.apache.flink.runtime.scheduler.DefaultExecutionOperations
- markFailed(Execution, Throwable) - Method in interface org.apache.flink.runtime.scheduler.ExecutionOperations
-
Mark the execution as FAILED.
- markFinished() - Method in class org.apache.flink.runtime.executiongraph.Execution
- markIdle() - Method in class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
- markIdle() - Method in class org.apache.flink.streaming.api.operators.source.WatermarkToDataOutput
- markIdle() - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator.WatermarkEmitter
- markInactive() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
Mark the slot as inactive/allocated.
- markLastConsumptionStatus(boolean, boolean) - Method in class org.apache.flink.runtime.io.network.partition.RoundRobinSubpartitionSelector
- markLastConsumptionStatus(boolean, boolean) - Method in interface org.apache.flink.runtime.io.network.partition.SubpartitionSelector
-
Records the status of the last consumption attempt on the subpartition returned by the last invocation of
SubpartitionSelector.getNextSubpartitionToConsume(). - markPartitionFinished(IntermediateResultPartition) - Method in class org.apache.flink.runtime.deployment.CachedShuffleDescriptors
- markPartitionFinished(ConsumedPartitionGroup, IntermediateResultPartition) - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
- MarkPartitionFinishedStrategy - Interface in org.apache.flink.runtime.executiongraph
-
This strategy is used to decide whether partition needs to be marked as finished.
- markPartitionGroupReleasable(ConsumedPartitionGroup) - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
- markResultAsCleanAsync(JobID) - Method in class org.apache.flink.runtime.highavailability.AbstractThreadsafeJobResultStore
- markResultAsCleanAsync(JobID) - Method in interface org.apache.flink.runtime.highavailability.JobResultStore
-
Marks an existing
JobResultEntryasclean. - markResultAsCleanInternal(JobID) - Method in class org.apache.flink.runtime.highavailability.AbstractThreadsafeJobResultStore
- markResultAsCleanInternal(JobID) - Method in class org.apache.flink.runtime.highavailability.FileSystemJobResultStore
- markResultAsCleanInternal(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedJobResultStore
- markSlotActive(AllocationID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Marks the slot under the given allocation id as active.
- markSlotActive(AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- markSlotInactive(AllocationID, Duration) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Marks the slot under the given allocation id as inactive.
- markSlotInactive(AllocationID, Duration) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- markStart() - Method in class org.apache.flink.runtime.metrics.TimerGauge
- markStart() - Method in interface org.apache.flink.runtime.metrics.TimerGauge.StartStopListener
- markStart() - Method in class org.apache.flink.streaming.api.operators.util.PausableRelativeClock
- markStart() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.GaugePeriodTimer
- markStart() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.PeriodTimer
- markSupported() - Method in class org.apache.flink.runtime.state.BoundedInputStream
- markSupported() - Method in class org.apache.flink.runtime.state.filesystem.FsSegmentDataInputStream
- markSupported() - Method in class org.apache.flink.runtime.util.ForwardingInputStream
- markTaskInitializationStarted() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- markTaskStart() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- MasterHooks - Class in org.apache.flink.runtime.checkpoint.hooks
-
Collection of methods to deal with checkpoint master hooks.
- MasterState - Class in org.apache.flink.runtime.checkpoint
-
Simple encapsulation of state generated by checkpoint coordinator.
- MasterState(String, byte[], int) - Constructor for class org.apache.flink.runtime.checkpoint.MasterState
- MasterTriggerRestoreHook<T> - Interface in org.apache.flink.runtime.checkpoint
-
The interface for hooks that can be called by the checkpoint coordinator when triggering or restoring a checkpoint.
- MasterTriggerRestoreHook.Factory - Interface in org.apache.flink.runtime.checkpoint
-
A factory to instantiate a
MasterTriggerRestoreHook. - match(ResourceProfile, ResourceCounter, Function<ResourceProfile, Integer>) - Method in class org.apache.flink.runtime.slots.DefaultRequirementMatcher
- match(ResourceProfile, ResourceCounter, Function<ResourceProfile, Integer>) - Method in interface org.apache.flink.runtime.slots.RequirementMatcher
-
Attempts to match the given resource profile with one of the given requirements.
- matchRequestsAndSlots(Collection<? extends PhysicalSlot>, Collection<PendingRequest>) - Method in enum org.apache.flink.runtime.jobmaster.slotpool.PreferredAllocationRequestSlotMatchingStrategy
- matchRequestsAndSlots(Collection<? extends PhysicalSlot>, Collection<PendingRequest>) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.RequestSlotMatchingStrategy
-
Match the given slots with the given collection of pending requests.
- matchRequestsAndSlots(Collection<? extends PhysicalSlot>, Collection<PendingRequest>) - Method in enum org.apache.flink.runtime.jobmaster.slotpool.SimpleRequestSlotMatchingStrategy
- MaterializationExpiredException - Exception in org.apache.flink.runtime.broadcast
-
Indicates that the
BroadcastVariableMaterializationhas materialized the broadcast variable at some point but discarded it already. - MaterializationExpiredException() - Constructor for exception org.apache.flink.runtime.broadcast.MaterializationExpiredException
- materializeBroadcastVariable(String, int, BatchTask<?, ?>, MutableReader<?>, TypeSerializerFactory<T>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableManager
-
Materializes the broadcast variable for the given name, scoped to the given task and its iteration superstep.
- materializeVariable(MutableReader<?>, TypeSerializerFactory<?>, BatchTask<?, ?>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
- MATERIALIZING - org.apache.flink.runtime.operators.DamBehavior
-
Constant indicating that the algorithm materialized (some) records, but may return records before all records are read.
- max - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
- max(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the maximum value of every window of the data stream at the given position.
- max(int) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current maximum of the data stream at the given position by the given key.
- max(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the maximum value of every window of the data stream at the given position.
- max(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the maximum value of the pojo data stream at the given field expression for every window.
- max(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current maximum of the data stream at the given field expression by the given key.
- max(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the maximum value of the pojo data stream at the given field expression for every window.
- MAX - org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter.AggregationMode
- MAX - org.apache.flink.streaming.api.functions.aggregation.AggregationFunction.AggregationType
- MAX_BATCH_SIZE - Static variable in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorFactory
- MAX_FILE_STATE_THRESHOLD - Static variable in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
-
Maximum size of state that is stored with the metadata, rather than in files.
- MAX_PARALLELISM_DEFAULT - Static variable in class org.apache.flink.runtime.jobgraph.JobVertex
- MAX_PRIORITY - Static variable in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
The maximal priority for mails.
- MAX_SUPPORTED_INPUT_COUNT - Static variable in class org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
- MAX_WATERMARK - Static variable in class org.apache.flink.streaming.api.watermark.Watermark
-
The watermark that signifies end-of-event-time.
- maxBackoff - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
The maximum backoff (in ms).
- maxBy(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the maximum element of every window of the data stream by the given position.
- maxBy(int) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current element with the maximum value at the given position by the given key.
- maxBy(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the maximum element of every window of the data stream by the given position.
- maxBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the maximum element of every window of the data stream by the given position.
- maxBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current element with the maximum value at the given position by the given key.
- maxBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the maximum element of every window of the data stream by the given position.
- maxBy(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the maximum element of every window of the data stream by the given position.
- maxBy(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current element with the maximum value at the given position by the given key.
- maxBy(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the maximum element of every window of the data stream by the given field.
- maxBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the maximum element of the pojo data stream by the given field expression for every window.
- maxBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current maximum element of the data stream by the given field expression by the given key.
- maxBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the maximum element of the pojo data stream by the given field expression for every window.
- MAXBY - org.apache.flink.streaming.api.functions.aggregation.AggregationFunction.AggregationType
- maxFileSize - Variable in class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFilePool
-
Max size for a physical file.
- maxNumFileHandles(int) - Method in class org.apache.flink.runtime.operators.sort.ExternalSorterBuilder
- maxParallelism() - Method in class org.apache.flink.runtime.operators.coordination.OperatorCoordinatorHolder
- maxParallelism() - Method in interface org.apache.flink.runtime.operators.coordination.OperatorInfo
- maxPhysicalFileSize - Variable in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
-
Max size for a physical file.
- maxRequiredBuffersPerGate() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- maxSpaceAmplification - Variable in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
- maxTimestamp() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow
- maxTimestamp() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
Gets the largest timestamp that still belongs to this window.
- maxTimestamp() - Method in class org.apache.flink.streaming.api.windowing.windows.Window
-
Gets the largest timestamp that still belongs to this window.
- maybeGetPath() - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
- maybeGetPath() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
- maybeGetPath() - Method in class org.apache.flink.runtime.state.OperatorStreamStateHandle
- maybeGetPath() - Method in class org.apache.flink.runtime.state.RetrievableStreamStateHandle
- maybeGetPath() - Method in interface org.apache.flink.runtime.state.StreamStateHandle
- maybeInterruptOnCancel(Thread, String, Long) - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
- maybeInterruptOnCancel(Thread, String, Long) - Method in interface org.apache.flink.runtime.jobgraph.tasks.TaskInvokable
-
Checks whether the task should be interrupted during cancellation and if so, execute the specified
Runnable interruptAction. - maybeInterruptOnCancel(Thread, String, Long) - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
Deprecated.
- maybeInterruptOnCancel(Thread, String, Long) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- maybeLogUsageWarning() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
- MaybeOffloaded() - Constructor for class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.MaybeOffloaded
- maybePersist(Buffer) - Method in class org.apache.flink.runtime.io.network.partition.consumer.ChannelStatePersister
- maybeRestartTasks(FailureHandlingResult) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.AdaptiveBatchScheduler
-
Modifies the vertices which need to be restarted.
- maybeRestartTasks(FailureHandlingResult) - Method in class org.apache.flink.runtime.scheduler.DefaultScheduler
- mayHaveFinishedTasks() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointPlan
-
Returns whether we support checkpoints after some tasks finished.
- mayHaveFinishedTasks() - Method in class org.apache.flink.runtime.checkpoint.DefaultCheckpointPlan
- mean - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
- measureIO(String, Object) - Static method in class org.apache.flink.runtime.io.network.logger.NetworkActionsLogger
- measureMailboxLatency() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
- median - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
- MemCheckpointStreamFactory - Class in org.apache.flink.runtime.state.memory
-
CheckpointStreamFactorythat produces streams that write to in-memory byte arrays. - MemCheckpointStreamFactory(int) - Constructor for class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory
-
Creates a new in-memory stream factory that accepts states whose serialized forms are up to the given number of bytes.
- MemCheckpointStreamFactory.MemoryCheckpointOutputStream - Class in org.apache.flink.runtime.state.memory
-
A
CheckpointStateOutputStreamthat writes into a byte array. - memory(List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.sort.ExternalSorterBuilder
- MEMORY_COMMITTED - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- MEMORY_MAX - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- MEMORY_USED - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- memoryAddress() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- MemoryAllocationException - Exception in org.apache.flink.runtime.memory
-
An exception to be thrown when a memory allocation operation is not successful.
- MemoryAllocationException() - Constructor for exception org.apache.flink.runtime.memory.MemoryAllocationException
- MemoryAllocationException(String) - Constructor for exception org.apache.flink.runtime.memory.MemoryAllocationException
- MemoryAllocationException(String, Throwable) - Constructor for exception org.apache.flink.runtime.memory.MemoryAllocationException
- MemoryAllocationException(Throwable) - Constructor for exception org.apache.flink.runtime.memory.MemoryAllocationException
- MemoryBackendCheckpointStorageAccess - Class in org.apache.flink.runtime.state.memory
-
An implementation of a checkpoint storage for the
JobManagerCheckpointStorage. - MemoryBackendCheckpointStorageAccess(JobID, Path, Path, boolean, int) - Constructor for class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorageAccess
-
Creates a new MemoryBackendCheckpointStorage.
- MemoryBlockIterator - Interface in org.apache.flink.runtime.util
-
The memory block iterator is an iterator that always buffers a block of elements in memory.
- MemoryCheckpointOutputStream(int) - Constructor for class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
- MemoryExecutionGraphInfoStore - Class in org.apache.flink.runtime.dispatcher
-
ExecutionGraphInfoStoreimplementation which stores theArchivedExecutionGraphin memory. - MemoryExecutionGraphInfoStore() - Constructor for class org.apache.flink.runtime.dispatcher.MemoryExecutionGraphInfoStore
- MemoryExecutionGraphInfoStore(Duration, int, ScheduledExecutor, Ticker) - Constructor for class org.apache.flink.runtime.dispatcher.MemoryExecutionGraphInfoStore
- memoryFraction(double) - Method in class org.apache.flink.runtime.operators.sort.ExternalSorterBuilder
- MemoryLogger - Class in org.apache.flink.runtime.taskmanager
-
A thread the periodically logs statistics about: Heap and non-heap memory usage Memory pools and pool usage Garbage collection times and counts
- MemoryLogger(Logger, long, CompletableFuture<Void>) - Constructor for class org.apache.flink.runtime.taskmanager.MemoryLogger
-
Creates a new memory logger that logs in the given interval and lives until the given termination future completes.
- memoryManager - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
- memoryManager - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
- MemoryManager - Class in org.apache.flink.runtime.memory
-
The memory manager governs the memory that Flink uses for sorting, hashing, caching or off-heap state backends (e.g.
- memoryProcessSpecFromConfig(Configuration) - Method in class org.apache.flink.runtime.util.config.memory.ProcessMemoryUtils
- MemoryReservationException - Exception in org.apache.flink.runtime.memory
-
An exception to be thrown when a memory reservation operation is not successful.
- MemoryTierConsumerAgent - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory
-
The data client is used to fetch data from memory tier.
- MemoryTierConsumerAgent(List<TieredStorageConsumerSpec>, TieredStorageNettyService) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory.MemoryTierConsumerAgent
- MemoryTierFactory - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory
-
The implementation of
TierFactoryfor memory tier. - MemoryTierFactory() - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory.MemoryTierFactory
- MemoryTierProducerAgent - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory
-
The memory tier implementation of
TierProducerAgent. - MemoryTierProducerAgent(TieredStoragePartitionId, int, int, int, int, boolean, TieredStorageMemoryManager, TieredStorageNettyService, TieredStorageResourceRegistry, BufferCompressor) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory.MemoryTierProducerAgent
- merge(Collection<W>, W) - Method in interface org.apache.flink.streaming.api.windowing.assigners.MergingWindowAssigner.MergeCallback
-
Specifies that the given windows should be merged into the result window.
- merge(ResourceProfile) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Calculates the sum of two resource profiles.
- merge(LeaderInformationRegister, String, LeaderInformation) - Static method in class org.apache.flink.runtime.leaderelection.LeaderInformationRegister
-
Merges another
LeaderInformationRegisterwith additional leader information into a newLeaderInformationRegisterinstance. - merge(CommittableCollector<CommT>) - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
-
Merges all information from an external collector into this collector.
- merge(W, Collection<W>, W, Collection<W>) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet.MergeFunction
-
This gets called when a merge occurs.
- MERGE_ACROSS_CHECKPOINT - org.apache.flink.runtime.checkpoint.filemerging.FileMergingType
- MERGE_WITHIN_CHECKPOINT - org.apache.flink.runtime.checkpoint.filemerging.FileMergingType
- mergedWindows - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
- mergeInto(CoLocationGroupImpl) - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroupImpl
- MergeIterator<E> - Class in org.apache.flink.runtime.operators.sort
-
An iterator that returns a sorted merge of the sequences of elements from a set of iterators, assuming those sequences are ordered themselves.
- MergeIterator(List<MutableObjectIterator<E>>, TypeComparator<E>) - Constructor for class org.apache.flink.runtime.operators.sort.MergeIterator
- mergeNamespaces(N, Collection<N>) - Method in interface org.apache.flink.runtime.state.internal.InternalMergingState
-
Merges the state of the current key for the given source namespaces into the state of the target namespace.
- mergeNamespaces(N, Collection<N>) - Method in class org.apache.flink.runtime.state.v2.AbstractAggregatingState
- mergeNamespaces(N, Collection<N>) - Method in class org.apache.flink.runtime.state.v2.AbstractReducingState
- mergeNamespaces(N, Collection<N>) - Method in class org.apache.flink.runtime.state.v2.adaptor.MergingStateAdaptor
- mergeNamespaces(N, Collection<N>) - Method in interface org.apache.flink.runtime.state.v2.internal.InternalMergingState
-
Merges the state of the current key for the given source namespaces into the state of the target namespace.
- mergePartitionedState(StateDescriptor<S, ?>) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.OnMergeContext
- mergePartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
- mergeSerializedBloomFilters(byte[], byte[]) - Static method in class org.apache.flink.runtime.operators.util.BloomFilter
- mergeVertexGroups(Set<V>, Set<V>, Map<V, Set<V>>) - Static method in class org.apache.flink.runtime.executiongraph.VertexGroupComputeUtil
- mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - Static method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
-
Merge overlapping
TimeWindows. - mergeWindows(Collection<W>, MergingWindowAssigner.MergeCallback<W>) - Method in class org.apache.flink.streaming.api.windowing.assigners.MergingWindowAssigner
-
Determines which windows (if any) should be merged.
- MergingStateAdaptor<K,N,IN,ACC,OUT,SYNCOUT> - Class in org.apache.flink.runtime.state.v2.adaptor
-
An adaptor that transforms
InternalMergingStateintoInternalMergingState. - MergingStateAdaptor(InternalMergingState<K, N, IN, ACC, SYNCOUT>) - Constructor for class org.apache.flink.runtime.state.v2.adaptor.MergingStateAdaptor
- MergingWindowAssigner<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssignerthat can merge windows. - MergingWindowAssigner() - Constructor for class org.apache.flink.streaming.api.windowing.assigners.MergingWindowAssigner
- MergingWindowAssigner.MergeCallback<W> - Interface in org.apache.flink.streaming.api.windowing.assigners
-
Callback to be used in
MergingWindowAssigner.mergeWindows(Collection, MergeCallback)for specifying which windows should be merged. - MergingWindowSet<W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
Utility for keeping track of merging
Windowswhen using aMergingWindowAssignerin aWindowOperator. - MergingWindowSet(MergingWindowAssigner<?, W>, ListState<Tuple2<W, W>>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
-
Restores a
MergingWindowSetfrom the given state. - MergingWindowSet.MergeFunction<W> - Interface in org.apache.flink.streaming.runtime.operators.windowing
-
Callback for
MergingWindowSet.addWindow(Window, MergeFunction). - MergingWindowStateStore(KeyedStateBackend<?>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
- message() - Method in enum org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- MessageHeaders<R extends RequestBody,P extends ResponseBody,M extends MessageParameters> - Interface in org.apache.flink.runtime.rest.messages
-
This class links
RequestBodys toResponseBodys types and contains meta-data required for their http headers. - MessageParameter<X> - Class in org.apache.flink.runtime.rest.messages
-
This class represents a single path/query parameter that can be used for a request.
- MessageParameter(String, MessageParameter.MessageParameterRequisiteness) - Constructor for class org.apache.flink.runtime.rest.messages.MessageParameter
- MessageParameter.MessageParameterRequisiteness - Enum in org.apache.flink.runtime.rest.messages
-
Enum for indicating whether a parameter is mandatory or optional.
- MessageParameters - Class in org.apache.flink.runtime.rest.messages
-
This class defines the path/query
MessageParameters that can be used for a request. - MessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.MessageParameters
- MessagePathParameter<X> - Class in org.apache.flink.runtime.rest.messages
-
This class represents path parameters of a request.
- MessagePathParameter(String) - Constructor for class org.apache.flink.runtime.rest.messages.MessagePathParameter
- MessageQueryParameter<X> - Class in org.apache.flink.runtime.rest.messages
-
This class represents query parameters of a request.
- MessageQueryParameter(String, MessageParameter.MessageParameterRequisiteness) - Constructor for class org.apache.flink.runtime.rest.messages.MessageQueryParameter
- META_KEY_GROUP - Static variable in class org.apache.flink.runtime.state.changelog.StateChange
- METADATA_FILE_NAME - Static variable in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorageAccess
-
The name of the metadata files in checkpoints / savepoints.
- MetadataOutputStreamWrapper - Class in org.apache.flink.runtime.state.filesystem
-
The wrapper manages metadata output stream close and commit.
- MetadataOutputStreamWrapper() - Constructor for class org.apache.flink.runtime.state.filesystem.MetadataOutputStreamWrapper
- MetadataSerializer - Interface in org.apache.flink.runtime.checkpoint.metadata
-
Deserializer for checkpoint metadata.
- MetadataSerializers - Class in org.apache.flink.runtime.checkpoint.metadata
-
Helper to access
MetadataSerializers for specific format versions. - MetadataV1Serializer - Class in org.apache.flink.runtime.checkpoint.metadata
-
Deserializer for checkpoints written in format
1(Flink 1.2.x format). - MetadataV2Serializer - Class in org.apache.flink.runtime.checkpoint.metadata
-
(De)serializer for checkpoint metadata format version 2.
- MetadataV2V3SerializerBase - Class in org.apache.flink.runtime.checkpoint.metadata
-
Base (De)serializer for checkpoint metadata format version 2 and 3.
- MetadataV2V3SerializerBase() - Constructor for class org.apache.flink.runtime.checkpoint.metadata.MetadataV2V3SerializerBase
- MetadataV2V3SerializerBase.DeserializationContext - Class in org.apache.flink.runtime.checkpoint.metadata
-
A context that keeps information needed during serialization.
- MetadataV3Serializer - Class in org.apache.flink.runtime.checkpoint.metadata
-
(De)serializer for checkpoint metadata format version 3.
- MetadataV3Serializer() - Constructor for class org.apache.flink.runtime.checkpoint.metadata.MetadataV3Serializer
-
Singleton, not meant to be instantiated.
- MetadataV4Serializer - Class in org.apache.flink.runtime.checkpoint.metadata
-
V4 serializer that adds
CheckpointPropertiesserialization. - MetadataV4Serializer() - Constructor for class org.apache.flink.runtime.checkpoint.metadata.MetadataV4Serializer
- MetadataV5Serializer - Class in org.apache.flink.runtime.checkpoint.metadata
-
V5 serializer that adds Operator name and uid.
- MetadataV5Serializer() - Constructor for class org.apache.flink.runtime.checkpoint.metadata.MetadataV5Serializer
- metaInfo - Variable in class org.apache.flink.runtime.state.heap.StateTable
-
Combined meta information such as name and serializers for this state.
- metaStateHandle - Variable in class org.apache.flink.runtime.state.AbstractIncrementalStateHandle
-
Primary meta data state of the incremental checkpoint.
- meter(String, M) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
- meter(String, M) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
- MeterDump(QueryScopeInfo, String, double) - Constructor for class org.apache.flink.runtime.metrics.dump.MetricDump.MeterDump
- Metric - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
Response type for a Metric and Metric-Value-Pair.
- Metric(String) - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.Metric
-
Creates a new
Metricwithout a value. - Metric(String, String) - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.Metric
-
Creates a new
Metricwith a possible value. - METRIC_CATEGORY_COUNTER - Static variable in class org.apache.flink.runtime.metrics.dump.MetricDump
-
Categories to be returned by
MetricDump.getCategory()to avoid instanceof checks. - METRIC_CATEGORY_GAUGE - Static variable in class org.apache.flink.runtime.metrics.dump.MetricDump
- METRIC_CATEGORY_HISTOGRAM - Static variable in class org.apache.flink.runtime.metrics.dump.MetricDump
- METRIC_CATEGORY_METER - Static variable in class org.apache.flink.runtime.metrics.dump.MetricDump
- METRIC_GROUP_INPUT - Static variable in class org.apache.flink.runtime.io.network.metrics.NettyShuffleMetricFactory
- METRIC_GROUP_OUTPUT - Static variable in class org.apache.flink.runtime.io.network.metrics.NettyShuffleMetricFactory
- METRIC_NAME - Static variable in class org.apache.flink.runtime.executiongraph.metrics.DownTimeGauge
- METRIC_NAME - Static variable in class org.apache.flink.runtime.executiongraph.metrics.UpTimeGauge
- METRIC_QUERY_SERVICE_NAME - Static variable in class org.apache.flink.runtime.metrics.dump.MetricQueryService
- MetricCollectionResponseBody - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
Response type for a collection of metrics.
- MetricCollectionResponseBody(Collection<Metric>) - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.MetricCollectionResponseBody
- MetricCollectionResponseBody.Deserializer - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
JSON deserializer for
MetricCollectionResponseBody. - MetricCollectionResponseBody.Serializer - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
JSON serializer for
MetricCollectionResponseBody. - MetricDump - Class in org.apache.flink.runtime.metrics.dump
-
A container for a dumped metric that contains the scope, name and value(s) of the metric.
- MetricDump.CounterDump - Class in org.apache.flink.runtime.metrics.dump
-
Container for the value of a
Counter. - MetricDump.GaugeDump - Class in org.apache.flink.runtime.metrics.dump
-
Container for the value of a
Gaugeas a string. - MetricDump.HistogramDump - Class in org.apache.flink.runtime.metrics.dump
-
Container for the values of a
Histogram. - MetricDump.MeterDump - Class in org.apache.flink.runtime.metrics.dump
-
Container for the rate of a
Meter. - MetricDumpDeserializer() - Constructor for class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricDumpDeserializer
- MetricDumpSerialization - Class in org.apache.flink.runtime.metrics.dump
-
Utility class for the serialization of metrics.
- MetricDumpSerialization.MetricDumpDeserializer - Class in org.apache.flink.runtime.metrics.dump
-
Deserializer for reading a list of
MetricDumpsfrom aMetricDumpSerialization.MetricSerializationResult. - MetricDumpSerialization.MetricDumpSerializer - Class in org.apache.flink.runtime.metrics.dump
-
Serializes a set of metrics into a
MetricDumpSerialization.MetricSerializationResult. - MetricDumpSerialization.MetricSerializationResult - Class in org.apache.flink.runtime.metrics.dump
-
This class encapsulates all serialized metrics and a count for each metric type.
- MetricDumpSerializer() - Constructor for class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricDumpSerializer
- MetricFetcher - Interface in org.apache.flink.runtime.rest.handler.legacy.metrics
-
The MetricFetcher can be used to fetch metrics from the JobManager and all registered TaskManagers.
- MetricFetcherImpl<T extends RestfulGateway> - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
-
Implementation of
MetricFetcherwhich fetches metrics from theMetricQueryServiceGateway. - MetricFetcherImpl(GatewayRetriever<T>, MetricQueryServiceRetriever, Executor, Duration, long) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricFetcherImpl
- MetricFilter - Interface in org.apache.flink.runtime.metrics.filter
-
A filter for metrics.
- metricGroup - Variable in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
-
The metric group for file merging snapshot manager.
- metricGroup() - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator.Context
-
Gets the metric group of the operator coordinator.
- metricGroup() - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinatorContext
- MetricNames - Class in org.apache.flink.runtime.metrics
-
Collection of metric names.
- MetricQueryService - Class in org.apache.flink.runtime.metrics.dump
-
The MetricQueryService creates a key-value representation of all metrics currently registered with Flink when queried.
- MetricQueryService(RpcService, String, long) - Constructor for class org.apache.flink.runtime.metrics.dump.MetricQueryService
- MetricQueryServiceGateway - Interface in org.apache.flink.runtime.webmonitor.retriever
-
MetricQueryServicerpc gateway interface. - MetricQueryServiceRetriever - Interface in org.apache.flink.runtime.webmonitor.retriever
-
Retriever for
MetricQueryServiceGateway. - MetricRegistry - Interface in org.apache.flink.runtime.metrics
-
Interface for a metric registry.
- MetricRegistryConfiguration - Class in org.apache.flink.runtime.metrics
-
Configuration object for
MetricRegistryImpl. - MetricRegistryConfiguration(ScopeFormats, char, long) - Constructor for class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
- MetricRegistryImpl - Class in org.apache.flink.runtime.metrics
-
A MetricRegistry keeps track of all registered
Metrics. - MetricRegistryImpl(MetricRegistryConfiguration) - Constructor for class org.apache.flink.runtime.metrics.MetricRegistryImpl
- MetricRegistryImpl(MetricRegistryConfiguration, Collection<ReporterSetup>) - Constructor for class org.apache.flink.runtime.metrics.MetricRegistryImpl
- MetricRegistryImpl(MetricRegistryConfiguration, Collection<ReporterSetup>, Collection<TraceReporterSetup>) - Constructor for class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
Creates a new MetricRegistry and starts the configured reporter.
- metrics - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
- metrics - Variable in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.ComponentMetricStore
- metrics - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Metric group for the operator.
- metrics - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
Metric group for the operator.
- MetricsAggregationParameter - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
TODO: add javadoc.
- MetricsAggregationParameter() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter
- MetricsAggregationParameter.AggregationMode - Enum in org.apache.flink.runtime.rest.messages.job.metrics
-
The available aggregations.
- MetricSerializationResult(byte[], byte[], byte[], byte[], int, int, int, int) - Constructor for class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
- metricsFilterParameter - Variable in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsMessageParameters
- metricsFilterParameter - Variable in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerOperatorMetricsMessageParameters
- metricsFilterParameter - Variable in class org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsMessageParameters
- metricsFilterParameter - Variable in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsMessageParameters
- MetricsFilterParameter - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
MessageQueryParameterfor filtering metrics provided byMetricStore. - MetricsFilterParameter() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.MetricsFilterParameter
- MetricsRegistrar - Interface in org.apache.flink.runtime.scheduler.metrics
-
A component that can register metrics.
- MetricStore - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
-
Nested data-structure to store metrics.
- MetricStore() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
- MetricStore.ComponentMetricStore - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
-
Structure containing metrics of a single component.
- MetricStore.SubtaskMetricStore - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
-
Sub-structure containing metrics of a single subtask.
- MetricStore.TaskManagerMetricStore - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
-
Sub-structure containing metrics of a single TaskManager.
- MetricStore.TaskMetricStore - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
-
Sub-structure containing metrics of a single Task.
- MetricUtils - Class in org.apache.flink.runtime.metrics.util
-
Utility class to register pre-defined metric sets.
- MIGRATE_LEGACY_FLINK_CONFIGURATION_TO_STANDARD_YAML - org.apache.flink.runtime.util.bash.BashJavaUtils.Command
-
Load configuration from legacy conf file and return standard yaml config file.
- migrateLegacyConfigurationToStandardYaml(String[]) - Static method in class org.apache.flink.runtime.util.bash.FlinkConfigLoader
- migrateLegacyConfigurationToStandardYaml(String[], String) - Static method in class org.apache.flink.runtime.util.ConfigurationParserUtils
- MimeTypes - Class in org.apache.flink.runtime.rest.handler.util
-
Simple utility class that resolves file extensions to MIME types.
- min - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
- min(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the minimum value of every window of the data stream at the given position.
- min(int) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current minimum of the data stream at the given position by the given key.
- min(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the minimum value of every window of the data stream at the given position.
- min(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the minimum value of the pojo data stream at the given field expression for every window.
- min(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current minimum of the data stream at the given field expression by the given key.
- min(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the minimum value of the pojo data stream at the given field expression for every window.
- MIN - org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter.AggregationMode
- MIN - org.apache.flink.streaming.api.functions.aggregation.AggregationFunction.AggregationType
- MIN_MONITORING_INTERVAL - Static variable in class org.apache.flink.streaming.api.functions.source.legacy.ContinuousFileMonitoringFunction
-
Deprecated.The minimum interval allowed between consecutive path scans.
- MIN_PAGE_SIZE - Static variable in class org.apache.flink.runtime.memory.MemoryManager
-
The minimal memory page size.
- MIN_PRIORITY - Static variable in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
The minimal priority for mails.
- minBy(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the minimum element of every window of the data stream by the given position.
- minBy(int) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current element with the minimum value at the given position by the given key.
- minBy(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the minimum element of every window of the data stream by the given position.
- minBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the minimum element of every window of the data stream by the given position.
- minBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current element with the minimum value at the given position by the given key.
- minBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the minimum element of every window of the data stream by the given position.
- minBy(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the minimum element of every window of the data stream by the given position.
- minBy(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current element with the minimum value at the given position by the given key.
- minBy(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the minimum element of every window of the data stream by the given field.
- minBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that gives the minimum element of the pojo data stream by the given field expression for every window.
- minBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current minimum element of the data stream by the given field expression by the given key.
- minBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that gives the minimum element of the pojo data stream by the given field expression for every window.
- MINBY - org.apache.flink.streaming.api.functions.aggregation.AggregationFunction.AggregationType
- MiniCluster - Class in org.apache.flink.runtime.minicluster
-
MiniCluster to execute Flink jobs locally.
- MiniCluster(MiniClusterConfiguration) - Constructor for class org.apache.flink.runtime.minicluster.MiniCluster
-
Creates a new Flink mini cluster based on the given configuration.
- MiniCluster(MiniClusterConfiguration, Supplier<Reference<RpcSystem>>) - Constructor for class org.apache.flink.runtime.minicluster.MiniCluster
- MiniCluster.CommonRpcServiceFactory - Class in org.apache.flink.runtime.minicluster
-
Factory which returns always the common
RpcService. - MiniCluster.DedicatedRpcServiceFactory - Class in org.apache.flink.runtime.minicluster
-
Factory which creates and registers new
RpcService. - MiniCluster.HaServices - Enum in org.apache.flink.runtime.minicluster
-
HA Services to use.
- MiniCluster.RpcServiceFactory - Interface in org.apache.flink.runtime.minicluster
-
Internal factory for
RpcService. - MiniClusterConfiguration - Class in org.apache.flink.runtime.minicluster
-
Configuration object for the
MiniCluster. - MiniClusterConfiguration(Configuration, int, RpcServiceSharing, String, MiniCluster.HaServices, PluginManager) - Constructor for class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
- MiniClusterConfiguration.Builder - Class in org.apache.flink.runtime.minicluster
-
Builder for the MiniClusterConfiguration.
- MiniClusterJobClient - Class in org.apache.flink.runtime.minicluster
-
A
JobClientfor aMiniCluster. - MiniClusterJobClient(JobID, MiniCluster, ClassLoader, MiniClusterJobClient.JobFinalizationBehavior) - Constructor for class org.apache.flink.runtime.minicluster.MiniClusterJobClient
- MiniClusterJobClient.JobFinalizationBehavior - Enum in org.apache.flink.runtime.minicluster
-
Determines the behavior of the
MiniClusterJobClientwhen the job finishes. - MiniDispatcher - Class in org.apache.flink.runtime.dispatcher
-
Mini Dispatcher which is instantiated as the dispatcher component by the
JobClusterEntrypoint. - MiniDispatcher(RpcService, DispatcherId, DispatcherServices, JobGraph, JobResult, DispatcherBootstrapFactory, JobManagerRunnerRegistry, ResourceCleanerFactory, ClusterEntrypoint.ExecutionMode) - Constructor for class org.apache.flink.runtime.dispatcher.MiniDispatcher
- MiniDispatcher(RpcService, DispatcherId, DispatcherServices, JobGraph, JobResult, DispatcherBootstrapFactory, ClusterEntrypoint.ExecutionMode) - Constructor for class org.apache.flink.runtime.dispatcher.MiniDispatcher
- MiniDispatcherRestEndpoint - Class in org.apache.flink.runtime.jobmaster
-
REST endpoint for the
JobClusterEntrypoint. - MiniDispatcherRestEndpoint(GatewayRetriever<? extends RestfulGateway>, Configuration, RestHandlerConfiguration, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, ScheduledExecutorService, MetricFetcher, LeaderElection, ExecutionGraphCache, FatalErrorHandler) - Constructor for class org.apache.flink.runtime.jobmaster.MiniDispatcherRestEndpoint
- MINIMAL_CHECKPOINT_TIME - Static variable in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
- MINIMUM_TIME_BETWEEN_CHECKPOINTS - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- minInputWatermarkGauge - Variable in class org.apache.flink.streaming.runtime.tasks.AbstractTwoInputStreamTask
- MinWatermarkGauge - Class in org.apache.flink.streaming.runtime.metrics
-
A
Gaugefor exposing the minimum watermark of chosenWatermarkGauges. - MinWatermarkGauge(WatermarkGauge...) - Constructor for class org.apache.flink.streaming.runtime.metrics.MinWatermarkGauge
- MISS_COUNT - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- missCounter(Counter) - Method in class org.apache.flink.runtime.metrics.groups.InternalCacheMetricGroup
- missingLength() - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- mkdirs() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
- MMAP - org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionType
-
A BoundedBlockingSubpartition type that stores the partition data in memory mapped file.
- mock(MetricGroup) - Static method in class org.apache.flink.runtime.metrics.groups.InternalSourceReaderMetricGroup
- ModifiableClusterConfiguration - Class in org.apache.flink.runtime.entrypoint
-
Configuration class which contains the parsed command line arguments for the
ClusterEntrypoint. - ModifiableClusterConfiguration(boolean, String, Properties, Properties, List<String>, List<Tuple3<String, String, String>>) - Constructor for class org.apache.flink.runtime.entrypoint.ModifiableClusterConfiguration
- ModifiableClusterConfigurationParserFactory - Class in org.apache.flink.runtime.entrypoint
-
A class can be used to extract the configuration from command line and modify it.
- ModifiableClusterConfigurationParserFactory() - Constructor for class org.apache.flink.runtime.entrypoint.ModifiableClusterConfigurationParserFactory
- monitorTarget(ResourceID, HeartbeatTarget<O>) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatManager
-
Start monitoring a
HeartbeatTarget. - monitorTarget(ResourceID, HeartbeatTarget<O>) - Method in class org.apache.flink.runtime.heartbeat.NoOpHeartbeatManager
- MORE_AVAILABLE - org.apache.flink.streaming.runtime.io.DataInputStatus
-
Indicator that more data is available and the input can be called immediately again to produce more data.
- moreAvailable - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputGate.InputWithData
- moreAvailable() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
- moreAvailable() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel.BufferAndAvailability
- morePriorityEvents - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputGate.InputWithData
- morePriorityEvents() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
- morePriorityEvents() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel.BufferAndAvailability
- moveElementToIdx(T, int) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
- MTIME - Static variable in class org.apache.flink.runtime.rest.messages.LogInfo
- MultiInputSortingDataInput<IN,K> - Class in org.apache.flink.streaming.api.operators.sort
-
An input that wraps an underlying input and sorts the incoming records.
- MultiInputSortingDataInput.SelectableSortingInputs - Class in org.apache.flink.streaming.api.operators.sort
-
A wrapper that combines sorting
inputswith aInputSelectablethat should be used to choose which input to consume next from. - MultiInputTransformationTranslator<OUT> - Class in org.apache.flink.streaming.runtime.translators
-
A
TransformationTranslatorfor theMultipleInputTransformationand theKeyedMultipleInputTransformation. - MultiInputTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.MultiInputTransformationTranslator
- MultipartRoutes - Class in org.apache.flink.runtime.rest.handler.router
-
A utility for
FileUploadHandlerto determine whether it should accept a request. - MultipartRoutes.Builder - Class in org.apache.flink.runtime.rest.handler.router
- MultipleFuturesAvailabilityHelper - Class in org.apache.flink.streaming.runtime.io
-
This class is semi-thread safe.
- MultipleFuturesAvailabilityHelper(int) - Constructor for class org.apache.flink.streaming.runtime.io.MultipleFuturesAvailabilityHelper
- MultipleInputSelectionHandler - Class in org.apache.flink.streaming.runtime.io
-
This handler is mainly used for selecting the next available input index in
StreamMultipleInputProcessor. - MultipleInputSelectionHandler(InputSelectable, int) - Constructor for class org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
- MultipleInputStreamOperator<OUT> - Interface in org.apache.flink.streaming.api.operators
-
Interface for stream operators with multiple
Inputs. - MultipleInputStreamTask<OUT> - Class in org.apache.flink.streaming.runtime.tasks
-
A
StreamTaskfor executing aMultipleInputStreamOperatorand supporting theMultipleInputStreamOperatorto select input for reading. - MultipleInputStreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
- MultipleInputTransformation<OUT> - Class in org.apache.flink.streaming.api.transformations
-
AbstractMultipleInputTransformationimplementation for non-keyed streams. - MultipleInputTransformation(String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.MultipleInputTransformation
- MultipleInputTransformation(String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.MultipleInputTransformation
- MultipleJobsDetails - Class in org.apache.flink.runtime.messages.webmonitor
-
An actor messages describing details of various jobs.
- MultipleJobsDetails(Collection<JobDetails>) - Constructor for class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
- MultipleRecordWriters<T extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.writer
-
The specific delegate implementation for the multiple outputs case.
- MultipleRecordWriters(List<RecordWriter<T>>) - Constructor for class org.apache.flink.runtime.io.network.api.writer.MultipleRecordWriters
- multiply(int) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
- MUST_BE_KNOWN - org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory.PartitionLocationConstraint
- mustBePipelinedConsumed() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
return if this partition's upstream and downstream must be scheduled in the same time.
- MutableHashTable<BT,PT> - Class in org.apache.flink.runtime.operators.hash
-
An implementation of a Hybrid Hash Join.
- MutableHashTable(TypeSerializer<BT>, TypeSerializer<PT>, TypeComparator<BT>, TypeComparator<PT>, TypePairComparator<PT, BT>, List<MemorySegment>, IOManager) - Constructor for class org.apache.flink.runtime.operators.hash.MutableHashTable
- MutableHashTable(TypeSerializer<BT>, TypeSerializer<PT>, TypeComparator<BT>, TypeComparator<PT>, TypePairComparator<PT, BT>, List<MemorySegment>, IOManager, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.MutableHashTable
- MutableHashTable(TypeSerializer<BT>, TypeSerializer<PT>, TypeComparator<BT>, TypeComparator<PT>, TypePairComparator<PT, BT>, List<MemorySegment>, IOManager, int, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.MutableHashTable
- MutableHashTable.HashBucketIterator<BT,PT> - Class in org.apache.flink.runtime.operators.hash
- MutableHashTable.ProbeIterator<PT> - Class in org.apache.flink.runtime.operators.hash
- MutableHashTable.UnmatchedBuildIterator<BT,PT> - Class in org.apache.flink.runtime.operators.hash
-
Iterate all the elements in memory which has not been probed during probe phase.
- MutableIOMetrics - Class in org.apache.flink.runtime.rest.handler.util
-
This class is a mutable version of the
IOMetricsclass that allows adding up IO-related metrics. - MutableIOMetrics() - Constructor for class org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
- MutableReader<T extends org.apache.flink.core.io.IOReadableWritable> - Interface in org.apache.flink.runtime.io.network.api.reader
-
A record-oriented reader for mutable record types.
- MutableRecordReader<T extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.reader
-
Implementation of the record-oriented reader for mutable record types.
- MutableRecordReader(InputGate, String[]) - Constructor for class org.apache.flink.runtime.io.network.api.reader.MutableRecordReader
-
Creates a new MutableRecordReader that de-serializes records from the given input gate and can spill partial records to disk, if they grow large.
- MutableVertexAttemptNumberStore - Interface in org.apache.flink.runtime.executiongraph
-
Mutability extension to the
VertexAttemptNumberStore. - MutableVertexParallelismStore - Interface in org.apache.flink.runtime.scheduler
-
Mutability extension to the
VertexParallelismStore.
N
- name - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump
-
The name of the stored metric.
- name - Variable in class org.apache.flink.runtime.state.RegisteredStateMetaInfoBase
-
The name of the state
- name() - Method in class org.apache.flink.runtime.checkpoint.MasterState
- name() - Method in class org.apache.flink.streaming.api.lineage.DefaultLineageDataset
- name() - Method in interface org.apache.flink.streaming.api.lineage.LineageDataset
- name() - Method in interface org.apache.flink.streaming.api.lineage.LineageDatasetFacet
-
Name for the facet which will be used as key in facets of LineageDataset.
- name(String) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Sets the name of this sink.
- name(String) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the name of the current data stream.
- NAME - Static variable in class org.apache.flink.runtime.rest.messages.LogInfo
- namespace() - Method in class org.apache.flink.streaming.api.lineage.DefaultLineageDataset
- namespace() - Method in interface org.apache.flink.streaming.api.lineage.LineageDataset
- NAMESPACE_SERIALIZER - org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.CommonSerializerKeys
- namespaceSerializer - Variable in class org.apache.flink.runtime.state.heap.AbstractHeapState
- nameToCheckpointID(String) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointStoreUtil
-
Get the checkpoint id from name.
- nameToCheckpointID(String) - Method in enum org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointStoreUtil
-
Converts a path to the checkpoint id.
- nameToJobID(String) - Method in interface org.apache.flink.runtime.jobmanager.JobGraphStoreUtil
-
Get the job id from name.
- nameToJobID(String) - Method in enum org.apache.flink.runtime.jobmanager.ZooKeeperJobGraphStoreUtil
- NATURAL - org.apache.flink.streaming.api.windowing.assigners.WindowStagger
-
When the first event is received in the window operator, take the difference between the start of the window and current procesing time as the offset.
- needAnnounceBacklog() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
Returns true if the producer backlog need to be announced to the consumer.
- needMarkPartitionFinished(ResultPartitionType) - Method in interface org.apache.flink.runtime.executiongraph.MarkPartitionFinishedStrategy
-
Decide whether partition needs to be marked as finished.
- needReconcile() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceReconcileResult
-
Returns whether the cluster resource need reconcile.
- needRecover() - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.BatchJobRecoveryHandler
-
Determines whether the job needs to undergo recovery.
- needRecover() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DefaultBatchJobRecoveryHandler
- needRecover() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DummyBatchJobRecoveryHandler
- needsAlignment() - Method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
- needsChannelState() - Method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
- NESTEDLOOP_BLOCKED_OUTER_FIRST - org.apache.flink.runtime.operators.DriverStrategy
- NESTEDLOOP_BLOCKED_OUTER_SECOND - org.apache.flink.runtime.operators.DriverStrategy
- NESTEDLOOP_STREAMED_OUTER_FIRST - org.apache.flink.runtime.operators.DriverStrategy
- NESTEDLOOP_STREAMED_OUTER_SECOND - org.apache.flink.runtime.operators.DriverStrategy
- netRuntime(long) - Method in class org.apache.flink.runtime.jobmaster.JobResult.Builder
- NETTY_SHUFFLE_SERVICE_FACTORY_CLASS - Static variable in class org.apache.flink.runtime.shuffle.ShuffleServiceOptions
- NettyBufferPool - Class in org.apache.flink.runtime.io.network.netty
-
Extends around Netty's
PooledByteBufAllocatorwith strict control over the number of created arenas. - NettyBufferPool(int) - Constructor for class org.apache.flink.runtime.io.network.netty.NettyBufferPool
-
Creates Netty's buffer pool with the specified number of direct arenas.
- nettyConfig() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- NettyConfig - Class in org.apache.flink.runtime.io.network.netty
- NettyConfig(InetAddress, int, int, int, Configuration) - Constructor for class org.apache.flink.runtime.io.network.netty.NettyConfig
- NettyConfig(InetAddress, PortRange, int, int, Configuration) - Constructor for class org.apache.flink.runtime.io.network.netty.NettyConfig
- NettyConnectionId - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty
-
NettyConnectionIdindicates the unique id of netty connection. - NettyConnectionManager - Class in org.apache.flink.runtime.io.network.netty
- NettyConnectionManager(NettyBufferPool, ResultPartitionProvider, TaskEventPublisher, NettyConfig, boolean) - Constructor for class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
- NettyConnectionManager(ResultPartitionProvider, TaskEventPublisher, NettyConfig, boolean) - Constructor for class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
- NettyConnectionReader - Interface in org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty
-
NettyConnectionReaderis used byTierConsumerAgentto read buffer from netty. - NettyConnectionReaderImpl - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty
-
The default implementation of
NettyConnectionReader. - NettyConnectionReaderImpl(Supplier<InputChannel>) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyConnectionReaderImpl
- NettyConnectionWriter - Interface in org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty
-
NettyConnectionWriteris used byTierProducerAgentto write buffers to netty connection. - NettyConnectionWriterImpl - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty
-
The default implementation of
NettyConnectionWriter. - NettyConnectionWriterImpl(NettyPayloadManager) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyConnectionWriterImpl
- NettyMessage - Class in org.apache.flink.runtime.io.network.netty
-
A simple and generic interface to serialize messages to Netty's buffer space.
- NettyMessage() - Constructor for class org.apache.flink.runtime.io.network.netty.NettyMessage
- NettyMessageClientDecoderDelegate - Class in org.apache.flink.runtime.io.network.netty
-
Decodes messages from the received netty buffers.
- NettyPartitionRequestClient - Class in org.apache.flink.runtime.io.network.netty
-
Partition request client for remote partition requests.
- NettyPartitionRequestListener - Class in org.apache.flink.runtime.io.network.netty
-
Implementation of
PartitionRequestListenerfor netty partition request. - NettyPartitionRequestListener(ResultPartitionProvider, NetworkSequenceViewReader, ResultSubpartitionIndexSet, ResultPartitionID) - Constructor for class org.apache.flink.runtime.io.network.netty.NettyPartitionRequestListener
- NettyPartitionRequestListener(ResultPartitionProvider, NetworkSequenceViewReader, ResultSubpartitionIndexSet, ResultPartitionID, long) - Constructor for class org.apache.flink.runtime.io.network.netty.NettyPartitionRequestListener
- NettyPayload - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty
-
The
NettyPayloadrepresents the payload that will be transferred to netty connection. - NettyPayloadManager - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty
-
NettyPayloadManageris used to contain all netty payloads from a storage tier. - NettyPayloadManager() - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyPayloadManager
- NettyProtocol - Class in org.apache.flink.runtime.io.network.netty
-
Defines the server and client channel handlers, i.e. the protocol, used by netty.
- NettyServiceProducer - Interface in org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty
-
NettyServiceProduceris used as the callback to registerNettyConnectionWriterand disconnect netty connection inTierProducerAgent. - NettyShuffleDescriptor - Class in org.apache.flink.runtime.shuffle
-
Default implementation of
ShuffleDescriptorforNettyShuffleMaster. - NettyShuffleDescriptor(ResourceID, NettyShuffleDescriptor.PartitionConnectionInfo, ResultPartitionID) - Constructor for class org.apache.flink.runtime.shuffle.NettyShuffleDescriptor
- NettyShuffleDescriptor(ResourceID, NettyShuffleDescriptor.PartitionConnectionInfo, ResultPartitionID, List<TierShuffleDescriptor>) - Constructor for class org.apache.flink.runtime.shuffle.NettyShuffleDescriptor
- NettyShuffleDescriptor.LocalExecutionPartitionConnectionInfo - Enum in org.apache.flink.runtime.shuffle
-
Local partition connection information.
- NettyShuffleDescriptor.NetworkPartitionConnectionInfo - Class in org.apache.flink.runtime.shuffle
-
Remote partition connection information with index to query partition.
- NettyShuffleDescriptor.PartitionConnectionInfo - Interface in org.apache.flink.runtime.shuffle
-
Information for connection to partition producer for shuffle exchange.
- NettyShuffleEnvironment - Class in org.apache.flink.runtime.io.network
-
The implementation of
ShuffleEnvironmentbased on netty network communication, local memory and disk files. - NettyShuffleEnvironmentConfiguration - Class in org.apache.flink.runtime.taskmanager
-
Configuration object for the network stack.
- NettyShuffleEnvironmentConfiguration(int, int, int, int, int, int, int, Optional<Integer>, Duration, boolean, NettyConfig, String[], BoundedBlockingSubpartitionType, boolean, NettyShuffleEnvironmentOptions.CompressionCodec, int, long, int, int, BufferDebloatConfiguration, boolean, int, TieredStorageConfiguration) - Constructor for class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- NettyShuffleMaster - Class in org.apache.flink.runtime.shuffle
-
Default
ShuffleMasterfor netty and local file based shuffle implementation. - NettyShuffleMaster(ShuffleMasterContext) - Constructor for class org.apache.flink.runtime.shuffle.NettyShuffleMaster
- NettyShuffleMetricFactory - Class in org.apache.flink.runtime.io.network.metrics
-
Factory for netty shuffle service metrics.
- NettyShuffleServiceFactory - Class in org.apache.flink.runtime.io.network
-
Netty based shuffle service implementation.
- NettyShuffleServiceFactory() - Constructor for class org.apache.flink.runtime.io.network.NettyShuffleServiceFactory
- NettyShuffleUtils - Class in org.apache.flink.runtime.shuffle
-
Utils to calculate network memory requirement of a vertex from network configuration and details of input and output.
- NetworkActionsLogger - Class in org.apache.flink.runtime.io.network.logger
-
Utility class for logging actions that happened in the network stack for debugging purposes.
- NetworkActionsLogger() - Constructor for class org.apache.flink.runtime.io.network.logger.NetworkActionsLogger
- NetworkBuffer - Class in org.apache.flink.runtime.io.network.buffer
-
Wrapper for pooled
MemorySegmentinstances. - NetworkBuffer(MemorySegment, BufferRecycler) - Constructor for class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
Creates a new buffer instance backed by the given memorySegment with 0 for the readerIndex and writerIndex.
- NetworkBuffer(MemorySegment, BufferRecycler, Buffer.DataType) - Constructor for class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
Creates a new buffer instance backed by the given memorySegment with 0 for the readerIndex and writerIndex.
- NetworkBuffer(MemorySegment, BufferRecycler, Buffer.DataType, boolean, int) - Constructor for class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
Creates a new buffer instance backed by the given memorySegment with 0 for the readerIndex and size as writerIndex.
- NetworkBuffer(MemorySegment, BufferRecycler, Buffer.DataType, int) - Constructor for class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
Creates a new buffer instance backed by the given memorySegment with 0 for the readerIndex and size as writerIndex.
- networkBufferPool - Variable in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGateFactory
- NetworkBufferPool - Class in org.apache.flink.runtime.io.network.buffer
-
The NetworkBufferPool is a fixed size pool of
MemorySegmentinstances for the network stack. - NetworkBufferPool(int, int) - Constructor for class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
- NetworkBufferPool(int, int, Duration) - Constructor for class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
Allocates all
MemorySegmentinstances managed by this pool. - networkBufferSize() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- networkBuffersPerChannel - Variable in class org.apache.flink.runtime.io.network.partition.consumer.RecoveredInputChannel
- networkBuffersPerChannel() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- NetworkClientHandler - Interface in org.apache.flink.runtime.io.network
-
Channel handler to read and write network messages on client side.
- NetworkInputConfig(TypeSerializer<?>, int) - Constructor for class org.apache.flink.streaming.api.graph.StreamConfig.NetworkInputConfig
- NetworkInputConfig(TypeSerializer<?>, int, StreamConfig.InputRequirement) - Constructor for class org.apache.flink.streaming.api.graph.StreamConfig.NetworkInputConfig
- NetworkPartitionConnectionInfo(InetSocketAddress, int) - Constructor for class org.apache.flink.runtime.shuffle.NettyShuffleDescriptor.NetworkPartitionConnectionInfo
- NetworkSequenceViewReader - Interface in org.apache.flink.runtime.io.network
-
Simple wrapper for the partition readerQueue iterator, which increments a sequence number for each returned buffer and remembers the receiver ID.
- NEVER - org.apache.flink.streaming.api.operators.ChainingStrategy
-
The operator will not be chained to the preceding or succeeding operators.
- NEVER_RETAIN_AFTER_TERMINATION - org.apache.flink.runtime.checkpoint.CheckpointRetentionPolicy
-
Checkpoints should always be cleaned up when an application reaches a terminal state.
- NeverTrigger() - Constructor for class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
- newBatchJobGraphBuilder() - Static method in class org.apache.flink.runtime.jobgraph.JobGraphBuilder
- newBuffer(Buffer, int, int) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyPayload
- newBuilder() - Static method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
- newBuilder() - Static method in class org.apache.flink.runtime.jobgraph.JobResourceRequirements
- newBuilder() - Static method in class org.apache.flink.runtime.state.metrics.LatencyTrackingStateConfig
- newBuilder(ResourceProfile) - Static method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
- newBuilder(MemoryManager, AbstractInvokable, TypeSerializer<E>, TypeComparator<E>) - Static method in class org.apache.flink.runtime.operators.sort.ExternalSorter
-
Creates a builder for the
ExternalSorter. - newBuilder(MemoryManager, TaskInvokable, TypeSerializer<E>, TypeComparator<E>, ExecutionConfig) - Static method in class org.apache.flink.runtime.operators.sort.ExternalSorter
-
Creates a builder for the
ExternalSorter. - newBuilder(GatewayRetriever<ResourceManagerGateway>, ScheduledExecutorService, Duration) - Static method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexThreadInfoTrackerBuilder
-
Create a new
VertexThreadInfoTrackerBuilder. - newDynamicPropertiesOption() - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Get an instance of the dynamic properties option.
- newError(Throwable) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyPayload
- newId() - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyConnectionId
- newIllegalKeyGroupException(int, KeyGroupRange) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
- newProcessSpecBuilder(Configuration) - Static method in class org.apache.flink.runtime.clusterframework.TaskExecutorProcessUtils
- newSegment(int) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyPayload
- newStreamingJobGraphBuilder() - Static method in class org.apache.flink.runtime.jobgraph.JobGraphBuilder
- newThread(Runnable) - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinatorProvider.CoordinatorExecutorThreadFactory
- newThread(Runnable) - Method in class org.apache.flink.runtime.taskmanager.DispatcherThreadFactory
- next() - Method in class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
- next() - Method in class org.apache.flink.runtime.io.disk.FileBasedBufferIterator
- next() - Method in class org.apache.flink.runtime.io.disk.InputViewIterator
- next() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.Enumerator
- next() - Method in interface org.apache.flink.runtime.io.network.api.reader.Reader
- next() - Method in class org.apache.flink.runtime.io.network.api.reader.RecordReader
- next() - Method in class org.apache.flink.runtime.iterative.io.HashPartitionIterator
- next() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable.SimpleIterator
- next() - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable.EntryIterator
- next() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.EntryIterator
- next() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.HashBucketIterator
- next() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.ProbeIterator
- next() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.UnmatchedBuildIterator
- next() - Method in class org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
- next() - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
- next() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
- next() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
- next() - Method in class org.apache.flink.runtime.operators.sort.MergeIterator
-
Gets the next smallest element, with respect to the definition of order implied by the
TypeSerializerprovided to this iterator. - next() - Method in class org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
- next() - Method in class org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
- next() - Method in interface org.apache.flink.runtime.operators.util.CoGroupTaskIterator
-
Moves the internal pointer to the next key (if present).
- next() - Method in class org.apache.flink.runtime.operators.util.metrics.CountingIterator
- next() - Method in class org.apache.flink.runtime.operators.util.metrics.CountingMutableObjectIterator
- next() - Method in class org.apache.flink.runtime.operators.util.ReaderIterator
- next() - Method in class org.apache.flink.runtime.state.changelog.SequenceNumber.GenericSequenceNumber
- next() - Method in interface org.apache.flink.runtime.state.changelog.SequenceNumber
- next() - Method in class org.apache.flink.runtime.state.heap.HeapKeyValueStateIterator
- next() - Method in interface org.apache.flink.runtime.state.KeyValueStateIterator
-
Advances the iterator.
- next() - Method in interface org.apache.flink.runtime.state.restore.ThrowingIterator
-
Returns the next element in the iteration.
- next() - Method in class org.apache.flink.runtime.state.v2.SyncIteratorWrapper
- next() - Method in class org.apache.flink.runtime.util.EmptyIterator
-
Always throws a
NoSuchElementException. - next() - Method in class org.apache.flink.runtime.util.EmptyMutableObjectIterator
-
Always returns null.
- next() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator.ValuesIterator
- next() - Method in class org.apache.flink.runtime.util.NonReusingMutableToRegularIteratorWrapper
- next() - Method in class org.apache.flink.runtime.util.RegularToMutableObjectIterator
- next() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator.ValuesIterator
-
Prior to call this method, call hasNext() once!
- next() - Method in class org.apache.flink.runtime.util.ReusingMutableToRegularIteratorWrapper
- next() - Method in class org.apache.flink.runtime.util.SingleElementIterator
- next() - Method in class org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
-
Get next user visible result, returns null if currently there is no more.
- next() - Method in class org.apache.flink.streaming.api.operators.collect.CollectResultFetcher
- next() - Method in class org.apache.flink.streaming.api.operators.collect.CollectResultIterator
- next() - Method in class org.apache.flink.streaming.api.operators.MapPartitionIterator
- next(BT) - Method in class org.apache.flink.runtime.iterative.io.HashPartitionIterator
- next(BT) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.HashBucketIterator
- next(BT) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.UnmatchedBuildIterator
- next(E) - Method in class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
- next(E) - Method in class org.apache.flink.runtime.io.disk.InputViewIterator
- next(E) - Method in class org.apache.flink.runtime.operators.sort.MergeIterator
-
Gets the next smallest element, with respect to the definition of order implied by the
TypeSerializerprovided to this iterator. - next(E) - Method in class org.apache.flink.runtime.util.EmptyMutableObjectIterator
-
Always returns null.
- next(IN) - Method in class org.apache.flink.runtime.operators.util.metrics.CountingMutableObjectIterator
- next(T) - Method in interface org.apache.flink.runtime.io.network.api.reader.MutableReader
- next(T) - Method in class org.apache.flink.runtime.io.network.api.reader.MutableRecordReader
- next(T) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable.EntryIterator
- next(T) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.EntryIterator
- next(T) - Method in class org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
- next(T) - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
- next(T) - Method in class org.apache.flink.runtime.operators.util.ReaderIterator
- next(T) - Method in class org.apache.flink.runtime.util.RegularToMutableObjectIterator
- nextBlock() - Method in class org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
- nextBlock() - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
- nextBlock() - Method in interface org.apache.flink.runtime.util.MemoryBlockIterator
-
Move the iterator to the next memory block.
- nextElement - Variable in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
- nextEntries() - Method in interface org.apache.flink.runtime.state.internal.InternalKvState.StateIncrementalVisitor
-
Return some next entries which are available at the moment.
- nextKey() - Method in interface org.apache.flink.runtime.util.KeyGroupedIterator
- nextKey() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator
-
Moves the iterator to the next key.
- nextKey() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator
-
Moves the iterator to the next key.
- nextOverflowBucket - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
- nextOverflowBucket - Variable in class org.apache.flink.runtime.operators.hash.InMemoryPartition
- nextPayloadForContinuousLoading() - Method in class org.apache.flink.runtime.asyncprocessing.AbstractStateIterator
-
To perform following loading, build and get next payload for the next request.
- nextRecord() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
- nextSegment() - Method in class org.apache.flink.runtime.memory.ListMemorySegmentSource
- nextSegment() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
This is the method called by the partitions to request memory to serialize records.
- nextSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.FileChannelInputView
- nextSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
Gets the next segment from the asynchronous block reader.
- nextSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.HeaderlessChannelReaderInputView
- nextSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.RandomAccessInputView
- nextSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
- nextSegment(MemorySegment) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
The method by which concrete subclasses realize page crossing.
- nextSegment(MemorySegment) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
- nextSegment(MemorySegment, int) - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
- nextSegment(MemorySegment, int) - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
- nextSegment(MemorySegment, int) - Method in class org.apache.flink.runtime.io.disk.RandomAccessOutputView
- nextSegment(MemorySegment, int) - Method in class org.apache.flink.runtime.io.disk.SimpleCollectingOutputView
- nextSegment(MemorySegment, int) - Method in class org.apache.flink.runtime.io.disk.SpillingBuffer
- nextSegment(MemorySegment, int) - Method in class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
- nextSegment(MemorySegment, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
This method must return a segment.
- nextSegment(MemorySegment, int) - Method in class org.apache.flink.runtime.operators.hash.HashPartition.BuildSideBuffer
- nextSelection() - Method in class org.apache.flink.streaming.api.operators.co.BatchCoBroadcastWithNonKeyedOperator
- nextSelection() - Method in interface org.apache.flink.streaming.api.operators.InputSelectable
-
Returns the next
InputSelectionthat wants to get the record. - nextSequenceNumber() - Method in interface org.apache.flink.runtime.state.changelog.StateChangelogWriter
-
Get
SequenceNumberto be used for the next element added byappend. - nextTimer - Variable in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
-
The one and only Future (if any) registered to execute the next
Triggerableaction, when its (processing) time arrives. - nioBuffer(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- nioBuffer(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- nioBufferCount() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- nioBuffers(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- NO_ALIGNED_CHECKPOINT_TIME_OUT - Static variable in class org.apache.flink.runtime.checkpoint.CheckpointOptions
- NO_CHECKPOINT - Static variable in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator
-
The checkpoint ID passed to the restore methods when no completed checkpoint exists, yet.
- NO_CURRENT_KEY_GROUP - Static variable in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
- NO_DRAIN - org.apache.flink.runtime.io.network.api.StopMode
- NO_EXTERNAL_RESOURCES - Static variable in interface org.apache.flink.runtime.externalresource.ExternalResourceInfoProvider
- NO_OFFSET_SET - Static variable in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
- NO_OP - Static variable in interface org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter
- NO_OP - Static variable in interface org.apache.flink.runtime.checkpoint.channel.SequentialChannelStateReader
- NO_OP - Static variable in interface org.apache.flink.runtime.state.changelog.LocalChangelogRegistry
- NO_OP - Static variable in interface org.apache.flink.streaming.runtime.io.checkpointing.UpstreamRecoveryTracker
- NO_OP_FILTER - Static variable in interface org.apache.flink.runtime.metrics.filter.MetricFilter
-
Filter that accepts every metric.
- NO_RESCALE - Static variable in class org.apache.flink.runtime.checkpoint.InflightDataRescalingDescriptor
- NO_SHARING - org.apache.flink.runtime.checkpoint.SnapshotType.SharingFilesStrategy
- NO_STRINGS - Static variable in class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
- NO_TRANSFORM - Static variable in interface org.apache.flink.runtime.state.StateSnapshotTransformer.StateSnapshotTransformFactory
- NO_VALUES - Static variable in class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
- NO_VERSION - Static variable in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters
- NoMatchSecurityFactoryException - Exception in org.apache.flink.runtime.security
-
Exception for not finding suitable security factories.
- NoMatchSecurityFactoryException(String, String, List<?>) - Constructor for exception org.apache.flink.runtime.security.NoMatchSecurityFactoryException
-
Exception for not finding suitable security factories.
- NoMatchSecurityFactoryException(String, String, List<?>, Throwable) - Constructor for exception org.apache.flink.runtime.security.NoMatchSecurityFactoryException
-
Exception for not finding suitable security factories.
- noMoreBlocks - Variable in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
- NoMoreSplitsEvent - Class in org.apache.flink.runtime.source.event
-
A source event sent from the SplitEnumerator to the SourceReader to indicate that no more splits will be assigned to the source reader anymore.
- NoMoreSplitsEvent() - Constructor for class org.apache.flink.runtime.source.event.NoMoreSplitsEvent
- NON_BLOCKING - org.apache.flink.runtime.checkpoint.filemerging.PhysicalFilePool.Type
- NON_LOCAL - org.apache.flink.runtime.jobmanager.scheduler.Locality
-
The task was scheduled to a destination not included in its locality preferences.
- NonBlockingPhysicalFilePool - Class in org.apache.flink.runtime.checkpoint.filemerging
-
A Non-Blocking
PhysicalFilePoolwhich will always provide usable physical file without blocking. - NonBlockingPhysicalFilePool(long, PhysicalFile.PhysicalFileCreator) - Constructor for class org.apache.flink.runtime.checkpoint.filemerging.NonBlockingPhysicalFilePool
- NonChainedOutput - Class in org.apache.flink.streaming.api.graph
-
Used by operator chain and represents a non-chained output of the corresponding stream operator.
- NonChainedOutput(boolean, int, int, int, long, boolean, IntermediateDataSetID, OutputTag<?>, StreamPartitioner<?>, ResultPartitionType) - Constructor for class org.apache.flink.streaming.api.graph.NonChainedOutput
- NonClosingCheckpointOutputStream<T extends StreamStateHandle> - Class in org.apache.flink.runtime.state
-
Abstract class to implement custom checkpoint output streams which should not be closable for user code.
- NonClosingCheckpointOutputStream(CheckpointStateOutputStream) - Constructor for class org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
- NonClosingInputStreamDecorator - Class in org.apache.flink.runtime.util
-
Decorator for input streams that ignores calls to
InputStream.close(). - NonClosingInputStreamDecorator(InputStream) - Constructor for class org.apache.flink.runtime.util.NonClosingInputStreamDecorator
- NonClosingOutputStreamDecorator - Class in org.apache.flink.runtime.util
-
Decorator for input streams that ignores calls to
OutputStream.close(). - NonClosingOutputStreamDecorator(OutputStream) - Constructor for class org.apache.flink.runtime.util.NonClosingOutputStreamDecorator
- nondeterministicValue(T) - Static method in class org.apache.flink.runtime.entrypoint.DeterminismEnvelope
- none() - Static method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
- NONE - org.apache.flink.runtime.checkpoint.SavepointType.PostCheckpointAction
- NONE - org.apache.flink.runtime.io.network.buffer.Buffer.DataType
-
Buffer.DataType.NONEindicates that there is no buffer. - NONE - org.apache.flink.runtime.jobmanager.HighAvailabilityMode
- NONE - org.apache.flink.runtime.operators.DriverStrategy
- NONE - org.apache.flink.runtime.operators.shipping.ShipStrategyType
-
Constant used as an indicator for an unassigned ship strategy.
- NONE - org.apache.flink.runtime.operators.util.LocalStrategy
- NONE_AVAILABLE - Static variable in class org.apache.flink.streaming.api.operators.InputSelection
- NonKeyedPartitionWindowedStream<T> - Class in org.apache.flink.streaming.api.datastream
-
NonKeyedPartitionWindowedStreamrepresents a data stream that collects all records of each subtask separately into a full window. - NonKeyedPartitionWindowedStream(StreamExecutionEnvironment, DataStream<T>) - Constructor for class org.apache.flink.streaming.api.datastream.NonKeyedPartitionWindowedStream
- NonLeaderRetrievalRestfulGateway - Class in org.apache.flink.runtime.webmonitor
-
* Gateway for restful endpoints without leader retrieval logic. * *
- NonOffloaded() - Constructor for class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.NonOffloaded
- NonOffloaded(SerializedValue<T>) - Constructor for class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.NonOffloaded
- nonParallel - Variable in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Indicate this is a non-parallel operator and cannot set a non-1 degree of parallelism
- NonPersistentMetadataCheckpointStorageLocation - Class in org.apache.flink.runtime.state.memory
-
A checkpoint storage location for the
MemCheckpointStreamFactoryin case no durable persistence for metadata has been configured. - NonPersistentMetadataCheckpointStorageLocation(int) - Constructor for class org.apache.flink.runtime.state.memory.NonPersistentMetadataCheckpointStorageLocation
- NonRecordWriter<T extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.writer
-
The specific delegate implementation for the non output case like sink task.
- NonRecordWriter() - Constructor for class org.apache.flink.runtime.io.network.api.writer.NonRecordWriter
- NonRecoverableError - org.apache.flink.runtime.throwable.ThrowableType
-
This indicates error that would not succeed even with retry, such as DivideZeroException.
- NonReusingBlockResettableIterator<T> - Class in org.apache.flink.runtime.operators.resettable
-
Implementation of an iterator that fetches a block of data into main memory and offers resettable access to the data in that block.
- NonReusingBlockResettableIterator(MemoryManager, Iterator<T>, TypeSerializer<T>, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
- NonReusingBlockResettableIterator(MemoryManager, TypeSerializer<T>, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
- NonReusingBuildFirstHashJoinIterator<V1,V2,O> - Class in org.apache.flink.runtime.operators.hash
-
An implementation of the
JoinTaskIteratorthat uses a hybrid-hash-join internally to match the records with equal key. - NonReusingBuildFirstHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V2, V1>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
- NonReusingBuildFirstReOpenableHashJoinIterator<V1,V2,O> - Class in org.apache.flink.runtime.operators.hash
- NonReusingBuildFirstReOpenableHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V2, V1>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstReOpenableHashJoinIterator
- NonReusingBuildSecondHashJoinIterator<V1,V2,O> - Class in org.apache.flink.runtime.operators.hash
-
An implementation of the
JoinTaskIteratorthat uses a hybrid-hash-join internally to match the records with equal key. - NonReusingBuildSecondHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V1, V2>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
- NonReusingBuildSecondReOpenableHashJoinIterator<V1,V2,O> - Class in org.apache.flink.runtime.operators.hash
- NonReusingBuildSecondReOpenableHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V1, V2>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondReOpenableHashJoinIterator
- NonReusingDeserializationDelegate<T> - Class in org.apache.flink.runtime.plugable
-
A
DeserializationDelegatethat always creates a new instance upon deserialization. - NonReusingDeserializationDelegate(TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.plugable.NonReusingDeserializationDelegate
- NonReusingKeyGroupedIterator<E> - Class in org.apache.flink.runtime.util
-
The key grouped iterator returns a key and all values that share the same key.
- NonReusingKeyGroupedIterator(MutableObjectIterator<E>, TypeComparator<E>) - Constructor for class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator
-
Initializes the KeyGroupedIterator.
- NonReusingKeyGroupedIterator.ValuesIterator - Class in org.apache.flink.runtime.util
- NonReusingMergeInnerJoinIterator<T1,T2,O> - Class in org.apache.flink.runtime.operators.sort
- NonReusingMergeInnerJoinIterator(MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.NonReusingMergeInnerJoinIterator
- NonReusingMergeOuterJoinIterator<T1,T2,O> - Class in org.apache.flink.runtime.operators.sort
- NonReusingMergeOuterJoinIterator(OuterJoinOperatorBase.OuterJoinType, MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.NonReusingMergeOuterJoinIterator
- NonReusingMutableToRegularIteratorWrapper<T> - Class in org.apache.flink.runtime.util
-
This class wraps a
MutableObjectIteratorinto a regularIterator. - NonReusingMutableToRegularIteratorWrapper(MutableObjectIterator<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.util.NonReusingMutableToRegularIteratorWrapper
- NonReusingSortMergeCoGroupIterator<T1,T2> - Class in org.apache.flink.runtime.operators.sort
- NonReusingSortMergeCoGroupIterator(MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>) - Constructor for class org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
- NonSupportedResourceAllocatorImpl - Class in org.apache.flink.runtime.resourcemanager.slotmanager
-
ResourceAllocator that not support to allocate/release resources.
- noOp() - Static method in interface org.apache.flink.runtime.heartbeat.HeartbeatServices
- NOOP_DISCARD_OBJECT - Static variable in interface org.apache.flink.runtime.checkpoint.Checkpoint
- NoOpBlocklistHandler - Class in org.apache.flink.runtime.blocklist
-
No-op implementation of
BlocklistHandler. - NoOpBlocklistHandler() - Constructor for class org.apache.flink.runtime.blocklist.NoOpBlocklistHandler
- NoOpBlocklistHandler.Factory - Class in org.apache.flink.runtime.blocklist
-
The factory to instantiate
NoOpBlocklistHandler. - NoOpChainedDriver<IT> - Class in org.apache.flink.runtime.operators
-
A chained driver that just passes on the input as the output
- NoOpChainedDriver() - Constructor for class org.apache.flink.runtime.operators.NoOpChainedDriver
- NoOpChannelStateWriter() - Constructor for class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter.NoOpChannelStateWriter
- NoOpCheckpointStatsTracker - Enum in org.apache.flink.runtime.checkpoint
- NoOpDeclareResourceRequirementServiceConnectionManager - Enum in org.apache.flink.runtime.jobmaster.slotpool
-
No-op implementation of the
DeclareResourceRequirementServiceConnectionManager. - NoOpDelegationTokenManager - Class in org.apache.flink.runtime.security.token
-
DelegationTokenManagerimplementation which does nothing. - NoOpDelegationTokenManager() - Constructor for class org.apache.flink.runtime.security.token.NoOpDelegationTokenManager
- NoOpDispatcherBootstrap - Class in org.apache.flink.runtime.dispatcher
-
A
DispatcherBootstrapwhich submits the providedjob graphsfor execution upon dispatcher initialization. - NoOpDispatcherBootstrap() - Constructor for class org.apache.flink.runtime.dispatcher.NoOpDispatcherBootstrap
- NoOpDriver<T> - Class in org.apache.flink.runtime.operators
-
A driver that does nothing but forward data from its input to its output.
- NoOpDriver() - Constructor for class org.apache.flink.runtime.operators.NoOpDriver
- NoOpExecutionDeploymentListener - Enum in org.apache.flink.runtime.executiongraph
-
No-op implementation of
ExecutionDeploymentListener. - NoOpHeartbeatManager<I,O> - Class in org.apache.flink.runtime.heartbeat
-
HeartbeatManagerimplementation which does nothing. - NoOpHeartbeatServices - Class in org.apache.flink.runtime.heartbeat
-
HeartbeatServicesimplementation which does nothing. - NoOpJobGraphStoreWatcher - Enum in org.apache.flink.runtime.jobmanager
-
Singleton
JobGraphStoreWatcherempty implementation. - NoOpMasterAgent - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier
-
The empty implementation for
TierMasterAgent. - NoOpMasterAgent() - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.NoOpMasterAgent
- NoOpMetricRegistry - Class in org.apache.flink.runtime.metrics
-
Metric registry which does nothing.
- NoOpMetricRegistry() - Constructor for class org.apache.flink.runtime.metrics.NoOpMetricRegistry
- NoOpResultSubpartitionView - Class in org.apache.flink.runtime.io.network.partition
-
A dummy implementation of the
ResultSubpartitionView. - NoOpResultSubpartitionView() - Constructor for class org.apache.flink.runtime.io.network.partition.NoOpResultSubpartitionView
- NoOpSecurityContext - Class in org.apache.flink.runtime.security.contexts
-
A security context that simply runs a Callable without performing a login action.
- NoOpSecurityContext() - Constructor for class org.apache.flink.runtime.security.contexts.NoOpSecurityContext
- NoOpSecurityContextFactory - Class in org.apache.flink.runtime.security.contexts
-
Default security context factory for
NoOpSecurityContext. - NoOpSecurityContextFactory() - Constructor for class org.apache.flink.runtime.security.contexts.NoOpSecurityContextFactory
- NoOpSlotAllocationSnapshotPersistenceService - Enum in org.apache.flink.runtime.taskexecutor.slot
-
SlotAllocationSnapshotPersistenceServicethat does nothing. - NoOpStreamOperator() - Constructor for class org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator.NoOpStreamOperator
- NoOpTaskActions - Class in org.apache.flink.runtime.taskmanager
-
A dummy implementation of the
TaskActionswhich is mainly used for tests. - NoOpTaskActions() - Constructor for class org.apache.flink.runtime.taskmanager.NoOpTaskActions
- NoOpTaskLocalStateStoreImpl - Class in org.apache.flink.runtime.state
-
This class implements a
TaskLocalStateStorewith no functionality and is used when local recovery is disabled. - NoOpTierShuffleDescriptor - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier
-
The empty implementation for
TierShuffleDescriptor. - NoOpTimestampsAndWatermarks<T> - Class in org.apache.flink.streaming.api.operators.source
-
An implementation of
TimestampsAndWatermarkswhere all watermarking/event-time operations are no-ops. - NoOpTimestampsAndWatermarks(TimestampAssigner<T>) - Constructor for class org.apache.flink.streaming.api.operators.source.NoOpTimestampsAndWatermarks
-
Creates a new
NoOpTimestampsAndWatermarkswith the given TimestampAssigner. - noOutput() - Static method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
-
Returns the type information for a
CommittableMessagewith no committable. - NoResourceAvailableException - Exception in org.apache.flink.runtime.jobmanager.scheduler
-
Indicates resource allocation failures.
- NoResourceAvailableException() - Constructor for exception org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
- NoResourceAvailableException(String) - Constructor for exception org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
- NoResourceAvailableException(String, Throwable) - Constructor for exception org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
- NoRestartBackoffTimeStrategy - Enum in org.apache.flink.runtime.executiongraph.failover
-
Restart strategy which does not restart tasks when tasks fail.
- NoRestartBackoffTimeStrategy.NoRestartBackoffTimeStrategyFactory - Enum in org.apache.flink.runtime.executiongraph.failover
-
The factory for creating
NoRestartBackoffTimeStrategy. - NORMAL - org.apache.flink.runtime.entrypoint.ClusterEntrypoint.ExecutionMode
-
Waits until the job result has been served.
- NormalizedKeySorter<T> - Class in org.apache.flink.runtime.operators.sort
- NormalizedKeySorter(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
- NormalizedKeySorter(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
- NOT_ALL_REQUIRED_TASKS_RUNNING - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- NOT_CONTAINED - Static variable in interface org.apache.flink.runtime.state.heap.HeapPriorityQueueElement
-
The index that indicates that a
HeapPriorityQueueElementobject is not contained in and managed by anyHeapPriorityQueue. - NOT_END_OF_DATA - org.apache.flink.runtime.io.PullingAsyncDataInput.EndOfDataStatus
- NotDuplicatingCheckpointStateToolset - Class in org.apache.flink.runtime.state
-
An empty implementation of
CheckpointStateToolset. - NotDuplicatingCheckpointStateToolset() - Constructor for class org.apache.flink.runtime.state.NotDuplicatingCheckpointStateToolset
- notEnoughResourceAvailable(JobID, Collection<ResourceRequirement>) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ResourceEventListener
- notExactlyOnce(SnapshotType, CheckpointStorageLocationReference) - Static method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
- NotExistException(String) - Constructor for exception org.apache.flink.runtime.persistence.StateHandleStore.NotExistException
-
Creates a new Exception with the given message and null cause.
- NotExistException(String, Throwable) - Constructor for exception org.apache.flink.runtime.persistence.StateHandleStore.NotExistException
-
Creates a new Exception with the given message and cause.
- notExisting() - Static method in class org.apache.flink.runtime.persistence.IntegerResourceVersion
- notExisting() - Static method in class org.apache.flink.runtime.persistence.StringResourceVersion
- notFound() - Method in class org.apache.flink.runtime.rest.handler.router.Router
-
Returns the fallback target for use when there's no match at
Router.route(HttpMethod, String). - notFound(T) - Method in class org.apache.flink.runtime.rest.handler.router.Router
-
Sets the fallback target for use when there's no match at
Router.route(HttpMethod, String). - NotFoundException - Exception in org.apache.flink.runtime.rest
-
A special exception that indicates that an element was not found and that the request should be answered with a
404return code. - NotFoundException(String) - Constructor for exception org.apache.flink.runtime.rest.NotFoundException
- NotFoundException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rest.NotFoundException
- NOTHING - org.apache.flink.runtime.minicluster.MiniClusterJobClient.JobFinalizationBehavior
-
Don't do anything when the job finishes.
- NOTHING_AVAILABLE - org.apache.flink.streaming.runtime.io.DataInputStatus
-
Indicator that no data is currently available, but more data will be available in the future again.
- NotificationListener - Interface in org.apache.flink.runtime.util.event
- notifyAbort(long, CheckpointException) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
- notifyAbortOnCancellationBarrier(long) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
- notifyAcquiredResource(JobID, ResourceProfile) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.DefaultResourceTracker
- notifyAcquiredResource(JobID, ResourceProfile) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ResourceTracker
-
Notifies the tracker about the acquisition of a resource with the given resource profile, for the given job.
- notifyAllocation(AllocationID, FineGrainedTaskManagerSlot) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerRegistration
- notifyAllocationComplete(AllocationID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerRegistration
- notifyAvailable() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyConnectionWriter
-
Notify the buffer is available in writer.
- notifyAvailable() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyConnectionWriterImpl
- notifyAvailable(TieredStoragePartitionId, TieredStorageInputChannelId) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.AvailabilityNotifier
-
Notify that the data for the specific partition and input channel is available in tiered storage.
- notifyAvailable(TieredStoragePartitionId, TieredStorageSubpartitionId) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierConsumerAgent
- notifyBufferAvailable(int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
- notifyBufferAvailable(int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
The unannounced credit is increased by the given amount and might notify increased credit to the producer.
- notifyBufferAvailable(Buffer) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferListener
-
Notification callback if a buffer is recycled and becomes available in buffer pool.
- notifyBufferAvailable(Buffer) - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferManager
-
The buffer pool notifies this listener of an available floating buffer.
- notifyBufferDestroyed() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferListener
-
Notification callback if the buffer provider is destroyed.
- notifyBufferDestroyed() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferManager
- notifyChannelNonEmpty() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Notifies the owning
SingleInputGatethat this channel became non-empty. - notifyCheckpoint(CheckpointBarrier) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
- notifyCheckpointAbortAsync(long, long) - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
- notifyCheckpointAbortAsync(long, long) - Method in interface org.apache.flink.runtime.jobgraph.tasks.CheckpointableTask
-
Invoked when a checkpoint has been aborted, i.e., when the checkpoint coordinator has received a decline message from one task and try to abort the targeted checkpoint by notification.
- notifyCheckpointAbortAsync(long, long) - Method in class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask
- notifyCheckpointAbortAsync(long, long) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- notifyCheckpointAborted(long) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateUdfStreamOperator
- notifyCheckpointAborted(long) - Method in interface org.apache.flink.runtime.checkpoint.OperatorCoordinatorCheckpointContext
-
We override the method here to remove the checked exception.
- notifyCheckpointAborted(long) - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator
-
We override the method here to remove the checked exception.
- notifyCheckpointAborted(long) - Method in class org.apache.flink.runtime.operators.coordination.OperatorCoordinatorHolder
- notifyCheckpointAborted(long) - Method in class org.apache.flink.runtime.operators.coordination.RecreateOnResetOperatorCoordinator
- notifyCheckpointAborted(long) - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinator
- notifyCheckpointAborted(long) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
- notifyCheckpointAborted(long) - Method in class org.apache.flink.runtime.state.TaskStateManagerImpl
-
Tracking when some local state can be disposed.
- notifyCheckpointAborted(long) - Method in class org.apache.flink.runtime.state.v2.adaptor.AsyncKeyedStateBackendAdaptor
- notifyCheckpointAborted(long) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- notifyCheckpointAborted(long) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- notifyCheckpointAborted(long) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
- notifyCheckpointAborted(long) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
- notifyCheckpointAborted(long) - Method in class org.apache.flink.streaming.api.operators.SourceOperator
- notifyCheckpointAborted(long) - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
- notifyCheckpointAborted(long) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
- notifyCheckpointAborted(long) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- notifyCheckpointAborted(long) - Method in class org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
- notifyCheckpointAborted(long, long) - Method in class org.apache.flink.runtime.taskmanager.Task
- notifyCheckpointAborted(long, long, long) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Notify the task of this execution about a aborted checkpoint.
- notifyCheckpointAborted(long, OperatorChain<?, ?>, Supplier<Boolean>) - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
-
Notified on the task side once a distributed checkpoint has been aborted.
- notifyCheckpointAborted(FileMergingSnapshotManager.SubtaskKey, long) - Method in interface org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager
-
This method is called as a notification once a distributed checkpoint has been aborted.
- notifyCheckpointAborted(FileMergingSnapshotManager.SubtaskKey, long) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
- notifyCheckpointAborted(FileMergingSnapshotManager.SubtaskKey, long) - Method in class org.apache.flink.runtime.checkpoint.filemerging.WithinCheckpointFileMergingSnapshotManager
- notifyCheckpointAborted(ExecutionAttemptID, JobID, long, long, long) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Notify the given task about a aborted checkpoint.
- notifyCheckpointAborted(ExecutionAttemptID, JobID, long, long, long) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
- notifyCheckpointComplete(long) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateUdfStreamOperator
- notifyCheckpointComplete(long) - Method in interface org.apache.flink.runtime.checkpoint.OperatorCoordinatorCheckpointContext
-
We override the method here to remove the checked exception.
- notifyCheckpointComplete(long) - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator
-
We override the method here to remove the checked exception.
- notifyCheckpointComplete(long) - Method in class org.apache.flink.runtime.operators.coordination.OperatorCoordinatorHolder
- notifyCheckpointComplete(long) - Method in class org.apache.flink.runtime.operators.coordination.RecreateOnResetOperatorCoordinator
- notifyCheckpointComplete(long) - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinator
- notifyCheckpointComplete(long) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
- notifyCheckpointComplete(long) - Method in class org.apache.flink.runtime.state.TaskStateManagerImpl
-
Tracking when local state can be confirmed and disposed.
- notifyCheckpointComplete(long) - Method in class org.apache.flink.runtime.state.v2.adaptor.AsyncKeyedStateBackendAdaptor
- notifyCheckpointComplete(long) - Method in class org.apache.flink.runtime.taskmanager.Task
- notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
- notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
- notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
- notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.api.operators.SourceOperator
- notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
- notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
- notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
- notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper
- notifyCheckpointComplete(long, OperatorChain<?, ?>, Supplier<Boolean>) - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
-
Notified on the task side once a distributed checkpoint has been completed.
- notifyCheckpointComplete(FileMergingSnapshotManager.SubtaskKey, long) - Method in interface org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager
-
Notifies the manager that the checkpoint with the given
checkpointIdcompleted and was committed. - notifyCheckpointComplete(FileMergingSnapshotManager.SubtaskKey, long) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
- notifyCheckpointComplete(FileMergingSnapshotManager.SubtaskKey, long) - Method in class org.apache.flink.runtime.checkpoint.filemerging.WithinCheckpointFileMergingSnapshotManager
- notifyCheckpointCompleteAsync(long) - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
- notifyCheckpointCompleteAsync(long) - Method in interface org.apache.flink.runtime.jobgraph.tasks.CheckpointableTask
-
Invoked when a checkpoint has been completed, i.e., when the checkpoint coordinator has received the notification from all participating tasks.
- notifyCheckpointCompleteAsync(long) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- notifyCheckpointOnComplete(long, long, long) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Notify the task of this execution about a completed checkpoint and the last subsumed checkpoint id if possible.
- notifyCheckpointOnComplete(ExecutionAttemptID, JobID, long, long, long) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Notify the given task about a completed checkpoint and the last subsumed checkpoint id if possible.
- notifyCheckpointOnComplete(ExecutionAttemptID, JobID, long, long, long) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
- notifyCheckpointStart(FileMergingSnapshotManager.SubtaskKey, long) - Method in interface org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager
-
Notifies the manager that the checkpoint with the given
checkpointIdhas been started. - notifyCheckpointStart(FileMergingSnapshotManager.SubtaskKey, long) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
-
SubtaskCheckpointCoordinatorImpluse this method let the file merging manager know an ongoing checkpoint may reference the managed dirs. - notifyCheckpointSubsumed(long) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- notifyCheckpointSubsumed(long) - Method in class org.apache.flink.runtime.state.v2.adaptor.AsyncKeyedStateBackendAdaptor
- notifyCheckpointSubsumed(long) - Method in class org.apache.flink.runtime.taskmanager.Task
- notifyCheckpointSubsumed(long) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
- notifyCheckpointSubsumed(long) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- notifyCheckpointSubsumed(long) - Method in class org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
- notifyCheckpointSubsumed(long) - Method in class org.apache.flink.streaming.runtime.tasks.StreamOperatorWrapper
- notifyCheckpointSubsumed(long, OperatorChain<?, ?>, Supplier<Boolean>) - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
-
Notified on the task side once a distributed checkpoint has been subsumed.
- notifyCheckpointSubsumed(FileMergingSnapshotManager.SubtaskKey, long) - Method in interface org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager
-
This method is called as a notification once a distributed checkpoint has been subsumed.
- notifyCheckpointSubsumed(FileMergingSnapshotManager.SubtaskKey, long) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
- notifyCheckpointSubsumedAsync(long) - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
- notifyCheckpointSubsumedAsync(long) - Method in interface org.apache.flink.runtime.jobgraph.tasks.CheckpointableTask
-
Invoked when a checkpoint has been subsumed, i.e., when the checkpoint coordinator has confirmed one checkpoint has been finished, and try to remove the first previous checkpoint.
- notifyCheckpointSubsumedAsync(long) - Method in class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask
- notifyCheckpointSubsumedAsync(long) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- notifyCoordinatorsAboutTaskFailure(Execution, Throwable) - Method in class org.apache.flink.runtime.scheduler.DefaultScheduler
- notifyCreditAvailable(RemoteInputChannel) - Method in class org.apache.flink.runtime.io.network.netty.NettyPartitionRequestClient
- notifyCreditAvailable(RemoteInputChannel) - Method in interface org.apache.flink.runtime.io.network.PartitionRequestClient
-
Notifies available credits from one remote input channel.
- notifyDataAvailable() - Method in class org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionDirectTransferReader
- notifyDataAvailable() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.TieredStorageResultSubpartitionView
- notifyDataAvailable() - Method in class org.apache.flink.runtime.io.network.partition.NoOpResultSubpartitionView
- notifyDataAvailable() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartitionView
- notifyDataAvailable() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
- notifyDataAvailable() - Method in class org.apache.flink.runtime.io.network.partition.UnionResultSubpartitionView
- notifyDataAvailable(ResultSubpartitionView) - Method in interface org.apache.flink.runtime.io.network.partition.BufferAvailabilityListener
-
Called whenever there might be new data available.
- notifyDataAvailable(ResultSubpartitionView) - Method in class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
- notifyDataAvailable(ResultSubpartitionView) - Method in class org.apache.flink.runtime.io.network.partition.UnionResultSubpartitionView
- notifyDataAvailable(T) - Method in class org.apache.flink.runtime.io.network.partition.RoundRobinSubpartitionSelector
- notifyDataAvailable(T) - Method in interface org.apache.flink.runtime.io.network.partition.SubpartitionSelector
-
Marks a subpartition as having data available.
- notifyEndOfData() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- notifyEndOfData(ExecutionAttemptID) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- notifyEndOfData(ExecutionAttemptID) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Notifies that the task has reached the end of data.
- notifyEndOfData(ExecutionAttemptID) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- notifyEndOfData(ExecutionAttemptID) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- notifyEndOfData(ExecutionAttemptID) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
-
Notifies that the task has reached the end of data.
- notifyEndOfData(ExecutionAttemptID) - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerActions
-
Notifies that the task has reached the end of data.
- notifyEndOfData(StopMode) - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
Notifies the downstream tasks that this
ResultPartitionWriterhave emitted all the user records. - notifyEndOfData(StopMode) - Method in class org.apache.flink.runtime.io.network.partition.BoundedBlockingResultPartition
- notifyEndOfData(StopMode) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartition
- notifyEndOfData(StopMode) - Method in class org.apache.flink.runtime.io.network.partition.PipelinedResultPartition
- notifyEndOfData(StopMode) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- notifyEndOfData(StopMode) - Method in class org.apache.flink.runtime.io.network.partition.SortMergeResultPartition
- notifyExecutionChange(Execution, ExecutionState, ExecutionState) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- notifyExecutionChange(Execution, ExecutionState, ExecutionState) - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
- notifyExecutionGraphUpdated(DefaultExecutionGraph, List<ExecutionJobVertex>) - Method in class org.apache.flink.runtime.scheduler.adapter.DefaultExecutionTopology
- notifyFailure(Throwable) - Method in class org.apache.flink.runtime.executiongraph.failover.ExponentialDelayRestartBackoffTimeStrategy
- notifyFailure(Throwable) - Method in class org.apache.flink.runtime.executiongraph.failover.FailureRateRestartBackoffTimeStrategy
- notifyFailure(Throwable) - Method in class org.apache.flink.runtime.executiongraph.failover.FixedDelayRestartBackoffTimeStrategy
- notifyFailure(Throwable) - Method in enum org.apache.flink.runtime.executiongraph.failover.NoRestartBackoffTimeStrategy
- notifyFailure(Throwable) - Method in interface org.apache.flink.runtime.executiongraph.failover.RestartBackoffTimeStrategy
-
Notify the strategy about the task failure cause.
- notifyFatalError(String, Throwable) - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerActions
-
Notifies the task manager about a fatal error occurred in the task.
- notifyGlobalFailure(Throwable) - Method in interface org.apache.flink.runtime.scheduler.InternalFailuresListener
- notifyGlobalFailure(Throwable) - Method in class org.apache.flink.runtime.scheduler.UpdateSchedulerNgOnInternalFailuresListener
- notifyHeartbeatTimeout(ResourceID) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatListener
-
Callback which is called if a heartbeat for the machine identified by the given resource ID times out.
- notifyJobTimeout(JobID, UUID) - Method in interface org.apache.flink.runtime.resourcemanager.JobLeaderIdActions
-
Notify a job timeout.
- notifyKvStateRegistered(JobID, JobVertexID, KeyGroupRange, String, KvStateID) - Method in interface org.apache.flink.runtime.query.KvStateRegistryListener
-
Notifies the listener about a registered KvState instance.
- notifyKvStateRegistered(JobID, JobVertexID, KeyGroupRange, String, KvStateID) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcKvStateRegistryListener
- notifyKvStateRegistered(JobID, JobVertexID, KeyGroupRange, String, KvStateID, InetSocketAddress) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- notifyKvStateRegistered(JobID, JobVertexID, KeyGroupRange, String, KvStateID, InetSocketAddress) - Method in interface org.apache.flink.runtime.jobmaster.KvStateRegistryGateway
-
Notifies that queryable state has been registered.
- notifyKvStateRegistered(JobID, JobVertexID, KeyGroupRange, String, KvStateID, InetSocketAddress) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- notifyKvStateRegistered(JobID, JobVertexID, KeyGroupRange, String, KvStateID, InetSocketAddress) - Method in class org.apache.flink.runtime.scheduler.KvStateHandler
- notifyKvStateRegistered(JobID, JobVertexID, KeyGroupRange, String, KvStateID, InetSocketAddress) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- notifyKvStateRegistered(JobID, JobVertexID, KeyGroupRange, String, KvStateID, InetSocketAddress) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
- notifyKvStateRegistered(JobVertexID, KeyGroupRange, String, KvStateID, InetSocketAddress) - Method in class org.apache.flink.runtime.query.KvStateLocationRegistry
-
Notifies the registry about a registered KvState instance.
- notifyKvStateUnregistered(JobID, JobVertexID, KeyGroupRange, String) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- notifyKvStateUnregistered(JobID, JobVertexID, KeyGroupRange, String) - Method in interface org.apache.flink.runtime.jobmaster.KvStateRegistryGateway
-
Notifies that queryable state has been unregistered.
- notifyKvStateUnregistered(JobID, JobVertexID, KeyGroupRange, String) - Method in interface org.apache.flink.runtime.query.KvStateRegistryListener
-
Notifies the listener about an unregistered KvState instance.
- notifyKvStateUnregistered(JobID, JobVertexID, KeyGroupRange, String) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- notifyKvStateUnregistered(JobID, JobVertexID, KeyGroupRange, String) - Method in class org.apache.flink.runtime.scheduler.KvStateHandler
- notifyKvStateUnregistered(JobID, JobVertexID, KeyGroupRange, String) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- notifyKvStateUnregistered(JobID, JobVertexID, KeyGroupRange, String) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
- notifyKvStateUnregistered(JobID, JobVertexID, KeyGroupRange, String) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcKvStateRegistryListener
- notifyKvStateUnregistered(JobVertexID, KeyGroupRange, String) - Method in class org.apache.flink.runtime.query.KvStateLocationRegistry
-
Notifies the registry about an unregistered KvState instance.
- notifyLeaderAddress(String, UUID) - Method in interface org.apache.flink.runtime.leaderretrieval.LeaderRetrievalListener
-
This method is called by the
LeaderRetrievalServicewhen a new leader is elected. - notifyLeaderAddress(String, UUID) - Method in class org.apache.flink.runtime.net.ConnectionUtils.LeaderConnectingAddressListener
- notifyLeaderAddress(String, UUID) - Method in class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderInformationListener
- notifyLeaderAddress(String, UUID) - Method in class org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
- notifyLeaderAddress(LeaderInformation) - Method in class org.apache.flink.runtime.leaderretrieval.DefaultLeaderRetrievalService
-
Called by specific
LeaderRetrievalDriverto notify leader address. - notifyLeaderAddress(LeaderInformation) - Method in interface org.apache.flink.runtime.leaderretrieval.LeaderRetrievalEventHandler
-
Called by specific
LeaderRetrievalDriverto notify leader address. - notifyLostResource(JobID, ResourceProfile) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.DefaultResourceTracker
- notifyLostResource(JobID, ResourceProfile) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ResourceTracker
-
Notifies the tracker about the loss of a resource with the given resource profile, for the given job.
- notifyNewBlockedNodes(Collection<BlockedNode>) - Method in interface org.apache.flink.runtime.blocklist.BlocklistListener
-
Notify new blocked node records.
- notifyNewBlockedNodes(Collection<BlockedNode>) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- notifyNewBlockedNodes(Collection<BlockedNode>) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- notifyNewBufferSize(int) - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
- notifyNewBufferSize(int) - Method in class org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionDirectTransferReader
- notifyNewBufferSize(int) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.TieredStorageResultSubpartitionView
- notifyNewBufferSize(int) - Method in class org.apache.flink.runtime.io.network.partition.NoOpResultSubpartitionView
- notifyNewBufferSize(int) - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartitionView
- notifyNewBufferSize(int) - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
- notifyNewBufferSize(int) - Method in class org.apache.flink.runtime.io.network.partition.UnionResultSubpartitionView
- notifyNewBufferSize(RemoteInputChannel, int) - Method in class org.apache.flink.runtime.io.network.netty.NettyPartitionRequestClient
- notifyNewBufferSize(RemoteInputChannel, int) - Method in interface org.apache.flink.runtime.io.network.PartitionRequestClient
-
Notifies new buffer size from one remote input channel.
- notifyNewLeaderAddress(CompletableFuture<Tuple2<String, UUID>>) - Method in class org.apache.flink.runtime.webmonitor.retriever.LeaderGatewayRetriever
- notifyNewLeaderAddress(CompletableFuture<Tuple2<String, UUID>>) - Method in class org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
- notifyNewlyInitializedJobVertices(List<ExecutionJobVertex>) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- notifyNewlyInitializedJobVertices(List<ExecutionJobVertex>) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Notify that some job vertices have been newly initialized, execution graph will try to update scheduling topology.
- notifyNewSlotsAreAvailable(Collection<? extends PhysicalSlot>) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPool.NewSlotsListener
-
Notifies the listener about newly available slots.
- notifyNewSlotsAreAvailable(Collection<? extends PhysicalSlot>) - Method in enum org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPool.NoOpNewSlotsListener
- notifyNotEnoughResourcesAvailable(Collection<ResourceRequirement>) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- notifyNotEnoughResourcesAvailable(Collection<ResourceRequirement>) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Notifies that not enough resources are available to fulfill the resource requirements of a job.
- notifyNotEnoughResourcesAvailable(Collection<ResourceRequirement>) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolBridge
- notifyNotEnoughResourcesAvailable(Collection<ResourceRequirement>) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolService
-
Notifies that not enough resources are available to fulfill the resource requirements.
- notifyOfAddedView(View) - Method in class org.apache.flink.runtime.metrics.ViewUpdater
-
Notifies this ViewUpdater of a new metric that should be regularly updated.
- notifyOfEndOfSuperstep() - Method in class org.apache.flink.runtime.iterative.concurrent.BlockingBackChannel
-
Called by iteration tail to signal that all input of a superstep has been processed (unblocks iteration head).
- notifyOfRemovedView(View) - Method in class org.apache.flink.runtime.metrics.ViewUpdater
-
Notifies this ViewUpdater of a metric that should no longer be regularly updated.
- notifyPartitionCreated(ResultPartition) - Method in class org.apache.flink.runtime.io.network.netty.NettyPartitionRequestListener
- notifyPartitionCreated(ResultPartition) - Method in interface org.apache.flink.runtime.io.network.partition.PartitionRequestListener
-
Notify the partition request listener when the given partition is registered.
- notifyPartitionCreatedTimeout() - Method in class org.apache.flink.runtime.io.network.netty.NettyPartitionRequestListener
- notifyPartitionCreatedTimeout() - Method in interface org.apache.flink.runtime.io.network.partition.PartitionRequestListener
-
When the partition request listener is timeout, it will be notified to send
PartitionNotFoundException. - notifyPartitionRecoveryStarted() - Method in interface org.apache.flink.runtime.shuffle.JobShuffleContext
-
Notifies that the recovery process of result partitions has started.
- notifyPartitionRecoveryStarted() - Method in class org.apache.flink.runtime.shuffle.JobShuffleContextImpl
- notifyPartitionRecoveryStarted(JobID) - Method in class org.apache.flink.runtime.shuffle.NettyShuffleMaster
- notifyPartitionRecoveryStarted(JobID) - Method in interface org.apache.flink.runtime.shuffle.ShuffleMaster
-
Notifies that the recovery process of result partitions has started.
- notifyPartitionRequestTimeout(PartitionRequestListener) - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
When the partition request from the given downstream task is timeout, it should notify the reader in netty server and send
PartitionNotFoundExceptionto the task. - notifyPriorityEvent(int) - Method in interface org.apache.flink.runtime.io.network.partition.BufferAvailabilityListener
-
Called when the first priority event is added to the head of the buffer queue.
- notifyPriorityEvent(int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
- notifyPriorityEvent(int) - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartitionView
- notifyPriorityEvent(int) - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
- notifyPriorityEvent(int) - Method in class org.apache.flink.runtime.io.network.partition.UnionResultSubpartitionView
- notifyReadyAsync(Callable<T>, BiConsumer<T, Throwable>) - Method in class org.apache.flink.runtime.source.coordinator.ExecutorNotifier
-
Call the given callable once.
- notifyReadyAsync(Callable<T>, BiConsumer<T, Throwable>, long, long) - Method in class org.apache.flink.runtime.source.coordinator.ExecutorNotifier
-
Call the given callable once.
- notifyRequiredSegmentId(int, int) - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
Notify the id of required segment from consumer.
- notifyRequiredSegmentId(int, int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Notify the upstream the id of required segment that should be sent to netty connection.
- notifyRequiredSegmentId(int, int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
- notifyRequiredSegmentId(int, int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- notifyRequiredSegmentId(int, int) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.TieredStorageResultSubpartitionView
- notifyRequiredSegmentId(int, int) - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
-
In tiered storage shuffle mode, only required segments will be sent to prevent the redundant buffer usage.
- notifyRequiredSegmentId(int, int) - Method in class org.apache.flink.runtime.io.network.partition.UnionResultSubpartitionView
- notifyRequiredSegmentId(RemoteInputChannel, int, int) - Method in class org.apache.flink.runtime.io.network.netty.NettyPartitionRequestClient
- notifyRequiredSegmentId(RemoteInputChannel, int, int) - Method in interface org.apache.flink.runtime.io.network.PartitionRequestClient
-
Notifies the id of segment required from one remote input channel.
- notifyResourceRequirements(JobID, Collection<ResourceRequirement>) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.DefaultResourceTracker
- notifyResourceRequirements(JobID, Collection<ResourceRequirement>) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ResourceTracker
-
Notifies the tracker about a new or updated
ResourceRequirements. - notifySchedulerNgAboutInternalTaskFailure(ExecutionAttemptID, Throwable, boolean, boolean) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- notifySchedulerNgAboutInternalTaskFailure(ExecutionAttemptID, Throwable, boolean, boolean) - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
- notifySchedulingTopologyUpdated(SchedulingTopology, List<ExecutionVertexID>) - Method in class org.apache.flink.runtime.executiongraph.failover.partitionrelease.RegionPartitionGroupReleaseStrategy
- notifySchedulingTopologyUpdated(SchedulingTopology, List<ExecutionVertexID>) - Method in interface org.apache.flink.runtime.scheduler.SchedulingTopologyListener
-
Notifies that the scheduling topology is just updated.
- notifySchedulingTopologyUpdated(SchedulingTopology, List<ExecutionVertexID>) - Method in class org.apache.flink.runtime.scheduler.strategy.VertexwiseSchedulingStrategy
- notifySlotAvailable(InstanceID, SlotID, AllocationID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- notifySlotAvailable(InstanceID, SlotID, AllocationID) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Sent by the TaskExecutor to notify the ResourceManager that a slot has become available.
- notifySlotStatus(AllocationID, JobID, InstanceID, ResourceProfile, SlotState) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- notifySlowTasks(Map<ExecutionVertexID, Collection<ExecutionAttemptID>>) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DefaultSpeculativeExecutionHandler
- notifySlowTasks(Map<ExecutionVertexID, Collection<ExecutionAttemptID>>) - Method in interface org.apache.flink.runtime.scheduler.slowtaskdetector.SlowTaskDetectorListener
-
Notify detected slow tasks.
- notifySolutionSetUpdate() - Method in class org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrier
-
Releases the waiting thread.
- notifySubpartitionsCreated(ResultPartition, ResultSubpartitionIndexSet) - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
When the
ResultPartitionManagerregistersResultPartition, it will get thePartitionRequestListenervia givenResultPartitionID, and create subpartition view reader for downstream task. - notifyTargetUnreachable(ResourceID) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatListener
-
Callback which is called if a target specified by the given resource ID is no longer reachable.
- notifyTaskFailed(Execution) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DefaultSpeculativeExecutionHandler
- notifyTaskFailed(Execution) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DummySpeculativeExecutionHandler
- notifyTaskFailed(Execution) - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.SpeculativeExecutionHandler
-
Notifies that a task has failed its execution.
- notifyTaskFailure(ExecutionAttemptID, Throwable, boolean, boolean) - Method in interface org.apache.flink.runtime.scheduler.InternalFailuresListener
- notifyTaskFailure(ExecutionAttemptID, Throwable, boolean, boolean) - Method in class org.apache.flink.runtime.scheduler.UpdateSchedulerNgOnInternalFailuresListener
- notifyTaskFinished(Execution, Function<ExecutionVertexID, CompletableFuture<?>>) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DefaultSpeculativeExecutionHandler
- notifyTaskFinished(Execution, Function<ExecutionVertexID, CompletableFuture<?>>) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DummySpeculativeExecutionHandler
- notifyTaskFinished(Execution, Function<ExecutionVertexID, CompletableFuture<?>>) - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.SpeculativeExecutionHandler
-
Notifies that a task has finished its execution.
- notifyTimeout(K, UUID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TimeoutListener
-
Notify the listener about the timeout for an event identified by key.
- notifyTimeout(AllocationID, UUID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- notifyViewCreated(int, ResultSubpartitionView) - Method in class org.apache.flink.runtime.io.network.partition.UnionResultSubpartitionView
- notLeader() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionDriver
- noTransform() - Static method in interface org.apache.flink.runtime.state.StateSnapshotTransformer.StateSnapshotTransformFactory
- NotReleasingPartitionGroupReleaseStrategy - Class in org.apache.flink.runtime.executiongraph.failover.partitionrelease
-
Does not release intermediate result partitions during job execution.
- NotReleasingPartitionGroupReleaseStrategy() - Constructor for class org.apache.flink.runtime.executiongraph.failover.partitionrelease.NotReleasingPartitionGroupReleaseStrategy
- NotReleasingPartitionGroupReleaseStrategy.Factory - Class in org.apache.flink.runtime.executiongraph.failover.partitionrelease
-
Factory for
NotReleasingPartitionGroupReleaseStrategy. - NUM_BYTES_PER_REQUEST - Static variable in class org.apache.flink.runtime.io.disk.BatchShuffleReadBufferPool
-
Memory size in bytes can be allocated from this buffer pool for a single request (4M is for better sequential read).
- NUM_BYTES_SEND - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- NUM_BYTES_UNKNOWN - Static variable in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- NUM_CACHED_BYTES - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- NUM_CACHED_RECORDS - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- NUM_EFFECTIVE_SPECULATIVE_EXECUTIONS - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- NUM_FINISHED_PARTITIONS_AS_CONSUMABLE - Static variable in class org.apache.flink.runtime.scheduler.strategy.PartialFinishedInputConsumableDecider
- NUM_FIRED_TIMERS - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- NUM_FIRED_TIMERS_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- NUM_GHOST_SAMPLE_IDS - Static variable in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator
- NUM_LOAD_FAILURES - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- NUM_PENDING_TASK_MANAGERS - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- NUM_RECORDS_IN_ERRORS - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- NUM_RECORDS_OUT_ERRORS - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- NUM_RECORDS_SEND - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- NUM_RECORDS_SEND_ERRORS - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- NUM_REGISTERED_TASK_MANAGERS - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- NUM_RESTARTS - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- NUM_RUNNING_JOBS - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- NUM_SLOW_EXECUTION_VERTICES - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- number - Variable in class org.apache.flink.runtime.state.changelog.SequenceNumber.GenericSequenceNumber
- numberOfChannels - Variable in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
- numberOfKeyGroups - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
The number of key-groups aka max parallelism.
- numberOfKeyGroups - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
- numberOfSubpartitions - Variable in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
- numBuckets - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The number of buckets in the current table.
- numBuffersIn - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
- numBuffersOut - Variable in class org.apache.flink.runtime.io.network.partition.ResultPartition
- numBytesIn - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
- numBytesIn - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
- numBytesOut - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
- numBytesOut - Variable in class org.apache.flink.runtime.io.network.partition.ResultPartition
- numCachedBytesGauge(Gauge<Long>) - Method in class org.apache.flink.runtime.metrics.groups.InternalCacheMetricGroup
- numCachedRecordsGauge(Gauge<Long>) - Method in class org.apache.flink.runtime.metrics.groups.InternalCacheMetricGroup
- numCounters - Variable in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
- numEventTimeTimers() - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
- numEventTimeTimers() - Method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManagerImpl
- numEventTimeTimers(N) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
- numFetchRetries - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
-
The number of retries when the transfer fails.
- numGauges - Variable in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
- numHashFunctions - Variable in class org.apache.flink.runtime.operators.util.BloomFilter
- numHistograms - Variable in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
- numKeyValueStateEntries() - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
Returns the total number of state entries across all keys/namespaces.
- numKeyValueStateEntries() - Method in interface org.apache.flink.runtime.state.TestableKeyedStateBackend
-
Returns the total number of state entries across all keys/namespaces.
- numKeyValueStateEntries(Object) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
Returns the total number of state entries across all keys for the given namespace.
- numKeyValueStatesByName() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- numLateRecordsDropped - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
- numLoadFailuresCounter(Counter) - Method in class org.apache.flink.runtime.metrics.groups.InternalCacheMetricGroup
- numMeters - Variable in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
- numNetworkBuffers() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- numOperators - Variable in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- numOverflowSegments - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
- numOverflowSegments - Variable in class org.apache.flink.runtime.operators.hash.InMemoryPartition
- numOwnerRequestedBuffer(Object) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemoryManager
-
Return the number of requested buffers belonging to a specific owner.
- numOwnerRequestedBuffer(Object) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemoryManagerImpl
- numPartialBuffers() - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- numProcessingTimeTimers() - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
- numProcessingTimeTimers() - Method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManagerImpl
- numProcessingTimeTimers(N) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
- numProxyQueryThreads() - Method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
-
Returns the number of query threads for the queryable state client proxy.
- numProxyServerThreads() - Method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
-
Returns the number of threads for the query proxy NIO event loop.
- numQueuedBufferPayloads() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyConnectionWriter
-
Get the number of written but unsent buffer netty payloads.
- numQueuedBufferPayloads() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyConnectionWriterImpl
- numQueuedPayloads() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyConnectionWriter
-
Get the number of written but unsent netty payloads.
- numQueuedPayloads() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyConnectionWriterImpl
- numRecordsIn - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
- numRecordsIn - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
- numRecordsOut - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
- numRecordsOut - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
- numRegisteredJobMetricGroups() - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
- numRegisteredJobMetricGroups() - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
- numRequestsRemaining - Variable in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
- numStateQueryThreads() - Method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
-
Returns the number of threads for the thread pool that performs the actual state lookup.
- numStateServerThreads() - Method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
-
Returns the number of threads for the query server NIO event loop.
- numSubpartitions - Variable in class org.apache.flink.runtime.io.network.partition.ResultPartition
- numTotalBytes() - Method in interface org.apache.flink.runtime.io.network.partition.DataBuffer
-
Returns the total number of bytes written to this
DataBuffer. - numTotalBytes() - Method in class org.apache.flink.runtime.io.network.partition.HashBasedDataBuffer
- numTotalBytes() - Method in class org.apache.flink.runtime.io.network.partition.SortBuffer
- numTotalBytesRead - Variable in class org.apache.flink.runtime.io.network.partition.SortBuffer
-
Total number of bytes already read from this sort buffer.
- numTotalRecords() - Method in interface org.apache.flink.runtime.io.network.partition.DataBuffer
-
Returns the total number of records written to this
DataBuffer. - numTotalRecords() - Method in class org.apache.flink.runtime.io.network.partition.HashBasedDataBuffer
- numTotalRecords() - Method in class org.apache.flink.runtime.io.network.partition.SortBuffer
- numWriteBuffersDelta() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageProducerMetricUpdate
- numWriteBytesDelta() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageProducerMetricUpdate
O
- objectReuse(boolean) - Method in class org.apache.flink.runtime.operators.sort.ExternalSorterBuilder
- objectReuseEnabled - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
- obtainDelegationTokens() - Method in class org.apache.flink.runtime.security.token.DefaultDelegationTokenManager
- obtainDelegationTokens() - Method in interface org.apache.flink.runtime.security.token.DelegationTokenManager
-
Obtains new tokens in a one-time fashion and automatically distributes them to all local JVM receivers.
- obtainDelegationTokens() - Method in class org.apache.flink.runtime.security.token.hadoop.HadoopFSDelegationTokenProvider
- obtainDelegationTokens() - Method in class org.apache.flink.runtime.security.token.hadoop.HBaseDelegationTokenProvider
- obtainDelegationTokens() - Method in class org.apache.flink.runtime.security.token.NoOpDelegationTokenManager
- obtainDelegationTokens(String, Set<FileSystem>, Credentials) - Method in class org.apache.flink.runtime.security.token.hadoop.HadoopFSDelegationTokenProvider
- obtainDelegationTokens(DelegationTokenContainer) - Method in class org.apache.flink.runtime.security.token.DefaultDelegationTokenManager
-
Obtains new tokens in a one-time fashion and leaves it up to the caller to distribute them.
- obtainDelegationTokens(DelegationTokenContainer) - Method in interface org.apache.flink.runtime.security.token.DelegationTokenManager
-
Obtains new tokens in a one-time fashion and leaves it up to the caller to distribute them.
- obtainDelegationTokens(DelegationTokenContainer) - Method in class org.apache.flink.runtime.security.token.NoOpDelegationTokenManager
- obtainDelegationTokensAndGetNextRenewal(DelegationTokenContainer) - Method in class org.apache.flink.runtime.security.token.DefaultDelegationTokenManager
- occupiedCount() - Method in class org.apache.flink.runtime.asyncprocessing.KeyAccountingUnit
- occupy(Object, K) - Method in class org.apache.flink.runtime.asyncprocessing.KeyAccountingUnit
-
Occupy a key for processing, the subsequent records with the same key would be blocked until the previous key release.
- of(int, int) - Static method in class org.apache.flink.runtime.state.KeyGroupRange
-
Factory method that also handles creation of empty key-groups.
- of(int, OperatorID) - Static method in class org.apache.flink.runtime.jobgraph.OperatorInstanceID
- of(long) - Static method in interface org.apache.flink.runtime.state.changelog.SequenceNumber
- of(long) - Static method in class org.apache.flink.streaming.api.windowing.evictors.CountEvictor
-
Creates a
CountEvictorthat keeps the given number of elements. - of(long) - Static method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
-
Creates a trigger that fires once the number of elements in a pane reaches the given count.
- of(long, boolean) - Static method in class org.apache.flink.streaming.api.windowing.evictors.CountEvictor
-
Creates a
CountEvictorthat keeps the given number of elements in the pane Eviction is done before/after the window function based on the value of doEvictAfter. - of(String, LeaderInformation) - Static method in class org.apache.flink.runtime.leaderelection.LeaderInformationRegister
-
Creates a single-entry instance containing only the passed information.
- of(Duration) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
Creates a new
TumblingEventTimeWindowsWindowAssignerthat assigns elements to time windows based on the element timestamp. - of(Duration) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
Creates a new
TumblingProcessingTimeWindowsWindowAssignerthat assigns elements to time windows based on the element timestamp. - of(Duration, Duration) - Static method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
Creates a new
SlidingEventTimeWindowsWindowAssignerthat assigns elements to sliding time windows based on the element timestamp. - of(Duration, Duration) - Static method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
Creates a new
SlidingProcessingTimeWindowsWindowAssignerthat assigns elements to sliding time windows based on the element timestamp. - of(Duration, Duration) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
Creates a new
TumblingEventTimeWindowsWindowAssignerthat assigns elements to time windows based on the element timestamp and offset. - of(Duration, Duration) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
Creates a new
TumblingProcessingTimeWindowsWindowAssignerthat assigns elements to time windows based on the element timestamp and offset. - of(Duration, Duration, Duration) - Static method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
-
Creates a new
SlidingEventTimeWindowsWindowAssignerthat assigns elements to time windows based on the element timestamp and offset. - of(Duration, Duration, Duration) - Static method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
-
Creates a new
SlidingProcessingTimeWindowsWindowAssignerthat assigns elements to time windows based on the element timestamp and offset. - of(Duration, Duration, WindowStagger) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
-
Creates a new
TumblingEventTimeWindowsWindowAssignerthat assigns elements to time windows based on the element timestamp, offset and a staggering offset, depending on the staggering policy. - of(Duration, Duration, WindowStagger) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
-
Creates a new
TumblingProcessingTimeWindowsWindowAssignerthat assigns elements to time windows based on the element timestamp, offset and a staggering offset, depending on the staggering policy. - of(Stream<int[]>, int) - Static method in class org.apache.flink.runtime.checkpoint.RescaleMappings
- of(JobID) - Static method in exception org.apache.flink.runtime.client.DuplicateJobSubmissionException
- of(Configuration) - Static method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler.Settings
- of(Configuration, JobCheckpointingSettings) - Static method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler.Settings
- of(Path) - Static method in class org.apache.flink.runtime.state.filemerging.DirectoryStreamStateHandle
- of(SinkCommitterMetricGroup) - Static method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
-
Creates a
CommittableCollectorbased on the current runtime information. - of(FileMergingSnapshotManager, Closeable) - Static method in class org.apache.flink.runtime.state.FileMergingSnapshotManagerClosableWrapper
- of(Environment) - Static method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager.SubtaskKey
- of(OperatorID, OperatorID, String, String) - Static method in class org.apache.flink.runtime.OperatorIDPair
- of(SlotInfo, Locality) - Static method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSelectionStrategy.SlotInfoAndLocality
- of(TriggerId, JobID) - Static method in class org.apache.flink.runtime.rest.handler.job.AsynchronousJobOperationKey
- of(StreamStateHandle, String) - Static method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle.HandleAndLocalPath
- of(StreamOperator<OUT>) - Static method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
-
Create a SimpleOperatorFactory from existed StreamOperator.
- of(Trigger<T, W>) - Static method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
-
Creates a new purging trigger from the given
Trigger. - of(SerializableSupplier<SimpleVersionedSerializer<CommT>>) - Static method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
-
Returns the type information based on the serializer for a
CommittableMessage. - of(T) - Static method in class org.apache.flink.runtime.state.DoneFuture
- of(T) - Static method in class org.apache.flink.runtime.state.SnapshotResult
- ofConfigurationAdded(String, String) - Static method in class org.apache.flink.runtime.dispatcher.ConfigurationNotAllowedMessage
- ofConfigurationChanged(String, MapDifference.ValueDifference<String>) - Static method in class org.apache.flink.runtime.dispatcher.ConfigurationNotAllowedMessage
- ofConfigurationObjectAdded(String, String, String) - Static method in class org.apache.flink.runtime.dispatcher.ConfigurationNotAllowedMessage
- ofConfigurationObjectChanged(String, String, MapDifference.ValueDifference<String>) - Static method in class org.apache.flink.runtime.dispatcher.ConfigurationNotAllowedMessage
- ofConfigurationObjectRemoved(String, String, String) - Static method in class org.apache.flink.runtime.dispatcher.ConfigurationNotAllowedMessage
- ofConfigurationObjectSetterUsed(String, String) - Static method in class org.apache.flink.runtime.dispatcher.ConfigurationNotAllowedMessage
- ofConfigurationRemoved(String, String) - Static method in class org.apache.flink.runtime.dispatcher.ConfigurationNotAllowedMessage
- ofDataChange(int, byte[]) - Static method in class org.apache.flink.runtime.state.changelog.StateChange
- OFF_CPU - org.apache.flink.runtime.rest.messages.FlameGraphTypeQueryParameter.Type
-
Type of the Flame Graph that includes threads in states Thread.State.
- offer(StateRequest<?, ?, ?, ?>) - Method in interface org.apache.flink.runtime.asyncprocessing.StateRequestContainer
-
Preserve a stateRequest into the
StateRequestContainer. - offer(T) - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
-
Adds element to the PriorityQueue in log(size) time if either the PriorityQueue is not full, or not lessThan(element, top()).
- offerSlots(Collection<? extends SlotOffer>, TaskManagerLocation, TaskManagerGateway, long) - Method in class org.apache.flink.runtime.jobmaster.slotpool.BlocklistDeclarativeSlotPool
- offerSlots(Collection<? extends SlotOffer>, TaskManagerLocation, TaskManagerGateway, long) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPool
-
Offers slots to this slot pool.
- offerSlots(Collection<? extends SlotOffer>, TaskManagerLocation, TaskManagerGateway, long) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultDeclarativeSlotPool
- offerSlots(ResourceID, Collection<SlotOffer>, Duration) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- offerSlots(ResourceID, Collection<SlotOffer>, Duration) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Offers the given slots to the job manager.
- offerSlots(TaskManagerLocation, TaskManagerGateway, Collection<SlotOffer>) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolBridge
- offerSlots(TaskManagerLocation, TaskManagerGateway, Collection<SlotOffer>) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolService
- offerSlots(TaskManagerLocation, TaskManagerGateway, Collection<SlotOffer>) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Offers multiple slots to the
SlotPool. - offerSlots(TaskManagerLocation, TaskManagerGateway, Collection<SlotOffer>) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolService
-
Offers multiple slots to the
SlotPoolService. - OFFLOAD_SHUFFLE_DESCRIPTORS_THRESHOLD - Static variable in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory
-
This is an expert option, that we do not want to expose in the documentation.
- Offloaded() - Constructor for class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.Offloaded
- Offloaded(PermanentBlobKey) - Constructor for class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.Offloaded
- offloadWithException(SerializedValue<T>, JobID, BlobWriter) - Static method in interface org.apache.flink.runtime.blob.BlobWriter
- ofGloballyTerminated(JobID) - Static method in exception org.apache.flink.runtime.client.DuplicateJobSubmissionException
- ofMetadataChange(byte[]) - Static method in class org.apache.flink.runtime.state.changelog.StateChange
- OK - org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureLevel
- OK - org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureStatus
- ON_CPU - org.apache.flink.runtime.rest.messages.FlameGraphTypeQueryParameter.Type
-
Type of the Flame Graph that includes threads in states Thread.State.
- ON_LOST_CONNECTION - org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalDriver.LeaderInformationClearancePolicy
- ON_SUSPENDED_CONNECTION - org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalDriver.LeaderInformationClearancePolicy
- onAddedJobGraph(JobID) - Method in class org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcess
- onAddedJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.DefaultJobGraphStore
- onAddedJobGraph(JobID) - Method in interface org.apache.flink.runtime.jobmanager.JobGraphStore.JobGraphListener
-
Callback for
JobGraphinstances added by a differentJobGraphStoreinstance. - onBuffer(Buffer, int, int, int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
Handles the input buffer.
- onChange() - Method in class org.apache.flink.runtime.scheduler.adaptive.DefaultStateTransitionManager
- onChange() - Method in interface org.apache.flink.runtime.scheduler.adaptive.StateTransitionManager
-
Is called if the environment changed in a way that a state transition could be considered.
- onCheckpoint(long) - Method in class org.apache.flink.runtime.source.coordinator.SplitAssignmentTracker
-
Behavior of SplitAssignmentTracker on checkpoint.
- onCheckpointComplete(long) - Method in class org.apache.flink.runtime.source.coordinator.SplitAssignmentTracker
-
when a checkpoint has been successfully made, this method is invoked to clean up the assignment history before this successful checkpoint.
- onClose() - Method in class org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess
- onClose() - Method in class org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcess
- onClose() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolBridge
- onClose() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolService
-
This method is called when the slot pool service is closed.
- onCompletedCheckpoint() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointStatsListener
-
Called when a checkpoint was completed successfully.
- onCompletedDeployment(ExecutionAttemptID) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionDeploymentListener
- onCompletedDeployment(ExecutionAttemptID) - Method in enum org.apache.flink.runtime.executiongraph.NoOpExecutionDeploymentListener
- onCompletedDeployment(ExecutionAttemptID) - Method in class org.apache.flink.runtime.jobmaster.ExecutionDeploymentTrackerDeploymentListenerAdapter
- OnCompletionActions - Interface in org.apache.flink.runtime.jobmanager
-
Interface for completion actions once a Flink job has reached a terminal state.
- onConsumedSubpartition() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
Notifies the parent partition about a consumed
ResultSubpartitionView. - one(T1) - Static method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
- OneInputStreamOperator<IN,OUT> - Interface in org.apache.flink.streaming.api.operators
-
Interface for stream operators with one input.
- OneInputStreamOperatorFactory<IN,OUT> - Interface in org.apache.flink.streaming.api.operators
-
A factory to create
OneInputStreamOperator. - OneInputStreamTask<IN,OUT> - Class in org.apache.flink.streaming.runtime.tasks
-
A
StreamTaskfor executing aOneInputStreamOperator. - OneInputStreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
-
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
- OneInputStreamTask(Environment, TimerService) - Constructor for class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
-
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
- OneInputTransformation<IN,OUT> - Class in org.apache.flink.streaming.api.transformations
-
This Transformation represents the application of a
OneInputStreamOperatorto one inputTransformation. - OneInputTransformation(Transformation<IN>, String, OneInputStreamOperator<IN, OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Creates a new
OneInputTransformationfrom the given input and operator. - OneInputTransformation(Transformation<IN>, String, OneInputStreamOperator<IN, OUT>, TypeInformation<OUT>, int, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.OneInputTransformation
- OneInputTransformation(Transformation<IN>, String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.OneInputTransformation
- OneInputTransformation(Transformation<IN>, String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Creates a new
LegacySinkTransformationfrom the given inputTransformation. - OneInputTransformationTranslator<IN,OUT> - Class in org.apache.flink.streaming.runtime.translators
-
A
TransformationTranslatorfor theOneInputTransformation. - OneInputTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.OneInputTransformationTranslator
- onElement(Object, long, GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.EndOfStreamTrigger
- onElement(Object, long, GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
- onElement(Object, long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
- onElement(Object, long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
- onElement(Object, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
- onElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
- onElement(T, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
- onElement(T, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
Called for every element that gets added to a pane.
- onEmptyBuffer(int, int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- onError(Throwable) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- onError(Throwable) - Method in class org.apache.flink.runtime.leaderelection.DefaultLeaderElectionService
- onError(Throwable) - Method in interface org.apache.flink.runtime.leaderelection.LeaderElectionDriver.Listener
-
Notifies the listener if an error occurred.
- onError(Throwable) - Method in class org.apache.flink.runtime.resourcemanager.active.ActiveResourceManager
- onError(Throwable) - Method in interface org.apache.flink.runtime.resourcemanager.active.ResourceEventHandler
-
Notifies that an error has occurred that the process cannot proceed.
- onEvent(TaskEvent) - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
-
Barrier will release the waiting thread if an event occurs.
- onEvent(TaskEvent) - Method in class org.apache.flink.runtime.iterative.task.SyncEventHandler
- onEvent(T) - Method in interface org.apache.flink.runtime.util.event.EventListener
- onEventTime(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
- onEventTime(long, GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.EndOfStreamTrigger
- onEventTime(long, GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
- onEventTime(long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
- onEventTime(long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
- onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
- onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
- onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
Called when an event-time timer that was set using the trigger context fires.
- onEventTime(InternalTimer<K, String>) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
- onEventTime(InternalTimer<K, N>) - Method in interface org.apache.flink.streaming.api.operators.Triggerable
-
Invoked when an event-time timer fires.
- onEventTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
- onEventTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
-
Deprecated.
- onEventTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.KeyedProcessOperator
- onEventTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator
-
Deprecated.
- onEventTime(InternalTimer<K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
- onEventTime(InternalTimer<K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
- onEventTime(InternalTimer<KEY, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.BatchGroupedReduceOperator
- onEventTime(InternalTimer<KS, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
- onExecutionFinished(ExecutionVertexID) - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.BatchJobRecoveryHandler
-
Records the execution vertex finished event for use during future batch job recovery.
- onExecutionFinished(ExecutionVertexID) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DefaultBatchJobRecoveryHandler
- onExecutionFinished(ExecutionVertexID) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DummyBatchJobRecoveryHandler
- onExecutionJobVertexInitialization(JobVertexID, int, Map<IntermediateDataSetID, JobVertexInputInfo>) - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.BatchJobRecoveryHandler
-
Records the job vertex initialization event for use during future batch job recovery.
- onExecutionJobVertexInitialization(JobVertexID, int, Map<IntermediateDataSetID, JobVertexInputInfo>) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DefaultBatchJobRecoveryHandler
- onExecutionJobVertexInitialization(JobVertexID, int, Map<IntermediateDataSetID, JobVertexInputInfo>) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DummyBatchJobRecoveryHandler
- onExecutionStateChange(ExecutionVertexID, ExecutionState) - Method in class org.apache.flink.runtime.scheduler.strategy.PipelinedRegionSchedulingStrategy
- onExecutionStateChange(ExecutionVertexID, ExecutionState) - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingStrategy
-
Called whenever an
Executionchanges its state. - onExecutionStateChange(ExecutionVertexID, ExecutionState) - Method in class org.apache.flink.runtime.scheduler.strategy.VertexwiseSchedulingStrategy
- onExecutionVertexReset(Collection<ExecutionVertexID>) - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.BatchJobRecoveryHandler
-
Handles the reset event for a collection of execution vertices and records the event for use during future batch job recovery.
- onExecutionVertexReset(Collection<ExecutionVertexID>) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DefaultBatchJobRecoveryHandler
- onExecutionVertexReset(Collection<ExecutionVertexID>) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DummyBatchJobRecoveryHandler
- onFailAllocation(ResourceCounter) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolBridge
- onFailAllocation(ResourceCounter) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolService
-
This method is called when an allocation fails.
- onFailedCheckpoint() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointStatsListener
-
Called when a checkpoint failed.
- onFailedPartitionRequest() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- onFatalError(Throwable) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- onFatalError(Throwable) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
- onFatalError(Throwable) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierShuffleHandler
-
A callback to process the fatal error (if the error exists).
- onFatalError(Throwable) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
Notifies the ResourceManager that a fatal error has occurred and it cannot proceed.
- onFatalError(Throwable) - Method in interface org.apache.flink.runtime.shuffle.ShuffleMasterContext
-
Handles the fatal error if any.
- onFatalError(Throwable) - Method in class org.apache.flink.runtime.shuffle.ShuffleMasterContextImpl
- onFatalError(Throwable) - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
- onFinished(ArchivedExecutionGraph) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- onGrantLeadership(UUID) - Method in class org.apache.flink.runtime.leaderelection.DefaultLeaderElectionService
- onGrantLeadership(UUID) - Method in interface org.apache.flink.runtime.leaderelection.LeaderElectionDriver.Listener
-
Callback that is called once the driver obtains the leadership.
- onLeaderInformationChange(String, LeaderInformation) - Method in class org.apache.flink.runtime.leaderelection.DefaultLeaderElectionService
- onLeaderInformationChange(String, LeaderInformation) - Method in interface org.apache.flink.runtime.leaderelection.LeaderElectionDriver.Listener
-
Notifies the listener about a changed leader information for the given component.
- onLeaderInformationChange(LeaderInformationRegister) - Method in class org.apache.flink.runtime.leaderelection.DefaultLeaderElectionService
- onLeaderInformationChange(LeaderInformationRegister) - Method in interface org.apache.flink.runtime.leaderelection.LeaderElectionDriver.Listener
-
Notifies the listener about all currently known leader information.
- onLogicalFileCreate(long) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager.SpaceStat
- onLogicalFileDelete(long) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager.SpaceStat
- ONLY_NEW_FILES - org.apache.flink.streaming.api.functions.source.legacy.FileMonitoringFunction.WatchType
-
Deprecated.
- OnlyExecutionGraphJsonArchivist - Interface in org.apache.flink.runtime.webmonitor.history
-
Interface for all classes that want to participate in the archiving of job-related json responses but only provide
AccessExecutionGraph-related information. - OnMainThreadJobManagerRunnerRegistry - Class in org.apache.flink.runtime.dispatcher
-
OnMainThreadJobManagerRunnerRegistryimplementsJobManagerRunnerRegistryguarding the passedJobManagerRunnerRegistryinstance in a way that it only allows modifying methods to be executed on the component's main thread. - OnMainThreadJobManagerRunnerRegistry(JobManagerRunnerRegistry, ComponentMainThreadExecutor) - Constructor for class org.apache.flink.runtime.dispatcher.OnMainThreadJobManagerRunnerRegistry
- onMerge(Collection<W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
- onMerge(GlobalWindow, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.EndOfStreamTrigger
- onMerge(GlobalWindow, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
- onMerge(TimeWindow, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
- onMerge(TimeWindow, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
- onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
- onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
- onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
Called when several windows have been merged into one window by the
WindowAssigner. - onMissingDeploymentsOf(Collection<ExecutionAttemptID>, ResourceID) - Method in interface org.apache.flink.runtime.jobmaster.ExecutionDeploymentReconciliationHandler
-
Called if some executions are expected to be hosted on a task executor, but aren't.
- onNewTokensObtained(byte[]) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- onNewTokensObtained(byte[]) - Method in interface org.apache.flink.runtime.security.token.DelegationTokenManager.Listener
-
Callback function when new delegation tokens obtained.
- onNewTokensObtained(byte[]) - Method in class org.apache.flink.runtime.security.token.DelegationTokenReceiverRepository
-
Callback function when new delegation tokens obtained.
- onNewTokensObtained(byte[]) - Method in class org.apache.flink.runtime.security.token.hadoop.HadoopDelegationTokenReceiver
- onNewTokensObtained(DelegationTokenContainer) - Method in class org.apache.flink.runtime.security.token.DelegationTokenReceiverRepository
-
Callback function when new delegation tokens obtained.
- onNext(Consumer<T>) - Method in class org.apache.flink.runtime.asyncprocessing.AbstractStateIterator
- onNext(Consumer<T>) - Method in class org.apache.flink.runtime.state.v2.adaptor.CompleteStateIterator
- onNext(Function<T, StateFuture<? extends U>>) - Method in class org.apache.flink.runtime.asyncprocessing.AbstractStateIterator
- onNext(Function<T, StateFuture<? extends U>>) - Method in class org.apache.flink.runtime.state.v2.adaptor.CompleteStateIterator
- onNextSync(Consumer<T>) - Method in class org.apache.flink.runtime.asyncprocessing.AbstractStateIterator
- onNonRecord(Runnable, EpochManager.ParallelMode) - Method in class org.apache.flink.runtime.asyncprocessing.EpochManager
-
Add a non-record to the current epoch, close current epoch and open a new epoch.
- onNotification() - Method in interface org.apache.flink.runtime.util.event.NotificationListener
- onPartitionConsumable(IntermediateResultPartitionID) - Method in class org.apache.flink.runtime.scheduler.strategy.PipelinedRegionSchedulingStrategy
- onPartitionConsumable(IntermediateResultPartitionID) - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingStrategy
-
Called whenever an
IntermediateResultPartitionbecomes consumable. - onPartitionConsumable(IntermediateResultPartitionID) - Method in class org.apache.flink.runtime.scheduler.strategy.VertexwiseSchedulingStrategy
- onPhysicalFileCreate() - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager.SpaceStat
- onPhysicalFileDelete(long) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager.SpaceStat
- onPhysicalFileUpdate(long) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager.SpaceStat
- onPreviousAttemptWorkersRecovered(Collection<WorkerType>) - Method in class org.apache.flink.runtime.resourcemanager.active.ActiveResourceManager
- onPreviousAttemptWorkersRecovered(Collection<WorkerType>) - Method in interface org.apache.flink.runtime.resourcemanager.active.ResourceEventHandler
-
Notifies that workers of previous attempt have been recovered from the external resource manager.
- onProcessingTime(long) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
- onProcessingTime(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
- onProcessingTime(long, GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.EndOfStreamTrigger
- onProcessingTime(long, GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
- onProcessingTime(long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
- onProcessingTime(long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
- onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
- onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
- onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
-
Called when a processing-time timer that was set using the trigger context fires.
- onProcessingTime(InternalTimer<K, String>) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
- onProcessingTime(InternalTimer<K, N>) - Method in interface org.apache.flink.streaming.api.operators.Triggerable
-
Invoked when a processing-time timer fires.
- onProcessingTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
- onProcessingTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
-
Deprecated.
- onProcessingTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.KeyedProcessOperator
- onProcessingTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator
-
Deprecated.
- onProcessingTime(InternalTimer<K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
- onProcessingTime(InternalTimer<K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
- onProcessingTime(InternalTimer<KEY, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.BatchGroupedReduceOperator
- onProcessingTime(InternalTimer<KS, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
- onRecord() - Method in class org.apache.flink.runtime.asyncprocessing.EpochManager
-
Add a record to the current epoch and return the current open epoch, the epoch will be associated with the
RecordContextof this record. - onRecoveredStateBuffer(Buffer) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RecoveredInputChannel
- onRecoveringFailed() - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.BatchJobRecoveryContext
-
Notifies the recovery failed.
- onRecoveringFinished(Set<JobVertexID>) - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.BatchJobRecoveryContext
-
Notifies the recovery finished.
- onRegistrationFailure(Throwable) - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
This method handle the Registration failure.
- onRegistrationFailure(Throwable) - Method in interface org.apache.flink.runtime.registration.RegistrationConnectionListener
-
This method is called by the
RegisteredRpcConnectionwhen the registration fails. - onRegistrationFailure(Throwable) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorToResourceManagerConnection
- onRegistrationRejection(String, R) - Method in interface org.apache.flink.runtime.registration.RegistrationConnectionListener
-
This method is called by the
RegisteredRpcConnectionwhen the registration is rejected. - onRegistrationRejection(TaskExecutorRegistrationRejection) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorToResourceManagerConnection
- onRegistrationRejection(R) - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
This method handles the Registration rejection.
- onRegistrationSuccess(TaskExecutorRegistrationSuccess) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorToResourceManagerConnection
- onRegistrationSuccess(S) - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
This method handle the Registration Response.
- onRegistrationSuccess(T, S) - Method in interface org.apache.flink.runtime.registration.RegistrationConnectionListener
-
This method is called by the
RegisteredRpcConnectionwhen the registration is success. - onReleasePartitions(Collection<TieredStoragePartitionId>) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierShuffleHandler
-
A callback to process the event of releasing a collection of tiered result partitions.
- onReleaseTaskManager(ResourceCounter) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolBridge
- onReleaseTaskManager(ResourceCounter) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolService
-
This method is called when a TaskManager is released.
- onRemovedJobGraph(JobID) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- onRemovedJobGraph(JobID) - Method in interface org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess.DispatcherGatewayService
- onRemovedJobGraph(JobID) - Method in class org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherGatewayService
- onRemovedJobGraph(JobID) - Method in class org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcess
- onRemovedJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.DefaultJobGraphStore
- onRemovedJobGraph(JobID) - Method in interface org.apache.flink.runtime.jobmanager.JobGraphStore.JobGraphListener
-
Callback for
JobGraphinstances removed by a differentJobGraphStoreinstance. - onRevokeLeadership() - Method in class org.apache.flink.runtime.leaderelection.DefaultLeaderElectionService
- onRevokeLeadership() - Method in interface org.apache.flink.runtime.leaderelection.LeaderElectionDriver.Listener
-
Callback that is called once the driver loses the leadership.
- onSenderBacklog(int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
Receives the backlog from the producer's buffer response.
- onStart() - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- onStart() - Method in class org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess
- onStart() - Method in class org.apache.flink.runtime.dispatcher.runner.JobDispatcherLeaderProcess
- onStart() - Method in class org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcess
- onStart() - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- onStart() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolBridge
- onStart() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolService
-
This method is called when the slot pool service is started.
- onStart() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- onStart() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- onStartedDeployment(ExecutionAttemptID, ResourceID) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionDeploymentListener
- onStartedDeployment(ExecutionAttemptID, ResourceID) - Method in enum org.apache.flink.runtime.executiongraph.NoOpExecutionDeploymentListener
- onStartedDeployment(ExecutionAttemptID, ResourceID) - Method in class org.apache.flink.runtime.jobmaster.ExecutionDeploymentTrackerDeploymentListenerAdapter
- onStateUpdate(ExecutionAttemptID, ExecutionState, ExecutionState) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionStateUpdateListener
- onStateUpdate(ExecutionAttemptID, ExecutionState, ExecutionState) - Method in class org.apache.flink.runtime.scheduler.metrics.DeploymentStateTimeMetrics
- onStop() - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- onStop() - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
Suspend the job and shutdown all other services including rpc.
- onStop() - Method in class org.apache.flink.runtime.metrics.dump.MetricQueryService
- onStop() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- onStop() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
Called to shut down the TaskManager.
- onSubpartitionAllDataProcessed(int) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartition
- onSubpartitionAllDataProcessed(int) - Method in class org.apache.flink.runtime.io.network.partition.PipelinedResultPartition
- onSubpartitionAllDataProcessed(int) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
The subpartition notifies that the corresponding downstream task have processed all the user records.
- onTaskFailed(Execution) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.AdaptiveBatchScheduler
- onTaskFailed(Execution) - Method in class org.apache.flink.runtime.scheduler.DefaultScheduler
- onTaskFailed(Execution) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- onTaskFinished(Execution, IOMetrics) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.AdaptiveBatchScheduler
- onTaskFinished(Execution, IOMetrics) - Method in class org.apache.flink.runtime.scheduler.DefaultScheduler
- onTaskFinished(Execution, IOMetrics) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- onTimer(long, CoProcessFunction.OnTimerContext, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction
-
Called when a timer set using
TimerServicefires. - onTimer(long, KeyedBroadcastProcessFunction.OnTimerContext, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction
-
Called when a timer set using
TimerServicefires. - onTimer(long, KeyedCoProcessFunction.OnTimerContext, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction
-
Called when a timer set using
TimerServicefires. - onTimer(long, KeyedProcessFunction.OnTimerContext, Collector<O>) - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction
-
Called when a timer set using
TimerServicefires. - onTimer(long, ProcessFunction.OnTimerContext, Collector<O>) - Method in class org.apache.flink.streaming.api.functions.ProcessFunction
-
Called when a timer set using
TimerServicefires. - OnTimerContext() - Constructor for class org.apache.flink.streaming.api.functions.co.CoProcessFunction.OnTimerContext
- OnTimerContext() - Constructor for class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.OnTimerContext
- OnTimerContext() - Constructor for class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.OnTimerContext
- OnTimerContext() - Constructor for class org.apache.flink.streaming.api.functions.KeyedProcessFunction.OnTimerContext
- OnTimerContext() - Constructor for class org.apache.flink.streaming.api.functions.ProcessFunction.OnTimerContext
- onTrigger() - Method in class org.apache.flink.runtime.scheduler.adaptive.DefaultStateTransitionManager
- onTrigger() - Method in interface org.apache.flink.runtime.scheduler.adaptive.StateTransitionManager
-
Is called when any previous observed environment changes shall be verified possibly triggering a state transition operation.
- onUnknownDeploymentsOf(Collection<ExecutionAttemptID>, ResourceID) - Method in interface org.apache.flink.runtime.jobmaster.ExecutionDeploymentReconciliationHandler
-
Called if some executions are hosted on a task executor, but we don't expect them.
- onWorkerRegistered(WorkerType, WorkerResourceSpec) - Method in class org.apache.flink.runtime.resourcemanager.active.ActiveResourceManager
- onWorkerRegistered(WorkerType, WorkerResourceSpec) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- onWorkerTerminated(ResourceID, String) - Method in class org.apache.flink.runtime.resourcemanager.active.ActiveResourceManager
- onWorkerTerminated(ResourceID, String) - Method in interface org.apache.flink.runtime.resourcemanager.active.ResourceEventHandler
-
Notifies that the worker has been terminated.
- OpaqueMemoryResource<T> - Class in org.apache.flink.runtime.memory
-
An opaque memory resource, meaning a memory resource not understood by Flink or the JVM.
- OpaqueMemoryResource(T, long, ThrowingRunnable<Exception>) - Constructor for class org.apache.flink.runtime.memory.OpaqueMemoryResource
- open() - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateUdfStreamOperator
- open() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
Initialize the hash table
- open() - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
-
Initialize the hash table
- open() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
Initialize the hash table
- open() - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
- open() - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
- open() - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
- open() - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
- open() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
- open() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
- open() - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
- open() - Method in class org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
- open() - Method in class org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
- open() - Method in interface org.apache.flink.runtime.operators.util.CoGroupTaskIterator
-
General-purpose open method.
- open() - Method in interface org.apache.flink.runtime.operators.util.JoinTaskIterator
-
General-purpose open method.
- open() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
- open() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
This method is called immediately before any elements are processed, it should contain the operator's initialization logic, e.g. state initialization.
- open() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
This method is called immediately before any elements are processed, it should contain the operator's initialization logic, e.g. state initialization.
- open() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
- open() - Method in class org.apache.flink.streaming.api.operators.BatchGroupedReduceOperator
- open() - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
- open() - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
- open() - Method in class org.apache.flink.streaming.api.operators.co.CoProcessOperator
- open() - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
- open() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
- open() - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
- open() - Method in class org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
-
Deprecated.
- open() - Method in class org.apache.flink.streaming.api.operators.KeyedProcessOperator
- open() - Method in class org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator
-
Deprecated.
- open() - Method in class org.apache.flink.streaming.api.operators.MapPartitionOperator
- open() - Method in class org.apache.flink.streaming.api.operators.PartitionAggregateOperator
- open() - Method in class org.apache.flink.streaming.api.operators.ProcessOperator
- open() - Method in class org.apache.flink.streaming.api.operators.SourceOperator
- open() - Method in class org.apache.flink.streaming.api.operators.StreamFlatMap
- open() - Method in class org.apache.flink.streaming.api.operators.StreamGroupedReduceOperator
- open() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
This method is called immediately before any elements are processed, it should contain the operator's initialization logic.
- open() - Method in class org.apache.flink.streaming.api.operators.StreamProject
- open() - Method in class org.apache.flink.streaming.api.operators.StreamSink
- open() - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
- open() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
- open() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
- open(OpenContext) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.OutputFormatSinkFunction
-
Deprecated.
- open(OpenContext) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.PrintSinkFunction
-
Deprecated.
- open(OpenContext) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.SocketClientSink
-
Deprecated.
- open(OpenContext) - Method in class org.apache.flink.streaming.api.functions.source.legacy.ContinuousFileMonitoringFunction
-
Deprecated.
- open(OpenContext) - Method in class org.apache.flink.streaming.api.functions.source.legacy.FromSplittableIteratorFunction
-
Deprecated.
- open(OpenContext) - Method in class org.apache.flink.streaming.api.functions.source.legacy.InputFormatSourceFunction
-
Deprecated.
- open(OpenContext) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
- open(OpenContext) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
- open(OpenContext) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
- open(OpenContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
- open(OpenContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
- open(OpenContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
- open(MutableObjectIterator<BT>, MutableObjectIterator<PT>) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Opens the hash join.
- open(MutableObjectIterator<BT>, MutableObjectIterator<PT>, boolean) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Opens the hash join.
- open(MutableObjectIterator<BT>, MutableObjectIterator<PT>, boolean) - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
- OPEN - org.apache.flink.runtime.util.ZooKeeperUtils.ZkClientACLMode
- OPEN - org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox.State
- openChainedTasks(List<ChainedDriver<?, ?>>, AbstractInvokable) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Opens all chained tasks, in the order as they are stored in the array.
- openInputStream() - Method in class org.apache.flink.runtime.state.filemerging.DirectoryStreamStateHandle
- openInputStream() - Method in class org.apache.flink.runtime.state.filemerging.EmptySegmentFileStateHandle
- openInputStream() - Method in class org.apache.flink.runtime.state.filemerging.SegmentFileStateHandle
- openInputStream() - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
- openInputStream() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
- openInputStream() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
- openInputStream() - Method in interface org.apache.flink.runtime.state.OperatorStateHandle
-
Returns an input stream to read the operator state information.
- openInputStream() - Method in class org.apache.flink.runtime.state.OperatorStreamStateHandle
- openInputStream() - Method in class org.apache.flink.runtime.state.PlaceholderStreamStateHandle
- openInputStream() - Method in class org.apache.flink.runtime.state.RetrievableStreamStateHandle
- openInputStream() - Method in class org.apache.flink.runtime.state.SharedStateRegistryImpl.EmptyDiscardStateObjectForRegister
- openInputStream() - Method in interface org.apache.flink.runtime.state.StreamStateHandle
-
Returns an
FSDataInputStreamthat can be used to read back the data that was previously written to the stream. - openTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
- openTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
- openTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
- openTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
- openTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
- openTask() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
- openTask() - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
- openUserCode(Function, Configuration) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Opens the given stub using its
RichFunction.open(OpenContext)method. - OperationAlreadyFailedException - Exception in org.apache.flink.runtime.dispatcher
-
Exception indicating that a requested operation already exists and has failed.
- OperationAlreadyFailedException(Throwable) - Constructor for exception org.apache.flink.runtime.dispatcher.OperationAlreadyFailedException
- operationId() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
- operationId() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointTriggerHeaders
- operationId() - Method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
- operationId() - Method in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteTriggerHeaders
- operationId() - Method in class org.apache.flink.runtime.rest.messages.job.JobResourcesRequirementsUpdateHeaders
- operationId() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
- operationId() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
- operationId() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
- operationId() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointTriggerHeaders
- operationId() - Method in class org.apache.flink.runtime.rest.messages.JobCancellationHeaders
- operationId() - Method in class org.apache.flink.runtime.rest.messages.JobClientHeartbeatHeaders
- operationId() - Method in interface org.apache.flink.runtime.rest.messages.MessageHeaders
-
Returns a short description for this header suitable for method code generation.
- OperationKey - Class in org.apache.flink.runtime.rest.handler.async
-
Any operation key for the
AbstractAsynchronousOperationHandlersmust extend this class. - OperationKey(TriggerId) - Constructor for class org.apache.flink.runtime.rest.handler.async.OperationKey
- OperationResult<R> - Class in org.apache.flink.runtime.rest.handler.async
-
Encapsulates the result of an asynchronous operation.
- operationResultResponse(String) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointStatusHandler
- operationResultResponse(Acknowledge) - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingStatusHandler
- operationResultResponse(Acknowledge) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalStatusHandler
- operationResultResponse(ClusterDataSetDeleteHandlers.SerializableVoid) - Method in class org.apache.flink.runtime.rest.handler.dataset.ClusterDataSetDeleteHandlers.ClusterDataSetDeleteStatusHandler
- operationResultResponse(R) - Method in class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.StatusHandler
-
Create the operation result from the given value.
- OperationResultStatus - Enum in org.apache.flink.runtime.rest.handler.async
-
Current status of an asynchronous operation.
- OPERATOR - org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.BackendStateType
- OPERATOR - org.apache.flink.streaming.util.LatencyStats.Granularity
- OPERATOR_STATE_DISTRIBUTION_MODE - org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.CommonOptionsKeys
-
Key to define
OperatorStateHandle.Mode, about how operator state is distributed on restore - OperatorAttributes - Class in org.apache.flink.streaming.api.operators
-
OperatorAttributes element provides Job Manager with information that can be used to optimize job performance.
- OperatorAttributesBuilder - Class in org.apache.flink.streaming.api.operators
-
The builder class for
OperatorAttributes. - OperatorAttributesBuilder() - Constructor for class org.apache.flink.streaming.api.operators.OperatorAttributesBuilder
- OperatorBackendSerializationProxy - Class in org.apache.flink.runtime.state
-
Serialization proxy for all meta data in operator state backends.
- OperatorBackendSerializationProxy(ClassLoader) - Constructor for class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
- OperatorBackendSerializationProxy(List<StateMetaInfoSnapshot>, List<StateMetaInfoSnapshot>, boolean) - Constructor for class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
- operatorChain - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
The chain of operators executed by this task.
- OperatorChain<OUT,OP extends StreamOperator<OUT>> - Class in org.apache.flink.streaming.runtime.tasks
-
The
OperatorChaincontains all operators that are executed as one chain within a singleStreamTask. - OperatorChain(StreamTask<OUT, OP>, RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>>) - Constructor for class org.apache.flink.streaming.runtime.tasks.OperatorChain
- OperatorChain.ChainedSource - Class in org.apache.flink.streaming.runtime.tasks
-
Wrapper class to access the chained sources and their's outputs.
- OperatorCoordinator - Interface in org.apache.flink.runtime.operators.coordination
-
A coordinator for runtime operators.
- OperatorCoordinator.Context - Interface in org.apache.flink.runtime.operators.coordination
-
The context gives the OperatorCoordinator access to contextual information and provides a gateway to interact with other components, such as sending operator events.
- OperatorCoordinator.Provider - Interface in org.apache.flink.runtime.operators.coordination
-
The provider creates an OperatorCoordinator and takes a
OperatorCoordinator.Contextto pass to the OperatorCoordinator. - OperatorCoordinator.SubtaskGateway - Interface in org.apache.flink.runtime.operators.coordination
-
The
SubtaskGatewayis the way to interact with a specific parallel instance of the Operator (an Operator subtask), like sending events to the operator. - OperatorCoordinatorCheckpointContext - Interface in org.apache.flink.runtime.checkpoint
-
This context is the interface through which the
CheckpointCoordinatorinteracts with anOperatorCoordinatorduring checkpointing and checkpoint restoring. - operatorCoordinatorHandler - Variable in class org.apache.flink.runtime.scheduler.SchedulerBase
- OperatorCoordinatorHandler - Interface in org.apache.flink.runtime.scheduler
-
Handler for the
OperatorCoordinators. - OperatorCoordinatorHolder - Class in org.apache.flink.runtime.operators.coordination
-
The
OperatorCoordinatorHolderholds theOperatorCoordinatorand manages all its interactions with the remaining components. - OperatorEvent - Interface in org.apache.flink.runtime.operators.coordination
-
Root interface for all events sent between
OperatorCoordinatorand anOperatorEventHandler. - operatorEventDispatcher - Variable in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- OperatorEventDispatcher - Interface in org.apache.flink.runtime.operators.coordination
-
The dispatcher through which Operators receive
OperatorEvents and through which they can send OperatorEvents back to theOperatorCoordinator. - OperatorEventDispatcherImpl - Class in org.apache.flink.streaming.runtime.tasks
-
An implementation of the
OperatorEventDispatcher. - OperatorEventDispatcherImpl(ClassLoader, TaskOperatorEventGateway) - Constructor for class org.apache.flink.streaming.runtime.tasks.OperatorEventDispatcherImpl
- OperatorEventGateway - Interface in org.apache.flink.runtime.operators.coordination
-
The gateway through which an Operator can send an
OperatorEventto theOperatorCoordinatoron the JobManager side. - OperatorEventHandler - Interface in org.apache.flink.runtime.operators.coordination
-
Interface for handlers of operator events on the operator side.
- operatorFactory - Variable in class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
- operatorId() - Method in class org.apache.flink.runtime.operators.coordination.OperatorCoordinatorHolder
- operatorId() - Method in interface org.apache.flink.runtime.operators.coordination.OperatorInfo
- OperatorID - Class in org.apache.flink.runtime.jobgraph
-
A class for statistically unique operator IDs.
- OperatorID() - Constructor for class org.apache.flink.runtime.jobgraph.OperatorID
- OperatorID(byte[]) - Constructor for class org.apache.flink.runtime.jobgraph.OperatorID
- OperatorID(long, long) - Constructor for class org.apache.flink.runtime.jobgraph.OperatorID
- OperatorIDPair - Class in org.apache.flink.runtime
-
Formed of a mandatory operator ID and optionally a user defined operator ID.
- OperatorInfo - Interface in org.apache.flink.runtime.operators.coordination
-
An interface to access basic properties of an operator in the context of its coordinator.
- OperatorInstanceID - Class in org.apache.flink.runtime.jobgraph
-
An ID for physical instance of the operator.
- OperatorInstanceID(int, OperatorID) - Constructor for class org.apache.flink.runtime.jobgraph.OperatorInstanceID
- operatorName - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobManagerOperatorQueryScopeInfo
- operatorName - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
- OperatorQueryScopeInfo(String, String, int, int, String) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
- OperatorQueryScopeInfo(String, String, int, int, String, String) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
- OperatorScopeFormat - Class in org.apache.flink.runtime.metrics.scope
-
The scope format for the
InternalOperatorMetricGroup. - OperatorScopeFormat(String, TaskScopeFormat) - Constructor for class org.apache.flink.runtime.metrics.scope.OperatorScopeFormat
- OperatorSnapshotFinalizer - Class in org.apache.flink.streaming.api.operators
-
This class finalizes
OperatorSnapshotFutures. - OperatorSnapshotFinalizer(OperatorSnapshotFutures) - Constructor for class org.apache.flink.streaming.api.operators.OperatorSnapshotFinalizer
- OperatorSnapshotFutures - Class in org.apache.flink.streaming.api.operators
- OperatorSnapshotFutures() - Constructor for class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
- OperatorSnapshotFutures(RunnableFuture<SnapshotResult<KeyedStateHandle>>, RunnableFuture<SnapshotResult<KeyedStateHandle>>, RunnableFuture<SnapshotResult<OperatorStateHandle>>, RunnableFuture<SnapshotResult<OperatorStateHandle>>, Future<SnapshotResult<StateObjectCollection<InputChannelStateHandle>>>, Future<SnapshotResult<StateObjectCollection<ResultSubpartitionStateHandle>>>) - Constructor for class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
- OperatorState - Class in org.apache.flink.runtime.checkpoint
-
Simple container class which contains the raw/managed operator state and key-group state handles from all subtasks of an operator and therefore represents the complete state of a logical operator.
- OperatorState(String, String, OperatorID, int, int) - Constructor for class org.apache.flink.runtime.checkpoint.OperatorState
- operatorStateBackend() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
-
Returns the operator state backend for the stream operator.
- operatorStateBackend(String, PrioritizedOperatorSubtaskState, CloseableRegistry, StateObject.StateObjectSizeStatsCollector) - Method in class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
- OperatorStateBackend - Interface in org.apache.flink.runtime.state
-
Interface that combines both, the user facing
OperatorStateStoreinterface and the system interfaceSnapshotable - OperatorStateBackendParametersImpl - Class in org.apache.flink.runtime.state
-
Internal POJO implementing
StateBackend.OperatorStateBackendParameters - OperatorStateBackendParametersImpl(Environment, String, Collection<OperatorStateHandle>, CloseableRegistry) - Constructor for class org.apache.flink.runtime.state.OperatorStateBackendParametersImpl
- OperatorStateBackendParametersImpl(Environment, String, Collection<OperatorStateHandle>, StateBackend.CustomInitializationMetrics, CloseableRegistry) - Constructor for class org.apache.flink.runtime.state.OperatorStateBackendParametersImpl
- operatorStateCheckpointClosingFuture - Variable in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
- OperatorStateCheckpointOutputStream - Class in org.apache.flink.runtime.state
-
Checkpoint output stream that allows to write raw operator state in a partitioned way.
- OperatorStateCheckpointOutputStream(CheckpointStateOutputStream) - Constructor for class org.apache.flink.runtime.state.OperatorStateCheckpointOutputStream
- OperatorStateHandle - Interface in org.apache.flink.runtime.state
-
Interface of a state handle for operator state.
- OperatorStateHandle.Mode - Enum in org.apache.flink.runtime.state
-
The modes that determine how an
OperatorStreamStateHandleis assigned to tasks during restore. - OperatorStateHandle.StateMetaInfo - Class in org.apache.flink.runtime.state
-
Meta information about the operator state handle.
- OperatorStateRepartitioner<T> - Interface in org.apache.flink.runtime.checkpoint
-
Interface that allows to implement different strategies for repartitioning of operator state as parallelism changes.
- OperatorStateRestoreOperation - Class in org.apache.flink.runtime.state
-
Implementation of operator state restore operation.
- OperatorStateRestoreOperation(CloseableRegistry, ClassLoader, Map<String, PartitionableListState<?>>, Map<String, BackendWritableBroadcastState<?, ?>>, Collection<OperatorStateHandle>) - Constructor for class org.apache.flink.runtime.state.OperatorStateRestoreOperation
- OperatorStreamStateHandle - Class in org.apache.flink.runtime.state
-
State handle for partitionable operator state.
- OperatorStreamStateHandle(Map<String, OperatorStateHandle.StateMetaInfo>, StreamStateHandle) - Constructor for class org.apache.flink.runtime.state.OperatorStreamStateHandle
- OperatorSubtaskDescriptionText - Class in org.apache.flink.runtime.util
-
This class generates a string that can be used to identify an operator subtask.
- OperatorSubtaskDescriptionText(OperatorID, String, int, int) - Constructor for class org.apache.flink.runtime.util.OperatorSubtaskDescriptionText
- OperatorSubtaskState - Class in org.apache.flink.runtime.checkpoint
-
This class encapsulates the state for one parallel instance of an operator.
- OperatorSubtaskState.Builder - Class in org.apache.flink.runtime.checkpoint
-
The builder for a new
OperatorSubtaskStatewhich can be obtained byOperatorSubtaskState.builder(). - operatorUidPathParameter - Variable in class org.apache.flink.runtime.rest.messages.job.coordination.ClientCoordinationMessageParameters
- OperatorUidPathParameter - Class in org.apache.flink.runtime.rest.messages
-
Path parameter identifying operators.
- OperatorUidPathParameter() - Constructor for class org.apache.flink.runtime.rest.messages.OperatorUidPathParameter
- optimalNumOfBits(long, double) - Static method in class org.apache.flink.runtime.operators.util.BloomFilter
-
Compute optimal bits number with given input entries and expected false positive probability.
- OPTIONAL - org.apache.flink.runtime.rest.messages.MessageParameter.MessageParameterRequisiteness
- options() - Static method in class org.apache.flink.runtime.entrypoint.ClusterConfigurationParserFactory
- options() - Static method in class org.apache.flink.runtime.entrypoint.DynamicParametersConfigurationParserFactory
- options() - Static method in class org.apache.flink.runtime.entrypoint.ModifiableClusterConfigurationParserFactory
- or(CompletableFuture<?>) - Method in class org.apache.flink.runtime.io.AvailabilityProvider.AvailabilityHelper
- or(CompletableFuture<?>, CompletableFuture<?>) - Static method in interface org.apache.flink.runtime.io.AvailabilityProvider
- or(AvailabilityProvider) - Method in class org.apache.flink.runtime.io.AvailabilityProvider.AvailabilityHelper
- order() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- org.apache.flink.runtime - package org.apache.flink.runtime
- org.apache.flink.runtime.accumulators - package org.apache.flink.runtime.accumulators
- org.apache.flink.runtime.asyncprocessing - package org.apache.flink.runtime.asyncprocessing
- org.apache.flink.runtime.asyncprocessing.operators - package org.apache.flink.runtime.asyncprocessing.operators
- org.apache.flink.runtime.blob - package org.apache.flink.runtime.blob
- org.apache.flink.runtime.blocklist - package org.apache.flink.runtime.blocklist
- org.apache.flink.runtime.broadcast - package org.apache.flink.runtime.broadcast
- org.apache.flink.runtime.checkpoint - package org.apache.flink.runtime.checkpoint
- org.apache.flink.runtime.checkpoint.channel - package org.apache.flink.runtime.checkpoint.channel
- org.apache.flink.runtime.checkpoint.filemerging - package org.apache.flink.runtime.checkpoint.filemerging
- org.apache.flink.runtime.checkpoint.hooks - package org.apache.flink.runtime.checkpoint.hooks
- org.apache.flink.runtime.checkpoint.metadata - package org.apache.flink.runtime.checkpoint.metadata
- org.apache.flink.runtime.client - package org.apache.flink.runtime.client
- org.apache.flink.runtime.clusterframework - package org.apache.flink.runtime.clusterframework
-
This package contains the cluster resource management functionality.
- org.apache.flink.runtime.clusterframework.types - package org.apache.flink.runtime.clusterframework.types
- org.apache.flink.runtime.concurrent - package org.apache.flink.runtime.concurrent
- org.apache.flink.runtime.deployment - package org.apache.flink.runtime.deployment
- org.apache.flink.runtime.dispatcher - package org.apache.flink.runtime.dispatcher
- org.apache.flink.runtime.dispatcher.cleanup - package org.apache.flink.runtime.dispatcher.cleanup
- org.apache.flink.runtime.dispatcher.runner - package org.apache.flink.runtime.dispatcher.runner
- org.apache.flink.runtime.entrypoint - package org.apache.flink.runtime.entrypoint
- org.apache.flink.runtime.entrypoint.component - package org.apache.flink.runtime.entrypoint.component
- org.apache.flink.runtime.entrypoint.parser - package org.apache.flink.runtime.entrypoint.parser
- org.apache.flink.runtime.event - package org.apache.flink.runtime.event
- org.apache.flink.runtime.execution - package org.apache.flink.runtime.execution
- org.apache.flink.runtime.execution.librarycache - package org.apache.flink.runtime.execution.librarycache
- org.apache.flink.runtime.executiongraph - package org.apache.flink.runtime.executiongraph
- org.apache.flink.runtime.executiongraph.failover - package org.apache.flink.runtime.executiongraph.failover
- org.apache.flink.runtime.executiongraph.failover.partitionrelease - package org.apache.flink.runtime.executiongraph.failover.partitionrelease
- org.apache.flink.runtime.executiongraph.metrics - package org.apache.flink.runtime.executiongraph.metrics
-
This package contains classes implementing various metrics for the job execution, based on the
Execution Graph. - org.apache.flink.runtime.externalresource - package org.apache.flink.runtime.externalresource
- org.apache.flink.runtime.failure - package org.apache.flink.runtime.failure
- org.apache.flink.runtime.filecache - package org.apache.flink.runtime.filecache
- org.apache.flink.runtime.hadoop - package org.apache.flink.runtime.hadoop
- org.apache.flink.runtime.heartbeat - package org.apache.flink.runtime.heartbeat
- org.apache.flink.runtime.highavailability - package org.apache.flink.runtime.highavailability
- org.apache.flink.runtime.highavailability.nonha - package org.apache.flink.runtime.highavailability.nonha
- org.apache.flink.runtime.highavailability.nonha.embedded - package org.apache.flink.runtime.highavailability.nonha.embedded
- org.apache.flink.runtime.highavailability.nonha.standalone - package org.apache.flink.runtime.highavailability.nonha.standalone
- org.apache.flink.runtime.highavailability.zookeeper - package org.apache.flink.runtime.highavailability.zookeeper
- org.apache.flink.runtime.history - package org.apache.flink.runtime.history
- org.apache.flink.runtime.instance - package org.apache.flink.runtime.instance
- org.apache.flink.runtime.io - package org.apache.flink.runtime.io
- org.apache.flink.runtime.io.compression - package org.apache.flink.runtime.io.compression
- org.apache.flink.runtime.io.disk - package org.apache.flink.runtime.io.disk
- org.apache.flink.runtime.io.disk.iomanager - package org.apache.flink.runtime.io.disk.iomanager
- org.apache.flink.runtime.io.network - package org.apache.flink.runtime.io.network
- org.apache.flink.runtime.io.network.api - package org.apache.flink.runtime.io.network.api
- org.apache.flink.runtime.io.network.api.reader - package org.apache.flink.runtime.io.network.api.reader
- org.apache.flink.runtime.io.network.api.serialization - package org.apache.flink.runtime.io.network.api.serialization
- org.apache.flink.runtime.io.network.api.writer - package org.apache.flink.runtime.io.network.api.writer
- org.apache.flink.runtime.io.network.buffer - package org.apache.flink.runtime.io.network.buffer
- org.apache.flink.runtime.io.network.logger - package org.apache.flink.runtime.io.network.logger
- org.apache.flink.runtime.io.network.metrics - package org.apache.flink.runtime.io.network.metrics
- org.apache.flink.runtime.io.network.netty - package org.apache.flink.runtime.io.network.netty
- org.apache.flink.runtime.io.network.netty.exception - package org.apache.flink.runtime.io.network.netty.exception
- org.apache.flink.runtime.io.network.partition - package org.apache.flink.runtime.io.network.partition
- org.apache.flink.runtime.io.network.partition.consumer - package org.apache.flink.runtime.io.network.partition.consumer
- org.apache.flink.runtime.io.network.partition.hybrid.index - package org.apache.flink.runtime.io.network.partition.hybrid.index
- org.apache.flink.runtime.io.network.partition.hybrid.tiered.common - package org.apache.flink.runtime.io.network.partition.hybrid.tiered.common
- org.apache.flink.runtime.io.network.partition.hybrid.tiered.file - package org.apache.flink.runtime.io.network.partition.hybrid.tiered.file
- org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty - package org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty
- org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle - package org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle
- org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage - package org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage
- org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier - package org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier
- org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk - package org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk
- org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory - package org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory
- org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote - package org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote
- org.apache.flink.runtime.iterative.concurrent - package org.apache.flink.runtime.iterative.concurrent
- org.apache.flink.runtime.iterative.convergence - package org.apache.flink.runtime.iterative.convergence
- org.apache.flink.runtime.iterative.event - package org.apache.flink.runtime.iterative.event
- org.apache.flink.runtime.iterative.io - package org.apache.flink.runtime.iterative.io
- org.apache.flink.runtime.iterative.task - package org.apache.flink.runtime.iterative.task
- org.apache.flink.runtime.jobgraph - package org.apache.flink.runtime.jobgraph
- org.apache.flink.runtime.jobgraph.forwardgroup - package org.apache.flink.runtime.jobgraph.forwardgroup
- org.apache.flink.runtime.jobgraph.jsonplan - package org.apache.flink.runtime.jobgraph.jsonplan
- org.apache.flink.runtime.jobgraph.tasks - package org.apache.flink.runtime.jobgraph.tasks
- org.apache.flink.runtime.jobgraph.topology - package org.apache.flink.runtime.jobgraph.topology
- org.apache.flink.runtime.jobmanager - package org.apache.flink.runtime.jobmanager
- org.apache.flink.runtime.jobmanager.scheduler - package org.apache.flink.runtime.jobmanager.scheduler
- org.apache.flink.runtime.jobmanager.slots - package org.apache.flink.runtime.jobmanager.slots
- org.apache.flink.runtime.jobmaster - package org.apache.flink.runtime.jobmaster
- org.apache.flink.runtime.jobmaster.event - package org.apache.flink.runtime.jobmaster.event
- org.apache.flink.runtime.jobmaster.factories - package org.apache.flink.runtime.jobmaster.factories
- org.apache.flink.runtime.jobmaster.slotpool - package org.apache.flink.runtime.jobmaster.slotpool
- org.apache.flink.runtime.leaderelection - package org.apache.flink.runtime.leaderelection
- org.apache.flink.runtime.leaderretrieval - package org.apache.flink.runtime.leaderretrieval
- org.apache.flink.runtime.memory - package org.apache.flink.runtime.memory
- org.apache.flink.runtime.messages - package org.apache.flink.runtime.messages
-
This package contains the messages that are sent between Flink's distributed components to coordinate the distributed operations.
- org.apache.flink.runtime.messages.checkpoint - package org.apache.flink.runtime.messages.checkpoint
-
This package contains the messages that are sent between
JobMasterandTaskExecutorto coordinate the checkpoint snapshots of the distributed dataflow. - org.apache.flink.runtime.messages.webmonitor - package org.apache.flink.runtime.messages.webmonitor
-
This package contains the actor messages that are sent between the JobManager and components that are interested in the status of the JobManager.
- org.apache.flink.runtime.metrics - package org.apache.flink.runtime.metrics
- org.apache.flink.runtime.metrics.dump - package org.apache.flink.runtime.metrics.dump
- org.apache.flink.runtime.metrics.filter - package org.apache.flink.runtime.metrics.filter
- org.apache.flink.runtime.metrics.groups - package org.apache.flink.runtime.metrics.groups
- org.apache.flink.runtime.metrics.scope - package org.apache.flink.runtime.metrics.scope
- org.apache.flink.runtime.metrics.util - package org.apache.flink.runtime.metrics.util
- org.apache.flink.runtime.minicluster - package org.apache.flink.runtime.minicluster
- org.apache.flink.runtime.net - package org.apache.flink.runtime.net
- org.apache.flink.runtime.operators - package org.apache.flink.runtime.operators
- org.apache.flink.runtime.operators.chaining - package org.apache.flink.runtime.operators.chaining
- org.apache.flink.runtime.operators.coordination - package org.apache.flink.runtime.operators.coordination
- org.apache.flink.runtime.operators.coordination.util - package org.apache.flink.runtime.operators.coordination.util
- org.apache.flink.runtime.operators.hash - package org.apache.flink.runtime.operators.hash
- org.apache.flink.runtime.operators.resettable - package org.apache.flink.runtime.operators.resettable
- org.apache.flink.runtime.operators.shipping - package org.apache.flink.runtime.operators.shipping
- org.apache.flink.runtime.operators.sort - package org.apache.flink.runtime.operators.sort
- org.apache.flink.runtime.operators.udf - package org.apache.flink.runtime.operators.udf
- org.apache.flink.runtime.operators.util - package org.apache.flink.runtime.operators.util
- org.apache.flink.runtime.operators.util.metrics - package org.apache.flink.runtime.operators.util.metrics
- org.apache.flink.runtime.persistence - package org.apache.flink.runtime.persistence
- org.apache.flink.runtime.persistence.filesystem - package org.apache.flink.runtime.persistence.filesystem
- org.apache.flink.runtime.plugable - package org.apache.flink.runtime.plugable
- org.apache.flink.runtime.query - package org.apache.flink.runtime.query
- org.apache.flink.runtime.registration - package org.apache.flink.runtime.registration
- org.apache.flink.runtime.resourcemanager - package org.apache.flink.runtime.resourcemanager
- org.apache.flink.runtime.resourcemanager.active - package org.apache.flink.runtime.resourcemanager.active
- org.apache.flink.runtime.resourcemanager.exceptions - package org.apache.flink.runtime.resourcemanager.exceptions
- org.apache.flink.runtime.resourcemanager.registration - package org.apache.flink.runtime.resourcemanager.registration
- org.apache.flink.runtime.resourcemanager.slotmanager - package org.apache.flink.runtime.resourcemanager.slotmanager
- org.apache.flink.runtime.rest - package org.apache.flink.runtime.rest
- org.apache.flink.runtime.rest.handler - package org.apache.flink.runtime.rest.handler
- org.apache.flink.runtime.rest.handler.async - package org.apache.flink.runtime.rest.handler.async
- org.apache.flink.runtime.rest.handler.cluster - package org.apache.flink.runtime.rest.handler.cluster
- org.apache.flink.runtime.rest.handler.dataset - package org.apache.flink.runtime.rest.handler.dataset
- org.apache.flink.runtime.rest.handler.job - package org.apache.flink.runtime.rest.handler.job
- org.apache.flink.runtime.rest.handler.job.checkpoints - package org.apache.flink.runtime.rest.handler.job.checkpoints
- org.apache.flink.runtime.rest.handler.job.coordination - package org.apache.flink.runtime.rest.handler.job.coordination
- org.apache.flink.runtime.rest.handler.job.metrics - package org.apache.flink.runtime.rest.handler.job.metrics
- org.apache.flink.runtime.rest.handler.job.rescaling - package org.apache.flink.runtime.rest.handler.job.rescaling
- org.apache.flink.runtime.rest.handler.job.savepoints - package org.apache.flink.runtime.rest.handler.job.savepoints
- org.apache.flink.runtime.rest.handler.legacy - package org.apache.flink.runtime.rest.handler.legacy
- org.apache.flink.runtime.rest.handler.legacy.files - package org.apache.flink.runtime.rest.handler.legacy.files
- org.apache.flink.runtime.rest.handler.legacy.messages - package org.apache.flink.runtime.rest.handler.legacy.messages
- org.apache.flink.runtime.rest.handler.legacy.metrics - package org.apache.flink.runtime.rest.handler.legacy.metrics
- org.apache.flink.runtime.rest.handler.resourcemanager - package org.apache.flink.runtime.rest.handler.resourcemanager
- org.apache.flink.runtime.rest.handler.router - package org.apache.flink.runtime.rest.handler.router
- org.apache.flink.runtime.rest.handler.taskmanager - package org.apache.flink.runtime.rest.handler.taskmanager
- org.apache.flink.runtime.rest.handler.util - package org.apache.flink.runtime.rest.handler.util
- org.apache.flink.runtime.rest.messages - package org.apache.flink.runtime.rest.messages
- org.apache.flink.runtime.rest.messages.checkpoints - package org.apache.flink.runtime.rest.messages.checkpoints
- org.apache.flink.runtime.rest.messages.cluster - package org.apache.flink.runtime.rest.messages.cluster
- org.apache.flink.runtime.rest.messages.dataset - package org.apache.flink.runtime.rest.messages.dataset
- org.apache.flink.runtime.rest.messages.job - package org.apache.flink.runtime.rest.messages.job
- org.apache.flink.runtime.rest.messages.job.coordination - package org.apache.flink.runtime.rest.messages.job.coordination
- org.apache.flink.runtime.rest.messages.job.metrics - package org.apache.flink.runtime.rest.messages.job.metrics
- org.apache.flink.runtime.rest.messages.job.savepoints - package org.apache.flink.runtime.rest.messages.job.savepoints
- org.apache.flink.runtime.rest.messages.job.savepoints.stop - package org.apache.flink.runtime.rest.messages.job.savepoints.stop
- org.apache.flink.runtime.rest.messages.json - package org.apache.flink.runtime.rest.messages.json
- org.apache.flink.runtime.rest.messages.queue - package org.apache.flink.runtime.rest.messages.queue
- org.apache.flink.runtime.rest.messages.taskmanager - package org.apache.flink.runtime.rest.messages.taskmanager
- org.apache.flink.runtime.rest.util - package org.apache.flink.runtime.rest.util
- org.apache.flink.runtime.rest.versioning - package org.apache.flink.runtime.rest.versioning
- org.apache.flink.runtime.scheduler - package org.apache.flink.runtime.scheduler
- org.apache.flink.runtime.scheduler.adapter - package org.apache.flink.runtime.scheduler.adapter
- org.apache.flink.runtime.scheduler.adaptive - package org.apache.flink.runtime.scheduler.adaptive
- org.apache.flink.runtime.scheduler.adaptive.allocator - package org.apache.flink.runtime.scheduler.adaptive.allocator
- org.apache.flink.runtime.scheduler.adaptivebatch - package org.apache.flink.runtime.scheduler.adaptivebatch
- org.apache.flink.runtime.scheduler.exceptionhistory - package org.apache.flink.runtime.scheduler.exceptionhistory
- org.apache.flink.runtime.scheduler.metrics - package org.apache.flink.runtime.scheduler.metrics
- org.apache.flink.runtime.scheduler.slowtaskdetector - package org.apache.flink.runtime.scheduler.slowtaskdetector
- org.apache.flink.runtime.scheduler.stopwithsavepoint - package org.apache.flink.runtime.scheduler.stopwithsavepoint
- org.apache.flink.runtime.scheduler.strategy - package org.apache.flink.runtime.scheduler.strategy
- org.apache.flink.runtime.security - package org.apache.flink.runtime.security
- org.apache.flink.runtime.security.contexts - package org.apache.flink.runtime.security.contexts
- org.apache.flink.runtime.security.modules - package org.apache.flink.runtime.security.modules
- org.apache.flink.runtime.security.token - package org.apache.flink.runtime.security.token
- org.apache.flink.runtime.security.token.hadoop - package org.apache.flink.runtime.security.token.hadoop
- org.apache.flink.runtime.shuffle - package org.apache.flink.runtime.shuffle
- org.apache.flink.runtime.slots - package org.apache.flink.runtime.slots
- org.apache.flink.runtime.source.coordinator - package org.apache.flink.runtime.source.coordinator
- org.apache.flink.runtime.source.event - package org.apache.flink.runtime.source.event
- org.apache.flink.runtime.state - package org.apache.flink.runtime.state
- org.apache.flink.runtime.state.changelog - package org.apache.flink.runtime.state.changelog
- org.apache.flink.runtime.state.changelog.inmemory - package org.apache.flink.runtime.state.changelog.inmemory
- org.apache.flink.runtime.state.delegate - package org.apache.flink.runtime.state.delegate
- org.apache.flink.runtime.state.filemerging - package org.apache.flink.runtime.state.filemerging
- org.apache.flink.runtime.state.filesystem - package org.apache.flink.runtime.state.filesystem
- org.apache.flink.runtime.state.hashmap - package org.apache.flink.runtime.state.hashmap
- org.apache.flink.runtime.state.heap - package org.apache.flink.runtime.state.heap
-
This package contains the classes for key/value state backends that store the state on the JVM heap as objects.
- org.apache.flink.runtime.state.internal - package org.apache.flink.runtime.state.internal
-
This package holds the classes of the internal state type hierarchy.
- org.apache.flink.runtime.state.memory - package org.apache.flink.runtime.state.memory
- org.apache.flink.runtime.state.metainfo - package org.apache.flink.runtime.state.metainfo
- org.apache.flink.runtime.state.metrics - package org.apache.flink.runtime.state.metrics
- org.apache.flink.runtime.state.restore - package org.apache.flink.runtime.state.restore
- org.apache.flink.runtime.state.storage - package org.apache.flink.runtime.state.storage
- org.apache.flink.runtime.state.ttl - package org.apache.flink.runtime.state.ttl
- org.apache.flink.runtime.state.v2 - package org.apache.flink.runtime.state.v2
- org.apache.flink.runtime.state.v2.adaptor - package org.apache.flink.runtime.state.v2.adaptor
- org.apache.flink.runtime.state.v2.internal - package org.apache.flink.runtime.state.v2.internal
- org.apache.flink.runtime.taskexecutor - package org.apache.flink.runtime.taskexecutor
- org.apache.flink.runtime.taskexecutor.exceptions - package org.apache.flink.runtime.taskexecutor.exceptions
- org.apache.flink.runtime.taskexecutor.partition - package org.apache.flink.runtime.taskexecutor.partition
- org.apache.flink.runtime.taskexecutor.rpc - package org.apache.flink.runtime.taskexecutor.rpc
- org.apache.flink.runtime.taskexecutor.slot - package org.apache.flink.runtime.taskexecutor.slot
- org.apache.flink.runtime.taskmanager - package org.apache.flink.runtime.taskmanager
- org.apache.flink.runtime.throughput - package org.apache.flink.runtime.throughput
- org.apache.flink.runtime.throwable - package org.apache.flink.runtime.throwable
- org.apache.flink.runtime.topology - package org.apache.flink.runtime.topology
- org.apache.flink.runtime.util - package org.apache.flink.runtime.util
- org.apache.flink.runtime.util.bash - package org.apache.flink.runtime.util.bash
- org.apache.flink.runtime.util.config.memory - package org.apache.flink.runtime.util.config.memory
- org.apache.flink.runtime.util.config.memory.jobmanager - package org.apache.flink.runtime.util.config.memory.jobmanager
- org.apache.flink.runtime.util.config.memory.taskmanager - package org.apache.flink.runtime.util.config.memory.taskmanager
- org.apache.flink.runtime.util.event - package org.apache.flink.runtime.util.event
- org.apache.flink.runtime.util.profiler - package org.apache.flink.runtime.util.profiler
- org.apache.flink.runtime.webmonitor - package org.apache.flink.runtime.webmonitor
- org.apache.flink.runtime.webmonitor.history - package org.apache.flink.runtime.webmonitor.history
- org.apache.flink.runtime.webmonitor.retriever - package org.apache.flink.runtime.webmonitor.retriever
- org.apache.flink.runtime.webmonitor.retriever.impl - package org.apache.flink.runtime.webmonitor.retriever.impl
- org.apache.flink.runtime.webmonitor.stats - package org.apache.flink.runtime.webmonitor.stats
- org.apache.flink.runtime.webmonitor.threadinfo - package org.apache.flink.runtime.webmonitor.threadinfo
- org.apache.flink.runtime.zookeeper - package org.apache.flink.runtime.zookeeper
- org.apache.flink.streaming.api - package org.apache.flink.streaming.api
- org.apache.flink.streaming.api.checkpoint - package org.apache.flink.streaming.api.checkpoint
- org.apache.flink.streaming.api.connector.sink2 - package org.apache.flink.streaming.api.connector.sink2
- org.apache.flink.streaming.api.datastream - package org.apache.flink.streaming.api.datastream
- org.apache.flink.streaming.api.environment - package org.apache.flink.streaming.api.environment
- org.apache.flink.streaming.api.functions - package org.apache.flink.streaming.api.functions
- org.apache.flink.streaming.api.functions.aggregation - package org.apache.flink.streaming.api.functions.aggregation
- org.apache.flink.streaming.api.functions.co - package org.apache.flink.streaming.api.functions.co
- org.apache.flink.streaming.api.functions.query - package org.apache.flink.streaming.api.functions.query
- org.apache.flink.streaming.api.functions.sink.legacy - package org.apache.flink.streaming.api.functions.sink.legacy
- org.apache.flink.streaming.api.functions.source - package org.apache.flink.streaming.api.functions.source
- org.apache.flink.streaming.api.functions.source.legacy - package org.apache.flink.streaming.api.functions.source.legacy
- org.apache.flink.streaming.api.functions.windowing - package org.apache.flink.streaming.api.functions.windowing
- org.apache.flink.streaming.api.graph - package org.apache.flink.streaming.api.graph
- org.apache.flink.streaming.api.lineage - package org.apache.flink.streaming.api.lineage
- org.apache.flink.streaming.api.operators - package org.apache.flink.streaming.api.operators
- org.apache.flink.streaming.api.operators.co - package org.apache.flink.streaming.api.operators.co
- org.apache.flink.streaming.api.operators.collect - package org.apache.flink.streaming.api.operators.collect
- org.apache.flink.streaming.api.operators.legacy - package org.apache.flink.streaming.api.operators.legacy
- org.apache.flink.streaming.api.operators.sort - package org.apache.flink.streaming.api.operators.sort
- org.apache.flink.streaming.api.operators.sorted.state - package org.apache.flink.streaming.api.operators.sorted.state
- org.apache.flink.streaming.api.operators.sortpartition - package org.apache.flink.streaming.api.operators.sortpartition
- org.apache.flink.streaming.api.operators.source - package org.apache.flink.streaming.api.operators.source
- org.apache.flink.streaming.api.operators.util - package org.apache.flink.streaming.api.operators.util
- org.apache.flink.streaming.api.transformations - package org.apache.flink.streaming.api.transformations
- org.apache.flink.streaming.api.watermark - package org.apache.flink.streaming.api.watermark
- org.apache.flink.streaming.api.windowing.assigners - package org.apache.flink.streaming.api.windowing.assigners
- org.apache.flink.streaming.api.windowing.evictors - package org.apache.flink.streaming.api.windowing.evictors
- org.apache.flink.streaming.api.windowing.triggers - package org.apache.flink.streaming.api.windowing.triggers
- org.apache.flink.streaming.api.windowing.windows - package org.apache.flink.streaming.api.windowing.windows
- org.apache.flink.streaming.runtime.io - package org.apache.flink.streaming.runtime.io
- org.apache.flink.streaming.runtime.io.checkpointing - package org.apache.flink.streaming.runtime.io.checkpointing
- org.apache.flink.streaming.runtime.io.recovery - package org.apache.flink.streaming.runtime.io.recovery
- org.apache.flink.streaming.runtime.metrics - package org.apache.flink.streaming.runtime.metrics
- org.apache.flink.streaming.runtime.operators - package org.apache.flink.streaming.runtime.operators
- org.apache.flink.streaming.runtime.operators.asyncprocessing - package org.apache.flink.streaming.runtime.operators.asyncprocessing
- org.apache.flink.streaming.runtime.operators.sink - package org.apache.flink.streaming.runtime.operators.sink
- org.apache.flink.streaming.runtime.operators.sink.committables - package org.apache.flink.streaming.runtime.operators.sink.committables
- org.apache.flink.streaming.runtime.operators.util - package org.apache.flink.streaming.runtime.operators.util
- org.apache.flink.streaming.runtime.operators.windowing - package org.apache.flink.streaming.runtime.operators.windowing
- org.apache.flink.streaming.runtime.operators.windowing.functions - package org.apache.flink.streaming.runtime.operators.windowing.functions
- org.apache.flink.streaming.runtime.partitioner - package org.apache.flink.streaming.runtime.partitioner
- org.apache.flink.streaming.runtime.streamrecord - package org.apache.flink.streaming.runtime.streamrecord
- org.apache.flink.streaming.runtime.tasks - package org.apache.flink.streaming.runtime.tasks
- org.apache.flink.streaming.runtime.tasks.mailbox - package org.apache.flink.streaming.runtime.tasks.mailbox
- org.apache.flink.streaming.runtime.translators - package org.apache.flink.streaming.runtime.translators
- org.apache.flink.streaming.runtime.watermarkstatus - package org.apache.flink.streaming.runtime.watermarkstatus
- org.apache.flink.streaming.util - package org.apache.flink.streaming.util
- org.apache.flink.streaming.util.functions - package org.apache.flink.streaming.util.functions
- org.apache.flink.streaming.util.graph - package org.apache.flink.streaming.util.graph
- org.apache.flink.streaming.util.keys - package org.apache.flink.streaming.util.keys
- org.apache.flink.streaming.util.typeutils - package org.apache.flink.streaming.util.typeutils
- originalGateway - Variable in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- OutboundChannelHandlerFactory - Interface in org.apache.flink.runtime.io.network.netty
-
Custom netty outbound handler factory in order to make custom changes on netty outbound data.
- outerJoinIterator - Variable in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
- output - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The collector that forwards the user code's results.
- output - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- output - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context
-
Emits a record to the side output identified by the
OutputTag. - output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.Context
-
Emits a record to the side output identified by the
OutputTag. - output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.co.ProcessJoinFunction.Context
-
Emits a record to the side output identified by the
OutputTag. - output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
-
Emits a record to the side output identified by the
OutputTag. - output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.ProcessFunction.Context
-
Emits a record to the side output identified by the
OutputTag. - output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyAllWindowContext
- output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
- output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
-
Emits a record to the side output identified by the
OutputTag. - output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
-
Emits a record to the side output identified by the
OutputTag. - output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessAllWindowContext
- output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
- output(OutputTag<X>, X) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
- output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
- Output<T> - Interface in org.apache.flink.streaming.api.operators
-
A
StreamOperatoris supplied with an object of this interface that can be used to emit elements and other messages, such as barriers and watermarks, from an operator. - OutputBufferPoolUsageGauge - Class in org.apache.flink.runtime.io.network.metrics
-
Gauge metric measuring the output buffer pool usage gauge for
ResultPartitions. - OutputBufferPoolUsageGauge(ResultPartition[]) - Constructor for class org.apache.flink.runtime.io.network.metrics.OutputBufferPoolUsageGauge
- OutputBuffersGauge - Class in org.apache.flink.runtime.io.network.metrics
-
Gauge metric measuring the number of queued output buffers for
ResultPartitions. - OutputBuffersGauge(ResultPartition[]) - Constructor for class org.apache.flink.runtime.io.network.metrics.OutputBuffersGauge
- OutputBuffersSizeGauge - Class in org.apache.flink.runtime.io.network.metrics
-
Gauge metric measuring the size in bytes of queued output buffers for
ResultPartitions. - OutputBuffersSizeGauge(ResultPartition[]) - Constructor for class org.apache.flink.runtime.io.network.metrics.OutputBuffersSizeGauge
- outputCollector - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
- OutputCollector<T> - Class in org.apache.flink.runtime.operators.shipping
-
The OutputCollector collects records, and emits them to the
RecordWriters. - OutputCollector(List<RecordWriter<SerializationDelegate<T>>>, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.operators.shipping.OutputCollector
-
Initializes the output collector with a set of writers.
- OutputEmitter<T> - Class in org.apache.flink.runtime.operators.shipping
-
The output emitter decides to which of the possibly multiple output channels a record is sent.
- OutputEmitter(ShipStrategyType, int) - Constructor for class org.apache.flink.runtime.operators.shipping.OutputEmitter
-
Creates a new channel selector that uses the given strategy (broadcasting, partitioning, ...)
- OutputEmitter(ShipStrategyType, int, TypeComparator<T>, Partitioner<?>, DataDistribution) - Constructor for class org.apache.flink.runtime.operators.shipping.OutputEmitter
- OutputEmitter(ShipStrategyType, TypeComparator<T>) - Constructor for class org.apache.flink.runtime.operators.shipping.OutputEmitter
-
Creates a new channel selector that uses the given strategy (broadcasting, partitioning, ...)
- OutputFormatOperatorFactory<IN,OUT> - Interface in org.apache.flink.streaming.api.operators
-
Interface for operator factories which create the sink operator containing an
OutputFormat. - OutputFormatSinkFunction<IN> - Class in org.apache.flink.streaming.api.functions.sink.legacy
-
Deprecated.Please use the
StreamingFileSinkfor writing to files from a streaming program. - OutputFormatSinkFunction(OutputFormat<IN>) - Constructor for class org.apache.flink.streaming.api.functions.sink.legacy.OutputFormatSinkFunction
-
Deprecated.
- OutputWithChainingCheck<OUT> - Interface in org.apache.flink.streaming.runtime.tasks
-
This is a wrapper for outputs to check whether the collected record has been emitted to a downstream subtask or to a chained operator.
- overflowSegments - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
- overflowSegments - Variable in class org.apache.flink.runtime.operators.hash.InMemoryPartition
- overrideRestoreModeForChangelogStateBackend() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- overwriteRecordAt(long, T) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
Deprecated.Don't use this, overwrites record and causes inconsistency or data loss for overwriting everything but records of the exact same size
- OwnedTaskLocalStateStore - Interface in org.apache.flink.runtime.state
-
This interface represents the administrative interface to
TaskLocalStateStore, that only the owner of the object should see. - owningStateMap - Variable in class org.apache.flink.runtime.state.heap.StateMapSnapshot
-
The
StateMapfrom which this snapshot was created.
P
- p75 - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
- p90 - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
- p95 - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
- p98 - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
- p99 - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
- p999 - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
- PACT - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
- PAGE_SIZE_UNKNOWN - Static variable in class org.apache.flink.runtime.io.network.partition.PageSizeUtil
-
Value indicating an unknown page size.
- PageSizeUtil - Class in org.apache.flink.runtime.io.network.partition
-
Utility for accessing the system page size.
- pairComparator - Variable in class org.apache.flink.runtime.operators.hash.AbstractHashTableProber
- pairComparator - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
- PARALLEL_BETWEEN_EPOCH - org.apache.flink.runtime.asyncprocessing.EpochManager.ParallelMode
-
Subsequent epochs can begin execution even if the previous epoch has not yet completed.
- Parallelism(int, int) - Constructor for class org.apache.flink.runtime.jobgraph.JobVertexResourceRequirements.Parallelism
- PARALLELISM - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
- PARALLELISM_AUTO_MAX - Static variable in class org.apache.flink.runtime.scheduler.DefaultVertexParallelismInfo
-
The constant to use for the parallelism, if the system should use the number of currently available slots.
- ParallelismAndInputInfos - Class in org.apache.flink.runtime.executiongraph
-
The parallelism and
JobVertexInputInfos of a job vertex . - ParallelismAndInputInfos(int, Map<IntermediateDataSetID, JobVertexInputInfo>) - Constructor for class org.apache.flink.runtime.executiongraph.ParallelismAndInputInfos
- ParallelSourceFunction<OUT> - Interface in org.apache.flink.streaming.api.functions.source.legacy
-
Deprecated.This interface is based on the
SourceFunctionAPI, which is due to be removed. Use the newSourceAPI instead. - param(String) - Method in class org.apache.flink.runtime.rest.handler.router.RouteResult
-
Extracts the param in
pathParamsfirst, then falls back to the first matching param inqueryParams. - params(String) - Method in class org.apache.flink.runtime.rest.handler.router.RouteResult
-
Extracts all params in
pathParamsandqueryParamsmatching the name. - parent - Variable in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
The parent partition this subpartition belongs to.
- parent - Variable in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
The parent group containing this group.
- parent() - Method in class org.apache.flink.runtime.metrics.groups.JobManagerJobMetricGroup
- parent() - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
- parent() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
- parentMetricGroup - Variable in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
- parse(String[]) - Method in class org.apache.flink.runtime.entrypoint.parser.CommandLineParser
- parseArguments(String[]) - Static method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
- parseBufferHeader(ByteBuffer) - Static method in class org.apache.flink.runtime.io.network.partition.BufferReaderWriterUtil
- parseDynamicProperties(CommandLine) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Parse the dynamic properties (passed on the command line).
- parseEvent(Buffer) - Method in class org.apache.flink.runtime.io.network.partition.consumer.ChannelStatePersister
-
Parses the buffer as an event and returns the
CheckpointBarrierif the event is indeed a barrier or returns null in all other cases. - parseParametersOrExit(String[], ParserResultFactory<T>, Class<?>) - Static method in class org.apache.flink.runtime.entrypoint.ClusterEntrypointUtils
-
Parses passed String array using the parameter definitions of the passed
ParserResultFactory. - parseRestBindPortFromWebInterfaceUrl(String) - Static method in class org.apache.flink.runtime.util.ResourceManagerUtils
-
Parse the port from the webInterfaceUrl.
- ParserResultFactory<T> - Interface in org.apache.flink.runtime.entrypoint.parser
-
Parser result factory used by the
CommandLineParser. - PARTIAL_RECORD - org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
- PartialDispatcherServices - Class in org.apache.flink.runtime.dispatcher
-
Partial
DispatcherServicesservices container which needs to be completed before being given to theDispatcher. - PartialDispatcherServices(Configuration, HighAvailabilityServices, GatewayRetriever<ResourceManagerGateway>, BlobServer, HeartbeatServices, JobManagerMetricGroupFactory, ExecutionGraphInfoStore, FatalErrorHandler, HistoryServerArchivist, String, Executor, DispatcherOperationCaches, Collection<FailureEnricher>) - Constructor for class org.apache.flink.runtime.dispatcher.PartialDispatcherServices
- PartialDispatcherServicesWithJobPersistenceComponents - Class in org.apache.flink.runtime.dispatcher
-
DispatcherFactoryservices container. - PartialFinishedInputConsumableDecider - Class in org.apache.flink.runtime.scheduler.strategy
-
PartialFinishedInputConsumableDecideris a specialInputConsumableDecider. - PartialFinishedInputConsumableDecider() - Constructor for class org.apache.flink.runtime.scheduler.strategy.PartialFinishedInputConsumableDecider
- PartialFinishedInputConsumableDecider.Factory - Class in org.apache.flink.runtime.scheduler.strategy
-
Factory for
PartialFinishedInputConsumableDecider. - PartialFinishingNotSupportedByStateException(String) - Constructor for exception org.apache.flink.runtime.checkpoint.FinishedTaskStateProvider.PartialFinishingNotSupportedByStateException
- PartialFinishingNotSupportedByStateException(String, Throwable) - Constructor for exception org.apache.flink.runtime.checkpoint.FinishedTaskStateProvider.PartialFinishingNotSupportedByStateException
- PartialFinishingNotSupportedByStateException(Throwable) - Constructor for exception org.apache.flink.runtime.checkpoint.FinishedTaskStateProvider.PartialFinishingNotSupportedByStateException
- PartialOrderPriorityQueue<T> - Class in org.apache.flink.runtime.operators.sort
-
This class implements a priority-queue, which maintains a partial ordering of its elements such that the least element can always be found in constant time.
- PartialOrderPriorityQueue(Comparator<T>, int) - Constructor for class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
- PARTITION_CUSTOM - org.apache.flink.runtime.operators.shipping.ShipStrategyType
-
Partitioning using a custom partitioner.
- PARTITION_FORCED_REBALANCE - org.apache.flink.runtime.operators.shipping.ShipStrategyType
-
Partitioning the data evenly, forced at a specific location (cannot be pushed down by optimizer).
- PARTITION_HASH - org.apache.flink.runtime.operators.shipping.ShipStrategyType
-
Repartitioning the data deterministically through a hash function.
- PARTITION_RANDOM - org.apache.flink.runtime.operators.shipping.ShipStrategyType
-
Repartitioning the data randomly, typically when the parallelism between two nodes changes.
- PARTITION_RANGE - org.apache.flink.runtime.operators.shipping.ShipStrategyType
-
Partitioning the data in ranges according to a total order.
- PartitionableListState<S> - Class in org.apache.flink.runtime.state
-
Implementation of operator list state.
- PartitionAggregateOperator<IN,ACC,OUT> - Class in org.apache.flink.streaming.api.operators
-
The
PartitionAggregateOperatoris used to apply the aggregate transformation on all records of each partition. - PartitionAggregateOperator(AggregateFunction<IN, ACC, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.PartitionAggregateOperator
- partitionBuffers - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
- partitionByKeyGroup() - Method in class org.apache.flink.runtime.state.KeyGroupPartitioner
-
Partitions the data into key-groups and returns the result as a
KeyGroupPartitioner.PartitioningResult. - PartitionConnectionException - Exception in org.apache.flink.runtime.io.network.partition.consumer
-
Exception for failed partition requests due to connection failure with unreachable producer.
- PartitionConnectionException(ResultPartitionID, Throwable) - Constructor for exception org.apache.flink.runtime.io.network.partition.consumer.PartitionConnectionException
- partitionCustom(Partitioner<K>, KeySelector<T, K>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Partitions a DataStream on the key returned by the selector, using a custom partitioner.
- PartitionDataMissingError - org.apache.flink.runtime.throwable.ThrowableType
-
Data consumption error, which indicates that we should revoke the producer.
- PartitionDescriptor - Class in org.apache.flink.runtime.shuffle
-
Partition descriptor for
ShuffleMasterto obtainShuffleDescriptor. - PartitionDescriptor(IntermediateDataSetID, int, IntermediateResultPartitionID, ResultPartitionType, int, int, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.shuffle.PartitionDescriptor
- PartitionedFile - Class in org.apache.flink.runtime.io.network.partition
-
PartitionedFileis the persistent file type of sort-merge based blocking shuffle. - PartitionedFile(int, int, Path, Path, long, long, long, ByteBuffer) - Constructor for class org.apache.flink.runtime.io.network.partition.PartitionedFile
- PartitionedFileWriter - Class in org.apache.flink.runtime.io.network.partition
-
File writer which can write buffers and generate
PartitionedFile. - PartitionedFileWriter(int, int, String) - Constructor for class org.apache.flink.runtime.io.network.partition.PartitionedFileWriter
- PartitionException - Exception in org.apache.flink.runtime.io.network.partition
-
Exception for covering all the scenarios of consuming partition failure which causes the consumer task failed, and the job master would decide whether to restart the producer based on this exception.
- PartitionException(String, ResultPartitionID) - Constructor for exception org.apache.flink.runtime.io.network.partition.PartitionException
- PartitionException(String, ResultPartitionID, Throwable) - Constructor for exception org.apache.flink.runtime.io.network.partition.PartitionException
- PartitionFileReader - Interface in org.apache.flink.runtime.io.network.partition.hybrid.tiered.file
-
PartitionFileReaderdefines the read logic for different types of shuffle files. - PartitionFileReader.ReadBufferResult - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.file
-
A wrapper class of the reading buffer result, including the read buffers, the hint of continue reading, and the read progress, etc.
- PartitionFileReader.ReadProgress - Interface in org.apache.flink.runtime.io.network.partition.hybrid.tiered.file
-
This
PartitionFileReader.ReadProgressdefines the read progress of thePartitionFileReader. - PartitionFileWriter - Interface in org.apache.flink.runtime.io.network.partition.hybrid.tiered.file
-
The
PartitionFileWriterinterface defines the write logic for different types of shuffle files. - PartitionFileWriter.SegmentBufferContext - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.file
-
The
PartitionFileWriter.SegmentBufferContextcontains all the buffers belonging to the segment. - PartitionFileWriter.SubpartitionBufferContext - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.file
-
The
PartitionFileWriter.SubpartitionBufferContextcontains all the buffers belonging to one subpartition. - partitionFinished() - Method in class org.apache.flink.runtime.scheduler.strategy.ConsumedPartitionGroup
- PartitionGroupReleaseStrategy - Interface in org.apache.flink.runtime.executiongraph.failover.partitionrelease
-
Interface for strategies that decide when to release
ConsumedPartitionGroups. - PartitionGroupReleaseStrategy.Factory - Interface in org.apache.flink.runtime.executiongraph.failover.partitionrelease
-
Factory for
PartitionGroupReleaseStrategy. - PartitionGroupReleaseStrategyFactoryLoader - Class in org.apache.flink.runtime.executiongraph.failover.partitionrelease
-
Instantiates a
RegionPartitionGroupReleaseStrategy. - partitionId - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
The parent partition of the subpartitions consumed by this channel.
- partitionId - Variable in class org.apache.flink.runtime.io.network.partition.ResultPartition
- PartitionInfo - Class in org.apache.flink.runtime.executiongraph
-
Contains information where to find a partition.
- PartitionInfo(IntermediateDataSetID, ShuffleDescriptor) - Constructor for class org.apache.flink.runtime.executiongraph.PartitionInfo
- partitionInfos - Variable in class org.apache.flink.runtime.io.network.partition.AbstractPartitionTracker
- partitionManager - Variable in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGateFactory
- partitionManager - Variable in class org.apache.flink.runtime.io.network.partition.ResultPartition
- PartitionNotFoundException - Exception in org.apache.flink.runtime.io.network.partition
-
Exception for failed partition requests due to non-existing partitions.
- PartitionNotFoundException(ResultPartitionID) - Constructor for exception org.apache.flink.runtime.io.network.partition.PartitionNotFoundException
- PartitionProducerDisposedException - Exception in org.apache.flink.runtime.jobmanager
-
Exception returned to a TaskManager on JobMaster requesting partition state, if the producer of a partition has been disposed.
- PartitionProducerDisposedException(ResultPartitionID) - Constructor for exception org.apache.flink.runtime.jobmanager.PartitionProducerDisposedException
- PartitionProducerStateChecker - Interface in org.apache.flink.runtime.taskexecutor
-
Intermediate partition state checker to query the JobManager about the state of the producer of a result partition.
- PartitionProducerStateProvider - Interface in org.apache.flink.runtime.io.network.partition
-
Request execution state of partition producer, the response accepts state check callbacks.
- PartitionProducerStateProvider.ResponseHandle - Interface in org.apache.flink.runtime.io.network.partition
-
Result of state query, accepts state check callbacks.
- PartitionReduceOperator<IN> - Class in org.apache.flink.streaming.api.operators
-
The
PartitionReduceOperatoris used to apply the reduce transformation on all records of each partition. - PartitionReduceOperator(ReduceFunction<IN>) - Constructor for class org.apache.flink.streaming.api.operators.PartitionReduceOperator
- PartitionRequestClient - Interface in org.apache.flink.runtime.io.network
-
Client to send messages or task events via network for
RemoteInputChannel. - partitionRequestInitialBackoff - Variable in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGateFactory
- partitionRequestInitialBackoff() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- PartitionRequestListener - Interface in org.apache.flink.runtime.io.network.partition
-
When the netty server receives a downstream task's partition request event and finds its upstream task doesn't register its partition yet, the netty server will construct a
PartitionRequestListenerand notify the listener when the task deploys itself and registers its partition toResultPartitionManager. - PartitionRequestListenerManager - Class in org.apache.flink.runtime.io.network.partition
-
Manages partition request listener with input channel id.
- PartitionRequestListenerManager() - Constructor for class org.apache.flink.runtime.io.network.partition.PartitionRequestListenerManager
- partitionRequestListenerTimeout - Variable in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGateFactory
- partitionRequestMaxBackoff - Variable in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGateFactory
- partitionRequestMaxBackoff() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- partitionsBeingBuilt - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The partitions that are built by processing the current partition.
- partitionTable - Variable in class org.apache.flink.runtime.io.network.partition.AbstractPartitionTracker
- PartitionTable<K> - Class in org.apache.flink.runtime.taskexecutor.partition
-
Thread-safe Utility for tracking partitions.
- PartitionTable() - Constructor for class org.apache.flink.runtime.taskexecutor.partition.PartitionTable
- PartitionTracker<K,M> - Interface in org.apache.flink.runtime.io.network.partition
-
Utility for tracking partitions.
- PartitionTrackerEntry<K,M> - Class in org.apache.flink.runtime.io.network.partition
-
Encapsulates all information that a
PartitionTrackerkeeps for a partition. - PartitionTrackerFactory - Interface in org.apache.flink.runtime.io.network.partition
-
Factory for
JobMasterPartitionTracker. - PartitionTrackerFactory.TaskExecutorGatewayLookup - Interface in org.apache.flink.runtime.io.network.partition
-
Lookup function for
TaskExecutorGateway. - PartitionTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This transformation represents a change of partitioning of the input elements.
- PartitionTransformation(Transformation<T>, StreamPartitioner<T>) - Constructor for class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
Creates a new
PartitionTransformationfrom the given input andStreamPartitioner. - PartitionTransformation(Transformation<T>, StreamPartitioner<T>, StreamExchangeMode) - Constructor for class org.apache.flink.streaming.api.transformations.PartitionTransformation
-
Creates a new
PartitionTransformationfrom the given input andStreamPartitioner. - PartitionTransformationTranslator<OUT> - Class in org.apache.flink.streaming.runtime.translators
-
A
TransformationTranslatorfor thePartitionTransformation. - PartitionTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.PartitionTransformationTranslator
- partitionType - Variable in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Type of this partition.
- partitionUnfinished() - Method in class org.apache.flink.runtime.scheduler.strategy.ConsumedPartitionGroup
- PartitionUpdateException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
-
Exception indicating a problem with the result partitions on the
TaskExecutorside. - PartitionUpdateException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.PartitionUpdateException
- PartitionUpdateException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.PartitionUpdateException
- PartitionUpdateException(Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.PartitionUpdateException
- PartitionWindowedStream<T> - Interface in org.apache.flink.streaming.api.datastream
-
PartitionWindowedStreamrepresents a data stream that collects all records of each partition separately into a full window. - PartitionWithMetrics - Interface in org.apache.flink.runtime.shuffle
-
Interface representing the description and metrics of a result partition.
- PASS_THROUGH - org.apache.flink.streaming.api.graph.StreamConfig.InputRequirement
-
Records from
StreamConfig.InputRequirement.PASS_THROUGHinputs are passed to the operator before passing any records fromStreamConfig.InputRequirement.SORTEDinputs. - PassThroughAllWindowFunction<W extends Window,T> - Class in org.apache.flink.streaming.api.functions.windowing
-
A
AllWindowFunctionthat just emits each input element. - PassThroughAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.PassThroughAllWindowFunction
- PassThroughWindowFunction<K,W extends Window,T> - Class in org.apache.flink.streaming.api.functions.windowing
-
A
WindowFunctionthat just emits each input element. - PassThroughWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.PassThroughWindowFunction
- PATCH - org.apache.flink.runtime.rest.HttpMethodWrapper
- pathParams() - Method in class org.apache.flink.runtime.rest.handler.router.RouteResult
-
Returns all params embedded in the request path.
- PausableRelativeClock - Class in org.apache.flink.streaming.api.operators.util
-
A
RelativeClockwhose time progress with respect to the wall clock can be paused and un-paused. - PausableRelativeClock(Clock) - Constructor for class org.apache.flink.streaming.api.operators.util.PausableRelativeClock
- pause() - Method in class org.apache.flink.streaming.api.operators.util.PausableRelativeClock
- pauseMeasurement() - Method in class org.apache.flink.runtime.throughput.ThroughputCalculator
-
Mark when the time should not be taken into account.
- pauseOrResumeSplits(Collection<String>, Collection<String>) - Method in class org.apache.flink.streaming.api.operators.source.NoOpTimestampsAndWatermarks
- pauseOrResumeSplits(Collection<String>, Collection<String>) - Method in class org.apache.flink.streaming.api.operators.source.ProgressiveTimestampsAndWatermarks
- pauseOrResumeSplits(Collection<String>, Collection<String>) - Method in interface org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks
- peek() - Method in class org.apache.flink.runtime.io.network.partition.DeduplicatedQueue
- peek() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyPayloadManager
- peek() - Method in class org.apache.flink.runtime.io.network.partition.PrioritizedDeque
-
Returns the first priority element or non-priority element if the former does not exist.
- peek() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
-
Returns the least element of the PriorityQueue in constant time, but does not remove it from the priority queue.
- peek() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
- peek() - Method in class org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
- peek() - Method in interface org.apache.flink.runtime.state.InternalPriorityQueue
-
Retrieves, but does not remove, the element (w.r.t. order) of this set, or returns
nullif this set is empty. - peek() - Method in class org.apache.flink.streaming.runtime.watermarkstatus.HeapPriorityQueue
- peekLast() - Method in class org.apache.flink.runtime.io.network.partition.PrioritizedDeque
-
Returns the last non-priority element or priority element if the former does not exist.
- peekNextBufferSubpartitionId() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
- peekNextBufferSubpartitionId() - Method in class org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionDirectTransferReader
- peekNextBufferSubpartitionId() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Returns the index of the subpartition where the next buffer locates, or -1 if there is no buffer available and the subpartition to be consumed is not determined.
- peekNextBufferSubpartitionId() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyConnectionReader
-
Returns the index of the subpartition where the next buffer locates, or -1 if there is no buffer available and the subpartition to be consumed is not determined.
- peekNextBufferSubpartitionId() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyConnectionReaderImpl
- peekNextBufferSubpartitionId() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.TieredStorageResultSubpartitionView
- peekNextBufferSubpartitionId() - Method in class org.apache.flink.runtime.io.network.partition.NoOpResultSubpartitionView
- peekNextBufferSubpartitionId() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartitionView
- peekNextBufferSubpartitionId() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
-
Returns the index of the subpartition where the next buffer locates, or -1 if there is no buffer available and the subpartition to be consumed is not determined.
- peekNextBufferSubpartitionId() - Method in class org.apache.flink.runtime.io.network.partition.UnionResultSubpartitionView
- peekNextBufferSubpartitionId(TieredStoragePartitionId, ResultSubpartitionIndexSet) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageConsumerClient
-
Returns the index of the subpartition where the next buffer locates, or -1 if there is no buffer available or the subpartition index does not belong to the specified indexSet.
- peekNextBufferSubpartitionId(TieredStoragePartitionId, ResultSubpartitionIndexSet) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskTierConsumerAgent
- peekNextBufferSubpartitionId(TieredStoragePartitionId, ResultSubpartitionIndexSet) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory.MemoryTierConsumerAgent
- peekNextBufferSubpartitionId(TieredStoragePartitionId, ResultSubpartitionIndexSet) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierConsumerAgent
- peekNextBufferSubpartitionId(TieredStoragePartitionId, ResultSubpartitionIndexSet) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierConsumerAgent
-
Returns the index of the subpartition where the next buffer locates, or -1 if there is no buffer available or the subpartition index does not belong to the specified indexSet.
- peekNextBufferSubpartitionIdInternal() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Returns the index of the subpartition where the next buffer locates, or -1 if there is no buffer available and the subpartition to be consumed is not determined.
- peekNextBufferSubpartitionIdInternal() - Method in class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
- peekNextBufferSubpartitionIdInternal() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RecoveredInputChannel
- peekNextBufferSubpartitionIdInternal() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- PENDING - org.apache.flink.runtime.jobmaster.ExecutionDeploymentState
-
The deployment has or is about to be started.
- PENDING_BYTES - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- PENDING_COMMITTABLES - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- PENDING_RECORDS - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- PendingCheckpoint - Class in org.apache.flink.runtime.checkpoint
-
A pending checkpoint is a checkpoint that has been started, but has not been acknowledged by all tasks that need to acknowledge it.
- PendingCheckpoint(JobID, long, long, CheckpointPlan, Collection<OperatorID>, Collection<String>, CheckpointProperties, CompletableFuture<CompletedCheckpoint>, PendingCheckpointStats, CompletableFuture<Void>) - Constructor for class org.apache.flink.runtime.checkpoint.PendingCheckpoint
- PendingCheckpoint.PendingCheckpointDiscardObject - Class in org.apache.flink.runtime.checkpoint
-
Implementation of
Checkpoint.DiscardObjectforPendingCheckpoint. - PendingCheckpoint.TaskAcknowledgeResult - Enum in org.apache.flink.runtime.checkpoint
-
Result of the
PendingCheckpoint.acknowledgedTasksmethod. - PendingCheckpointDiscardObject() - Constructor for class org.apache.flink.runtime.checkpoint.PendingCheckpoint.PendingCheckpointDiscardObject
- PendingCheckpointStatistics(long, CheckpointStatsStatus, boolean, String, long, long, long, long, long, long, long, long, int, int, CheckpointStatistics.RestAPICheckpointType, Map<JobVertexID, TaskCheckpointStatistics>) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.PendingCheckpointStatistics
- PendingCheckpointStats - Class in org.apache.flink.runtime.checkpoint
-
Statistics for a pending checkpoint that is still in progress.
- pendingRequests - Variable in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator
-
In progress samples.
- PendingStatsRequest(int, Collection<? extends Set<ExecutionAttemptID>>) - Constructor for class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator.PendingStatsRequest
-
Creates new
TaskStatsRequestCoordinator.PendingStatsRequest. - PendingSubtaskCheckpointStatistics(int) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.PendingSubtaskCheckpointStatistics
- PendingTaskManager - Class in org.apache.flink.runtime.resourcemanager.slotmanager
-
Represents a pending task manager in the
SlotManager. - PendingTaskManager(ResourceProfile, int) - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.PendingTaskManager
- PendingTaskManagerId - Class in org.apache.flink.runtime.resourcemanager.slotmanager
-
Id of
PendingTaskManager. - pendingTasks - Variable in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator.PendingStatsRequest
-
All tasks what did not yet return a result.
- perform(Path, long) - Method in interface org.apache.flink.runtime.checkpoint.filemerging.PhysicalFile.PhysicalFileDeleter
-
Delete the file.
- perform(FileMergingSnapshotManager.SubtaskKey, CheckpointedStateScope) - Method in interface org.apache.flink.runtime.checkpoint.filemerging.PhysicalFile.PhysicalFileCreator
-
Create the file.
- PERIODIC_SCHEDULER_SHUTDOWN - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- PeriodTimer - Interface in org.apache.flink.streaming.runtime.tasks.mailbox
-
Interface for the measurement of the period of time.
- PerJobCheckpointRecoveryFactory<T extends CompletedCheckpointStore> - Class in org.apache.flink.runtime.checkpoint
-
Simple
CheckpointRecoveryFactorywhich creates and keeps separateCompletedCheckpointStoreandCheckpointIDCounterfor eachJobID. - PerJobCheckpointRecoveryFactory(PerJobCheckpointRecoveryFactory.CheckpointStoreRecoveryHelper<T>) - Constructor for class org.apache.flink.runtime.checkpoint.PerJobCheckpointRecoveryFactory
- PerJobCheckpointRecoveryFactory(PerJobCheckpointRecoveryFactory.CheckpointStoreRecoveryHelper<T>, Supplier<CheckpointIDCounter>) - Constructor for class org.apache.flink.runtime.checkpoint.PerJobCheckpointRecoveryFactory
- PerJobCheckpointRecoveryFactory.CheckpointStoreRecoveryHelper<StoreType extends CompletedCheckpointStore> - Interface in org.apache.flink.runtime.checkpoint
-
Restores or creates a
CompletedCheckpointStore, optionally using an existing one. - permanent(Path) - Static method in class org.apache.flink.runtime.state.SnapshotDirectory
-
Creates a permanent snapshot directory for the given path, which will not delete the underlying directory in
SnapshotDirectory.cleanup()afterSnapshotDirectory.completeSnapshotAndGetHandle()was called. - PermanentBlobCache - Class in org.apache.flink.runtime.blob
-
Provides a cache for permanent BLOB files including a per-job ref-counting and a staged cleanup.
- PermanentBlobCache(Configuration, File, BlobView, InetSocketAddress) - Constructor for class org.apache.flink.runtime.blob.PermanentBlobCache
- PermanentBlobCache(Configuration, File, BlobView, InetSocketAddress, BlobCacheSizeTracker) - Constructor for class org.apache.flink.runtime.blob.PermanentBlobCache
- PermanentBlobCache(Configuration, Reference<File>, BlobView, InetSocketAddress) - Constructor for class org.apache.flink.runtime.blob.PermanentBlobCache
-
Instantiates a new cache for permanent BLOBs which are also available in an HA store.
- PermanentBlobCache(Configuration, Reference<File>, BlobView, InetSocketAddress, BlobCacheSizeTracker) - Constructor for class org.apache.flink.runtime.blob.PermanentBlobCache
- PermanentBlobKey - Class in org.apache.flink.runtime.blob
-
BLOB key referencing permanent BLOB files.
- PermanentBlobKey() - Constructor for class org.apache.flink.runtime.blob.PermanentBlobKey
-
Constructs a new BLOB key.
- PermanentBlobService - Interface in org.apache.flink.runtime.blob
-
A service to retrieve permanent binary large objects (BLOBs).
- persist() - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
-
Persist the updated mapping to the given state if the mapping changed since initialization.
- persist(SequenceNumber, long) - Method in interface org.apache.flink.runtime.state.changelog.StateChangelogWriter
-
Durably persist previously
appendeddata starting from the providedSequenceNumberand up to the latest change added. - persistAllocationSnapshot(SlotAllocationSnapshot) - Method in class org.apache.flink.runtime.taskexecutor.slot.FileSlotAllocationSnapshotPersistenceService
- persistAllocationSnapshot(SlotAllocationSnapshot) - Method in enum org.apache.flink.runtime.taskexecutor.slot.NoOpSlotAllocationSnapshotPersistenceService
- persistAllocationSnapshot(SlotAllocationSnapshot) - Method in interface org.apache.flink.runtime.taskexecutor.slot.SlotAllocationSnapshotPersistenceService
-
Persist the given slot allocation snapshot.
- PersistentMetadataCheckpointStorageLocation - Class in org.apache.flink.runtime.state.memory
-
A checkpoint storage location for the
MemCheckpointStreamFactorywhen it durably persists the metadata in a file system. - PersistentMetadataCheckpointStorageLocation(FileSystem, Path, int) - Constructor for class org.apache.flink.runtime.state.memory.PersistentMetadataCheckpointStorageLocation
-
Creates a checkpoint storage persists metadata to a file system and stores state in line in state handles with the metadata.
- PerWindowStateStore(KeyedStateBackend<?>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.PerWindowStateStore
- PHYSICAL_FILE_COUNT - Static variable in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingMetricGroup
- PHYSICAL_FILE_SIZE - Static variable in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingMetricGroup
- PhysicalFile - Class in org.apache.flink.runtime.checkpoint.filemerging
-
An abstraction of physical files in file-merging checkpoints.
- PhysicalFile(FSDataOutputStream, Path, PhysicalFile.PhysicalFileDeleter, CheckpointedStateScope) - Constructor for class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFile
- PhysicalFile(FSDataOutputStream, Path, PhysicalFile.PhysicalFileDeleter, CheckpointedStateScope, boolean) - Constructor for class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFile
- PhysicalFile.PhysicalFileCreator - Interface in org.apache.flink.runtime.checkpoint.filemerging
-
Functional interface to create the physical file.
- PhysicalFile.PhysicalFileDeleter - Interface in org.apache.flink.runtime.checkpoint.filemerging
-
Functional interface to delete the physical file.
- physicalFileCreator - Variable in class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFilePool
-
creator to create a physical file.
- physicalFileDeleter - Variable in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
- PhysicalFilePool - Class in org.apache.flink.runtime.checkpoint.filemerging
-
A pool for reusing
PhysicalFile. - PhysicalFilePool(long, PhysicalFile.PhysicalFileCreator) - Constructor for class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFilePool
- PhysicalFilePool.Type - Enum in org.apache.flink.runtime.checkpoint.filemerging
-
Types of supported physical file pool.
- PhysicalSlot - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
The context of an
AllocatedSlot. - PhysicalSlot.Payload - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
Payload which can be assigned to an
AllocatedSlot. - PhysicalSlotProvider - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
The provider serves physical slot requests.
- PhysicalSlotProviderImpl - Class in org.apache.flink.runtime.jobmaster.slotpool
-
The provider serves physical slot requests.
- PhysicalSlotProviderImpl(SlotSelectionStrategy, SlotPool) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlotProviderImpl
- PhysicalSlotRequest - Class in org.apache.flink.runtime.jobmaster.slotpool
-
Represents a request for a physical slot.
- PhysicalSlotRequest(SlotRequestId, SlotProfile, boolean) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlotRequest
- PhysicalSlotRequest.Result - Class in org.apache.flink.runtime.jobmaster.slotpool
-
Result of a
PhysicalSlotRequest. - PhysicalSlotRequestBulk - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
Represents a bulk of physical slot requests.
- PhysicalSlotRequestBulkChecker - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
This class tracks a fulfillability timeout of a bulk of physical slot requests.
- PhysicalSlotRequestBulkCheckerImpl - Class in org.apache.flink.runtime.jobmaster.slotpool
-
Default implementation of
PhysicalSlotRequestBulkChecker. - PhysicalStateHandleID - Class in org.apache.flink.runtime.state
-
Unique ID that allows for physical comparison between state handles.
- PhysicalStateHandleID(String) - Constructor for class org.apache.flink.runtime.state.PhysicalStateHandleID
- PhysicalTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
A
Transformationthat creates a physical operation. - PIPELINED - org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
A pipelined streaming data exchange.
- PIPELINED - org.apache.flink.runtime.operators.DamBehavior
-
Constant indicating that the algorithm does not come with any form of dam and records pass through in a pipelined fashion.
- PIPELINED - org.apache.flink.streaming.api.transformations.StreamExchangeMode
-
Producer and consumer are online at the same time.
- PIPELINED_APPROXIMATE - org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
Pipelined partitions with a bounded (local) buffer pool to support downstream task to continue consuming data after reconnection in Approximate Local-Recovery.
- PIPELINED_BOUNDED - org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
Pipelined partitions with a bounded (local) buffer pool.
- PIPELINED_REGION_RESTART_STRATEGY_NAME - Static variable in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategyFactoryLoader
-
Config name for the
RestartPipelinedRegionFailoverStrategy. - PipelinedApproximateSubpartition - Class in org.apache.flink.runtime.io.network.partition
-
A pipelined in-memory only subpartition, which allows to reconnect after failure.
- PipelinedApproximateSubpartitionView - Class in org.apache.flink.runtime.io.network.partition
-
View over a pipelined in-memory only subpartition allowing reconnecting.
- PipelinedRegion<VID extends VertexID,RID extends ResultID,V extends Vertex<VID,RID,V,R>,R extends Result<VID,RID,V,R>> - Interface in org.apache.flink.runtime.topology
-
A pipelined region is a set of vertices connected via pipelined data exchanges.
- PipelinedRegionComputeUtil - Class in org.apache.flink.runtime.executiongraph.failover
-
Common utils for computing pipelined regions.
- PipelinedRegionSchedulingStrategy - Class in org.apache.flink.runtime.scheduler.strategy
-
SchedulingStrategyinstance which schedules tasks in granularity of pipelined regions. - PipelinedRegionSchedulingStrategy(SchedulerOperations, SchedulingTopology) - Constructor for class org.apache.flink.runtime.scheduler.strategy.PipelinedRegionSchedulingStrategy
- PipelinedRegionSchedulingStrategy.Factory - Class in org.apache.flink.runtime.scheduler.strategy
-
The factory for creating
PipelinedRegionSchedulingStrategy. - PipelinedResultPartition - Class in org.apache.flink.runtime.io.network.partition
-
A result output of a task, pipelined (streamed) to the receivers.
- PipelinedResultPartition(String, int, ResultPartitionID, ResultPartitionType, ResultSubpartition[], int, ResultPartitionManager, BufferCompressor, SupplierWithException<BufferPool, IOException>) - Constructor for class org.apache.flink.runtime.io.network.partition.PipelinedResultPartition
- PipelinedSubpartition - Class in org.apache.flink.runtime.io.network.partition
-
A pipelined in-memory only subpartition, which can be consumed once.
- PipelinedSubpartitionView - Class in org.apache.flink.runtime.io.network.partition
-
View over a pipelined in-memory only subpartition.
- PipelinedSubpartitionView(PipelinedSubpartition, BufferAvailabilityListener) - Constructor for class org.apache.flink.runtime.io.network.partition.PipelinedSubpartitionView
- PipelineErrorHandler - Class in org.apache.flink.runtime.rest.handler
-
This is the last handler in the pipeline.
- PipelineErrorHandler(Logger, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.PipelineErrorHandler
- PLACEHOLDER - Static variable in class org.apache.flink.runtime.io.network.partition.hybrid.index.FileDataIndexCache
-
Placeholder of cache entry's value.
- PlaceholderStreamStateHandle - Class in org.apache.flink.runtime.state
-
A placeholder state handle for shared state that will replaced by an original that was created in a previous checkpoint.
- PlaceholderStreamStateHandle(PhysicalStateHandleID, long, boolean) - Constructor for class org.apache.flink.runtime.state.PlaceholderStreamStateHandle
- POINTWISE - org.apache.flink.runtime.jobgraph.DistributionPattern
-
Each producing sub task is connected to one or more subtask(s) of the consuming task.
- POINTWISE_EDGES_PIPELINED - org.apache.flink.streaming.api.graph.GlobalStreamExchangeMode
-
Set job edges with
ForwardPartitionerorRescalePartitionerto beResultPartitionType.PIPELINED_BOUNDEDand other edges to beResultPartitionType.BLOCKING. - PointwiseBlockingResultInfo - Class in org.apache.flink.runtime.scheduler.adaptivebatch
-
Information of Pointwise result.
- poll() - Method in class org.apache.flink.runtime.io.network.partition.DeduplicatedQueue
- poll() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyPayloadManager
- poll() - Method in class org.apache.flink.runtime.io.network.partition.PrioritizedDeque
-
Polls the first priority element or non-priority element if the former does not exist.
- poll() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
-
Removes and returns the least element of the PriorityQueue in log(size) time.
- poll() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
- poll() - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueSet
- poll() - Method in class org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
- poll() - Method in interface org.apache.flink.runtime.state.InternalPriorityQueue
-
Retrieves and removes the first element (w.r.t. the order) of this set, or returns
nullif this set is empty. - poll() - Method in class org.apache.flink.streaming.runtime.watermarkstatus.HeapPriorityQueue
- poll(StageRunner.SortStage) - Method in interface org.apache.flink.runtime.operators.sort.StageRunner.StageMessageDispatcher
-
Retrieves and removes the head of the given stage queue, or returns
nullif the queue is empty. - pollFile(FileMergingSnapshotManager.SubtaskKey, CheckpointedStateScope) - Method in class org.apache.flink.runtime.checkpoint.filemerging.BlockingPhysicalFilePool
- pollFile(FileMergingSnapshotManager.SubtaskKey, CheckpointedStateScope) - Method in class org.apache.flink.runtime.checkpoint.filemerging.NonBlockingPhysicalFilePool
- pollFile(FileMergingSnapshotManager.SubtaskKey, CheckpointedStateScope) - Method in class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFilePool
-
Poll a physical file from the pool.
- pollNext() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
Poll the
BufferOrEvent. - pollNext() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- pollNext() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
- pollNext() - Method in interface org.apache.flink.runtime.io.PullingAsyncDataInput
-
Poll the next element.
- pollNext() - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
- pollNext() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
- positionToNextBuffer(FileChannel, ByteBuffer) - Static method in class org.apache.flink.runtime.io.network.partition.BufferReaderWriterUtil
-
Skip one data buffer from the channel's current position by headerBuffer.
- PossibleInconsistentStateException - Exception in org.apache.flink.runtime.persistence
-
PossibleInconsistentStateExceptionrepresents errors that might have lead to an inconsistent state within the HA resources. - PossibleInconsistentStateException() - Constructor for exception org.apache.flink.runtime.persistence.PossibleInconsistentStateException
- PossibleInconsistentStateException(String, Throwable) - Constructor for exception org.apache.flink.runtime.persistence.PossibleInconsistentStateException
- PossibleInconsistentStateException(Throwable) - Constructor for exception org.apache.flink.runtime.persistence.PossibleInconsistentStateException
- POST - org.apache.flink.runtime.rest.HttpMethodWrapper
- postComplete(boolean) - Method in class org.apache.flink.runtime.asyncprocessing.ContextStateFutureImpl
- postProcessElement() - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperator
- postProcessElement() - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperatorV2
- postProcessElement() - Method in interface org.apache.flink.streaming.runtime.operators.asyncprocessing.AsyncStateProcessingOperator
-
A callback that will be triggered after an element finishes
processElement. - PREDECESSORS - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
- PreferredAllocationRequestSlotMatchingStrategy - Enum in org.apache.flink.runtime.jobmaster.slotpool
-
RequestSlotMatchingStrategythat takes the preferred allocations into account. - PreferredLocationsRetriever - Interface in org.apache.flink.runtime.scheduler
-
Component to retrieve the preferred locations of an execution vertex.
- prepare() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
- prepare() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
- prepare() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
- prepare() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
- prepare() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
- prepare() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
- prepare() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
- prepare() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
- prepare() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
- prepare() - Method in class org.apache.flink.runtime.operators.CrossDriver
- prepare() - Method in interface org.apache.flink.runtime.operators.Driver
-
This method is called before the user code is opened.
- prepare() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
- prepare() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
- prepare() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
- prepare() - Method in class org.apache.flink.runtime.operators.JoinDriver
- prepare() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
- prepare() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
- prepare() - Method in class org.apache.flink.runtime.operators.MapDriver
- prepare() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
- prepare() - Method in class org.apache.flink.runtime.operators.NoOpDriver
- prepare() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
- prepare() - Method in class org.apache.flink.runtime.operators.ReduceDriver
- prepare() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
- prepareCanonicalSavepoint(CheckpointableKeyedStateBackend<?>, CloseableRegistry) - Static method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
- prepareClose() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
Lifecycle method to close the mailbox for action submission.
- prepareNextPartition() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
- prepareNextPartition() - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
- prepareProbePhase(IOManager, FileIOChannel.Enumerator, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
- prepareSnapshot(ChannelStateWriter, long) - Method in class org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput
- prepareSnapshot(ChannelStateWriter, long) - Method in class org.apache.flink.streaming.api.operators.sort.SortingDataInput
- prepareSnapshot(ChannelStateWriter, long) - Method in class org.apache.flink.streaming.runtime.io.recovery.RescalingStreamTaskNetworkInput
- prepareSnapshot(ChannelStateWriter, long) - Method in interface org.apache.flink.streaming.runtime.io.StreamInputProcessor
- prepareSnapshot(ChannelStateWriter, long) - Method in class org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessor
- prepareSnapshot(ChannelStateWriter, long) - Method in class org.apache.flink.streaming.runtime.io.StreamOneInputProcessor
- prepareSnapshot(ChannelStateWriter, long) - Method in interface org.apache.flink.streaming.runtime.io.StreamTaskInput
-
Prepares to spill the in-flight input buffers as checkpoint snapshot.
- prepareSnapshot(ChannelStateWriter, long) - Method in class org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput
- prepareSnapshot(ChannelStateWriter, long) - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
- prepareSnapshotPreBarrier(long) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperator
- prepareSnapshotPreBarrier(long) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperatorV2
- prepareSnapshotPreBarrier(long) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- prepareSnapshotPreBarrier(long) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- prepareSnapshotPreBarrier(long) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
This method is called when the operator should do a snapshot, before it emits its own checkpoint barrier.
- prepareSnapshotPreBarrier(long) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
- prepareSnapshotPreBarrier(long) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- prepareSnapshotPreBarrier(long) - Method in class org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
- prepareUserArtifactEntries(Map<String, DistributedCache.DistributedCacheEntry>, JobID) - Static method in enum org.apache.flink.runtime.jobgraph.JobGraphUtils
- preserveRecordOrderAndProcess(ThrowingRunnable<Exception>) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperator
- preserveRecordOrderAndProcess(ThrowingRunnable<Exception>) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperatorV2
- preserveRecordOrderAndProcess(ThrowingRunnable<Exception>) - Method in interface org.apache.flink.streaming.runtime.operators.asyncprocessing.AsyncStateProcessingOperator
-
Check the order of same-key record, and then process the record.
- prettyPrintInterval() - Method in class org.apache.flink.runtime.state.KeyGroupRange
- PreviousAllocationSlotSelectionStrategy - Class in org.apache.flink.runtime.jobmaster.slotpool
-
This class implements a
SlotSelectionStrategythat is based on previous allocations and falls back to using location preference hints if there is no previous allocation. - previousSchemaSerializer() - Method in class org.apache.flink.runtime.state.StateSerializerProvider
-
Gets the serializer that recognizes the previous serialization schema of the state.
- PrimaryAndSecondaryStream(CheckpointStateOutputStream, CheckpointStateOutputStream) - Constructor for class org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryAndSecondaryStream
- PrimaryStreamOnly(CheckpointStateOutputStream) - Constructor for class org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryStreamOnly
- print() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes a DataStream to the standard output stream (stdout).
- print(String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes a DataStream to the standard output stream (stdout).
- printHelp(String) - Method in class org.apache.flink.runtime.entrypoint.parser.CommandLineParser
- PrintSinkFunction<IN> - Class in org.apache.flink.streaming.api.functions.sink.legacy
-
Deprecated.This interface will be removed in future versions. Use the new
PrintSinkinterface instead. - PrintSinkFunction() - Constructor for class org.apache.flink.streaming.api.functions.sink.legacy.PrintSinkFunction
-
Deprecated.Instantiates a print sink function that prints to standard out.
- PrintSinkFunction(boolean) - Constructor for class org.apache.flink.streaming.api.functions.sink.legacy.PrintSinkFunction
-
Deprecated.Instantiates a print sink function that prints to standard out.
- PrintSinkFunction(String, boolean) - Constructor for class org.apache.flink.streaming.api.functions.sink.legacy.PrintSinkFunction
-
Deprecated.Instantiates a print sink function that prints to standard out and gives a sink identifier.
- printToErr() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes a DataStream to the standard error stream (stderr).
- printToErr(String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes a DataStream to the standard error stream (stderr).
- priorAllocation(ResourceProfile, ResourceProfile, Collection<TaskManagerLocation>, Collection<AllocationID>, Set<AllocationID>) - Static method in class org.apache.flink.runtime.clusterframework.types.SlotProfile
-
Returns a slot profile for the given resource profile, prior allocations and all prior allocation ids from the whole execution graph.
- prioritize(T) - Method in class org.apache.flink.runtime.io.network.partition.PrioritizedDeque
-
Prioritizes an already existing element.
- PRIORITIZED_EVENT_BUFFER - org.apache.flink.runtime.io.network.buffer.Buffer.DataType
-
Same as EVENT_BUFFER, but the event has been prioritized (e.g. it skipped buffers).
- PrioritizedDeque<T> - Class in org.apache.flink.runtime.io.network.partition
-
A deque-like data structure that supports prioritization of elements, such they will be polled before any non-priority elements.
- PrioritizedDeque() - Constructor for class org.apache.flink.runtime.io.network.partition.PrioritizedDeque
- prioritizedOperatorState(OperatorID) - Method in interface org.apache.flink.runtime.state.TaskStateManager
-
Returns means to restore previously reported state of an operator running in the owning task.
- prioritizedOperatorState(OperatorID) - Method in class org.apache.flink.runtime.state.TaskStateManagerImpl
- PrioritizedOperatorSubtaskState - Class in org.apache.flink.runtime.checkpoint
-
This class is a wrapper over multiple alternative
OperatorSubtaskStatethat are (partial) substitutes for each other and imposes a priority ordering over all alternatives for the different states which define an order in which the operator should attempt to restore the state from them. - PrioritizedOperatorSubtaskState.Builder - Class in org.apache.flink.runtime.checkpoint
-
A builder for PrioritizedOperatorSubtaskState.
- priority() - Method in interface org.apache.flink.runtime.io.network.netty.InboundChannelHandlerFactory
-
Gives back priority of the
ChannelHandler. - priority() - Method in interface org.apache.flink.runtime.io.network.netty.OutboundChannelHandlerFactory
-
Gives back priority of the
ChannelHandler. - PRIORITY_QUEUE - org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.BackendStateType
- priorityAvailabilityHelper - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
- PriorityComparable<T> - Interface in org.apache.flink.runtime.state
-
Interface for objects that can be compared by priority.
- PriorityComparator<T> - Interface in org.apache.flink.runtime.state
-
This interface works similar to
Comparableand is used to prioritize between two objects. - PriorityQueueSetFactory - Interface in org.apache.flink.runtime.state
-
Factory for
KeyGroupedInternalPriorityQueueinstances. - probeIterator - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Iterator over the elements from the probe side.
- probeSideBuffer - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
- probeSideChannel - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
- probeSideRecordCounter - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
- probeSideSerializer - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The utilities to serialize the probe side data types.
- probeSideSerializer - Variable in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
- probeSideSerializer - Variable in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
- probeSideSerializer - Variable in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
- probeSideSerializer - Variable in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
- probeTypeComparator - Variable in class org.apache.flink.runtime.operators.hash.AbstractHashTableProber
- process(Byte, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
- process(Byte, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
- process(Byte, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
- process(Byte, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
- process(Byte, W, InternalWindowFunction.InternalWindowContext, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
- process(KEY, ProcessWindowFunction.Context, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction
-
Evaluates the window and outputs none or several elements.
- process(KEY, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
- process(KEY, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
- process(KEY, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction
-
Evaluates the window and outputs none or several elements.
- process(KEY, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
- process(KEY, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
- process(K, ProcessWindowFunction.Context, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
- process(K, S) - Method in interface org.apache.flink.runtime.state.KeyedStateFunction
-
The actual method to be applied on each of the states.
- process(K, W, InternalWindowFunction.InternalWindowContext, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
- process(BroadcastProcessFunction<IN1, IN2, OUT>) - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
Assumes as inputs a
BroadcastStreamand a non-keyedDataStreamand applies the givenBroadcastProcessFunctionon them, thereby creating a transformed output stream. - process(BroadcastProcessFunction<IN1, IN2, OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
Assumes as inputs a
BroadcastStreamand a non-keyedDataStreamand applies the givenBroadcastProcessFunctionon them, thereby creating a transformed output stream. - process(CoProcessFunction<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies the given
CoProcessFunctionon the connected input streams, thereby creating a transformed output stream. - process(CoProcessFunction<IN1, IN2, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies the given
CoProcessFunctionon the connected input streams, thereby creating a transformed output stream. - process(KeyedBroadcastProcessFunction<KEY, IN1, IN2, OUT>) - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
Assumes as inputs a
BroadcastStreamand aKeyedStreamand applies the givenKeyedBroadcastProcessFunctionon them, thereby creating a transformed output stream. - process(KeyedBroadcastProcessFunction<KEY, IN1, IN2, OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.datastream.BroadcastConnectedStream
-
Assumes as inputs a
BroadcastStreamand aKeyedStreamand applies the givenKeyedBroadcastProcessFunctionon them, thereby creating a transformed output stream. - process(KeyedCoProcessFunction<K, IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies the given
KeyedCoProcessFunctionon the connected input keyed streams, thereby creating a transformed output stream. - process(KeyedCoProcessFunction<K, IN1, IN2, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
-
Applies the given
KeyedCoProcessFunctionon the connected input streams, thereby creating a transformed output stream. - process(ProcessJoinFunction<IN1, IN2, OUT>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoined
-
Completes the join operation with the given user function that is executed for each joined pair of elements.
- process(ProcessJoinFunction<IN1, IN2, OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoined
-
Completes the join operation with the given user function that is executed for each joined pair of elements.
- process(KeyedProcessFunction<KEY, T, R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies the given
KeyedProcessFunctionon the input stream, thereby creating a transformed output stream. - process(KeyedProcessFunction<KEY, T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies the given
KeyedProcessFunctionon the input stream, thereby creating a transformed output stream. - process(ProcessFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Applies the given
ProcessFunctionon the input stream, thereby creating a transformed output stream. - process(ProcessFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Applies the given
ProcessFunctionon the input stream, thereby creating a transformed output stream. - process(ProcessAllWindowFunction.Context, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction
-
Evaluates the window and outputs none or several elements.
- process(ProcessAllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- process(ProcessAllWindowFunction.Context, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
- process(ProcessAllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- process(ProcessWindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- process(ProcessWindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
- process(ProcessWindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- PROCESS_CONTINUOUSLY - org.apache.flink.streaming.api.functions.source.FileProcessingMode
-
Periodically scans the path for new data.
- PROCESS_FAILURE - org.apache.flink.runtime.entrypoint.ClusterEntrypoint.ShutdownBehaviour
- PROCESS_ONCE - org.apache.flink.streaming.api.functions.source.FileProcessingMode
-
Processes the current contents of the path and exits.
- PROCESS_ONLY_APPENDED - org.apache.flink.streaming.api.functions.source.legacy.FileMonitoringFunction.WatchType
-
Deprecated.
- ProcessAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
Base abstract class for functions that are evaluated over non-keyed windows using a context for retrieving extra information.
- ProcessAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction
- ProcessAllWindowFunction.Context - Class in org.apache.flink.streaming.api.functions.windowing
-
The context holding window metadata.
- processBarrier(CheckpointBarrier, InputChannelInfo, boolean) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
- processBarrier(CheckpointBarrier, InputChannelInfo, boolean) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierTracker
- processBarrier(CheckpointBarrier, InputChannelInfo, boolean) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
- processBarrierAnnouncement(CheckpointBarrier, int, InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
- processBarrierAnnouncement(CheckpointBarrier, int, InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierTracker
- processBarrierAnnouncement(CheckpointBarrier, int, InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
- processBroadcastElement(IN2, BroadcastProcessFunction.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.BroadcastProcessFunction
-
This method is called for each element in the
broadcast stream. - processBroadcastElement(IN2, KeyedBroadcastProcessFunction.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction
-
This method is called for each element in the
broadcast stream. - processBuffer(BufferOrEvent) - Method in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
- processCancellationBarrier(CancelCheckpointMarker, InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
- processCancellationBarrier(CancelCheckpointMarker, InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierTracker
- processCancellationBarrier(CancelCheckpointMarker, InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
- processContext - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
- processElement(IN1, IN2, ProcessJoinFunction.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.ProcessJoinFunction
-
This method is called for each joined pair of elements.
- processElement(IN1, BroadcastProcessFunction.ReadOnlyContext, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.BroadcastProcessFunction
-
This method is called for each element in the (non-broadcast)
data stream. - processElement(IN1, KeyedBroadcastProcessFunction.ReadOnlyContext, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction
-
This method is called for each element in the (non-broadcast)
keyed stream. - processElement(I, KeyedProcessFunction.Context, Collector<O>) - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction
-
Process one element from the input stream.
- processElement(I, ProcessFunction.Context, Collector<O>) - Method in class org.apache.flink.streaming.api.functions.ProcessFunction
-
Process one element from the input stream.
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.functions.query.QueryableAppendingStateOperator
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.functions.query.QueryableValueStateOperator
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.BatchGroupedReduceOperator
- processElement(StreamRecord<IN>) - Method in interface org.apache.flink.streaming.api.operators.Input
-
Processes one element that arrived on this input of the
MultipleInputStreamOperator. - processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.KeyedProcessOperator
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.LegacyKeyedProcessOperator
-
Deprecated.
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.MapPartitionOperator
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.PartitionAggregateOperator
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.PartitionReduceOperator
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.ProcessOperator
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamFilter
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamFlatMap
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamGroupedReduceOperator
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamMap
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamProject
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamSink
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreInput
- processElement(StreamRecord<INPUT>) - Method in class org.apache.flink.streaming.api.operators.sortpartition.KeyedSortPartitionOperator
- processElement(StreamRecord<INPUT>) - Method in class org.apache.flink.streaming.api.operators.sortpartition.SortPartitionOperator
- processElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
- processElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
- processElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator.IdentityStreamOperator
- processElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator.NoOpStreamOperator
- processElement1(IN1, CoProcessFunction.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction
-
This method is called for each element in the first of the connected streams.
- processElement1(IN1, KeyedCoProcessFunction.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction
-
This method is called for each element in the first of the connected streams.
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.BatchCoBroadcastWithKeyedOperator
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.BatchCoBroadcastWithNonKeyedOperator
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.CoProcessOperator
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.CoStreamMap
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
- processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
-
Deprecated.
- processElement1(StreamRecord<IN1>) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes one element that arrived on the first input of this two-input operator.
- processElement1(StreamRecord<T1>) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
-
Process a
StreamRecordfrom the left stream. - processElement2(IN2, CoProcessFunction.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction
-
This method is called for each element in the second of the connected streams.
- processElement2(IN2, KeyedCoProcessFunction.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction
-
This method is called for each element in the second of the connected streams.
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithKeyedOperator
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.CoProcessOperator
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.CoStreamMap
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
- processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.LegacyKeyedCoProcessOperator
-
Deprecated.
- processElement2(StreamRecord<IN2>) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes one element that arrived on the second input of this two-input operator.
- processElement2(StreamRecord<T2>) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
-
Process a
StreamRecordfrom the right stream. - processEndOfPartition(InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
- processEndOfPartition(InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierTracker
- processEndOfPartition(InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
- processEvent(BufferOrEvent) - Method in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
- processEvent(BufferOrEvent) - Method in class org.apache.flink.streaming.runtime.io.recovery.RescalingStreamTaskNetworkInput
- processExitCode() - Method in enum org.apache.flink.runtime.clusterframework.ApplicationStatus
-
Gets the process exit code associated with this status.
- ProcessFunction<I,O> - Class in org.apache.flink.streaming.api.functions
-
A function that processes elements of a stream.
- ProcessFunction() - Constructor for class org.apache.flink.streaming.api.functions.ProcessFunction
- ProcessFunction.Context - Class in org.apache.flink.streaming.api.functions
-
Information available in an invocation of
#processElement(Object, Context, Collector)or#onTimer(long, OnTimerContext, Collector). - ProcessFunction.OnTimerContext - Class in org.apache.flink.streaming.api.functions
-
Information available in an invocation of
#onTimer(long, OnTimerContext, Collector). - PROCESSING_TIME - org.apache.flink.streaming.api.TimeDomain
-
Time is based on the current processing-time of a machine where processing happens.
- ProcessingModeDeserializer() - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingModeDeserializer
- ProcessingModeSerializer() - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingModeSerializer
- processingTimeService - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- processingTimeService - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
- processingTimeService - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- processingTimeService - Variable in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
- ProcessingTimeService - Interface in org.apache.flink.streaming.runtime.tasks
-
Defines the current processing time and handles all related actions, such as register timers for tasks to be executed in the future.
- ProcessingTimeServiceAware - Interface in org.apache.flink.streaming.runtime.tasks
-
Interface for
StreamOperatorFactory, which enables stream operators to accessProcessingTimeService. - ProcessingTimeServiceFactory - Interface in org.apache.flink.streaming.runtime.tasks
-
A factory for creating processing time services with a given
MailboxExecutor. - ProcessingTimeServiceUtil - Class in org.apache.flink.streaming.runtime.tasks
-
Utility for classes that implements the
ProcessingTimeServiceinterface. - ProcessingTimeServiceUtil() - Constructor for class org.apache.flink.streaming.runtime.tasks.ProcessingTimeServiceUtil
- processingTimeTimersQueue - Variable in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
-
Processing time timers that are currently in-flight.
- ProcessingTimeTrigger - Class in org.apache.flink.streaming.api.windowing.triggers
-
A
Triggerthat fires once the current system time passes the end of the window to which a pane belongs. - processInput() - Method in interface org.apache.flink.streaming.runtime.io.StreamInputProcessor
-
In case of two and more input processors this method must call
InputSelectable.nextSelection()to choose which input to consume from next. - processInput() - Method in class org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessor
- processInput() - Method in class org.apache.flink.streaming.runtime.io.StreamOneInputProcessor
- processInput(MailboxDefaultAction.Controller) - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
Deprecated.
- processInput(MailboxDefaultAction.Controller) - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
- processInput(MailboxDefaultAction.Controller) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
This method implements the default action of the task (e.g. processing one event from the input).
- ProcessJoinFunction<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
-
A function that processes two joined elements and produces a single output one.
- ProcessJoinFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.ProcessJoinFunction
- ProcessJoinFunction.Context - Class in org.apache.flink.streaming.api.functions.co
-
The context that is available during an invocation of
#processElement(Object, Object, Context, Collector). - processLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- processLatencyMarker(LatencyMarker) - Method in interface org.apache.flink.streaming.api.operators.Input
-
Processes a
LatencyMarkerthat arrived on the first input of this two-input operator. - processLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreInput
- processLatencyMarker1(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- processLatencyMarker1(LatencyMarker) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes a
LatencyMarkerthat arrived on the first input of this two-input operator. - processLatencyMarker2(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- processLatencyMarker2(LatencyMarker) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes a
LatencyMarkerthat arrived on the second input of this two-input operator. - ProcessMemoryOptions - Class in org.apache.flink.runtime.util.config.memory
-
Common Flink's options to describe its JVM process memory configuration for JM or TM.
- ProcessMemoryOptions(List<ConfigOption<MemorySize>>, ConfigOption<MemorySize>, ConfigOption<MemorySize>, JvmMetaspaceAndOverheadOptions) - Constructor for class org.apache.flink.runtime.util.config.memory.ProcessMemoryOptions
- ProcessMemorySpec - Interface in org.apache.flink.runtime.util.config.memory
-
Common interface for Flink JVM process memory components.
- ProcessMemoryUtils<FM extends FlinkMemory> - Class in org.apache.flink.runtime.util.config.memory
-
Common utils to parse JVM process memory configuration for JM or TM.
- ProcessMemoryUtils(ProcessMemoryOptions, FlinkMemoryUtils<FM>) - Constructor for class org.apache.flink.runtime.util.config.memory.ProcessMemoryUtils
- ProcessMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
AbstractImitatingJobManagerMetricGroupimplementation for process related metrics. - processNonRecord(ThrowingRunnable<? extends Exception>) - Method in class org.apache.flink.runtime.asyncprocessing.AsyncExecutionController
- ProcessOperator<IN,OUT> - Class in org.apache.flink.streaming.api.operators
-
A
StreamOperatorfor executingProcessFunctions. - ProcessOperator(ProcessFunction<IN, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.ProcessOperator
- processProbeIter() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
- processRecordAttributes(RecordAttributes) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- processRecordAttributes(RecordAttributes) - Method in interface org.apache.flink.streaming.api.operators.Input
-
Processes a
RecordAttributesthat arrived at this input. - processRecordAttributes(RecordAttributes, int) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- processRecordAttributes1(RecordAttributes) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- processRecordAttributes1(RecordAttributes) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes a
RecordAttributesthat arrived on the first input of this operator. - processRecordAttributes2(RecordAttributes) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- processRecordAttributes2(RecordAttributes) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes a
RecordAttributesthat arrived on the second input of this operator. - processResourceRequirements(ResourceRequirements) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedSlotManager
- processResourceRequirements(ResourceRequirements) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Notifies the slot manager about the resource requirements of a job.
- processSpecFromConfig(Configuration) - Static method in class org.apache.flink.runtime.clusterframework.TaskExecutorProcessUtils
- processSpecFromConfig(Configuration) - Static method in class org.apache.flink.runtime.jobmanager.JobManagerProcessUtils
- processSpecFromWorkerResourceSpec(Configuration, WorkerResourceSpec) - Static method in class org.apache.flink.runtime.clusterframework.TaskExecutorProcessUtils
- processTaskExecutorClusterPartitionReport(ResourceID, ClusterPartitionReport) - Method in interface org.apache.flink.runtime.io.network.partition.ResourceManagerPartitionTracker
-
Processes
ClusterPartitionReportof a task executor. - processTaskExecutorClusterPartitionReport(ResourceID, ClusterPartitionReport) - Method in class org.apache.flink.runtime.io.network.partition.ResourceManagerPartitionTrackerImpl
- processTaskExecutorShutdown(ResourceID) - Method in interface org.apache.flink.runtime.io.network.partition.ResourceManagerPartitionTracker
-
Processes the shutdown of task executor.
- processTaskExecutorShutdown(ResourceID) - Method in class org.apache.flink.runtime.io.network.partition.ResourceManagerPartitionTrackerImpl
- processUnmatchedBuildIter() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
- processWatermark(Watermark) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperator
- processWatermark(Watermark) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperatorV2
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.co.CoBroadcastWithNonKeyedOperator
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.co.CoProcessOperator
- processWatermark(Watermark) - Method in interface org.apache.flink.streaming.api.operators.Input
-
Processes a
Watermarkthat arrived on the first input of this two-input operator. - processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.ProcessOperator
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.StreamSink
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
-
Override the base implementation to completely ignore watermarks propagated from upstream, except for the "end of time" watermark.
- processWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreInput
- processWatermark1(Watermark) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- processWatermark1(Watermark) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes a
Watermarkthat arrived on the first input of this two-input operator. - processWatermark2(Watermark) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- processWatermark2(Watermark) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes a
Watermarkthat arrived on the second input of this two-input operator. - processWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperator
- processWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- processWatermarkStatus(WatermarkStatus) - Method in interface org.apache.flink.streaming.api.operators.Input
-
Processes a
WatermarkStatusthat arrived on this input of theMultipleInputStreamOperator. - processWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
-
Override the base implementation to completely ignore statuses propagated from upstream.
- processWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreInput
- processWatermarkStatus(WatermarkStatus, int) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperatorV2
- processWatermarkStatus(WatermarkStatus, int) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- processWatermarkStatus1(WatermarkStatus) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- processWatermarkStatus1(WatermarkStatus) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes a
WatermarkStatusthat arrived on the first input of this two-input operator. - processWatermarkStatus2(WatermarkStatus) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- processWatermarkStatus2(WatermarkStatus) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
-
Processes a
WatermarkStatusthat arrived on the second input of this two-input operator. - ProcessWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
-
Base abstract class for functions that are evaluated over keyed (grouped) windows using a context for retrieving extra information.
- ProcessWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction
- ProcessWindowFunction.Context - Class in org.apache.flink.streaming.api.functions.windowing
-
The context holding window metadata.
- ProducerDescriptor - Class in org.apache.flink.runtime.shuffle
-
Partition producer descriptor for
ShuffleMasterto obtainShuffleDescriptor. - ProducerDescriptor(ResourceID, ExecutionAttemptID, InetAddress, int) - Constructor for class org.apache.flink.runtime.shuffle.ProducerDescriptor
- ProducerFailedException - Exception in org.apache.flink.runtime.io.network.partition
-
Network-stack level Exception to notify remote receiver about a failed partition producer.
- ProducerFailedException(Throwable) - Constructor for exception org.apache.flink.runtime.io.network.partition.ProducerFailedException
-
The cause of the producer failure.
- ProducerMergedPartitionFile - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.file
-
The partition file in the producer-merge mode.
- ProducerMergedPartitionFile() - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.ProducerMergedPartitionFile
- ProducerMergedPartitionFileIndex - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.file
-
The
ProducerMergedPartitionFileIndexis used byProducerMergedPartitionFileWriterandProducerMergedPartitionFileReader, to maintain the offset of each buffer in the physical file. - ProducerMergedPartitionFileIndex(int, Path, int, long) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.ProducerMergedPartitionFileIndex
- ProducerMergedPartitionFileIndex.FixedSizeRegion - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.file
-
Represents a series of buffers that are: From the same subpartition Logically (i.e. buffer index) consecutive Physically (i.e. offset in the file) consecutive
- ProducerMergedPartitionFileReader - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.file
-
The implementation of
PartitionFileReaderwith producer-merge mode. - ProducerMergedPartitionFileReader.ProducerMergedReadProgress - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.file
-
The implementation of
PartitionFileReader.ReadProgressmainly includes current reading offset, end of read offset, etc. - ProducerMergedPartitionFileWriter - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.file
-
The implementation of
PartitionFileWriterwith producer-side merge mode. - ProducerMergedReadProgress(long, long) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.ProducerMergedPartitionFileReader.ProducerMergedReadProgress
- PROFILER - org.apache.flink.runtime.taskexecutor.FileType
-
The profiler file type for taskmanager.
- ProfilingFileMessageParameters - Class in org.apache.flink.runtime.rest.messages.cluster
-
Parameters for
JobManagerProfilingFileHandler. - ProfilingFileMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.cluster.ProfilingFileMessageParameters
- profilingFileNamePathParameter - Variable in class org.apache.flink.runtime.rest.messages.cluster.ProfilingFileMessageParameters
- profilingFileNamePathParameter - Variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingFileMessageParameters
- ProfilingFileNamePathParameter - Class in org.apache.flink.runtime.rest.messages
-
Parameters used by
JobManagerProfilingFileHandler. - ProfilingFileNamePathParameter() - Constructor for class org.apache.flink.runtime.rest.messages.ProfilingFileNamePathParameter
- ProfilingInfo - Class in org.apache.flink.runtime.rest.messages
-
Contains information of a Profiling Instance.
- ProfilingInfo.ProfilingMode - Enum in org.apache.flink.runtime.rest.messages
-
Supported profiling mode in async-profiler.
- ProfilingInfo.ProfilingStatus - Enum in org.apache.flink.runtime.rest.messages
-
Profiling Status.
- ProfilingInfoList - Class in org.apache.flink.runtime.rest.messages
-
Class containing a collection of
ProfilingInfo. - ProfilingInfoList(Collection<ProfilingInfo>) - Constructor for class org.apache.flink.runtime.rest.messages.ProfilingInfoList
- ProfilingRequestBody - Class in org.apache.flink.runtime.rest.messages.cluster
-
RequestBodyto trigger profiling instance. - ProfilingRequestBody(ProfilingInfo.ProfilingMode, int) - Constructor for class org.apache.flink.runtime.rest.messages.cluster.ProfilingRequestBody
- ProfilingService - Class in org.apache.flink.runtime.util.profiler
-
Create and keep profiling requests with rolling policy.
- ProgressiveTimestampsAndWatermarks<T> - Class in org.apache.flink.streaming.api.operators.source
-
An implementation of
TimestampsAndWatermarksthat does periodic watermark emission and keeps track of watermarks on a per-split basis. - ProgressiveTimestampsAndWatermarks(TimestampAssigner<T>, WatermarkGeneratorSupplier<T>, TimestampsAndWatermarks.TimestampsAndWatermarksContextProvider, ProcessingTimeService, Duration, RelativeClock, Clock, TaskIOMetricGroup) - Constructor for class org.apache.flink.streaming.api.operators.source.ProgressiveTimestampsAndWatermarks
- project(int...) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Initiates a Project transformation on a
TupleDataStream.
Note: Only Tuple DataStreams can be projected. - projectTuple1() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple10() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple11() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple12() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple13() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple14() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple15() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple16() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple17() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple18() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple19() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple2() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple20() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple21() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple22() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple23() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple24() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple25() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple3() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple4() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple5() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple6() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple7() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple8() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTuple9() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Projects a
TupleDataStreamto the previously selected fields. - projectTupleX() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
-
Chooses a projectTupleX according to the length of
StreamProjection.fieldIndexes. - promoteJobPartitions(Collection<ResultPartitionID>) - Method in interface org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTracker
-
Promotes the given partitions.
- promoteJobPartitions(Collection<ResultPartitionID>) - Method in class org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTrackerImpl
- promotePartitions(JobID, Set<ResultPartitionID>) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- promotePartitions(JobID, Set<ResultPartitionID>) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Batch promote intermediate result partitions.
- promotePartitions(JobID, Set<ResultPartitionID>) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- providePhysicalFile() - Method in interface org.apache.flink.runtime.state.filesystem.FileMergingCheckpointStateOutputStream.FileMergingSnapshotManagerProxy
-
Provide a physical file.
- Provider(OperatorID) - Constructor for class org.apache.flink.runtime.operators.coordination.RecreateOnResetOperatorCoordinator.Provider
- Provider(OperatorID, int) - Constructor for class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator.Provider
- ProxyMetricGroup<P extends org.apache.flink.metrics.MetricGroup> - Class in org.apache.flink.runtime.metrics.groups
-
Metric group which forwards all registration calls to its parent metric group.
- ProxyMetricGroup(P) - Constructor for class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
- pruneCheckpoints(LongPredicate, boolean) - Method in class org.apache.flink.runtime.state.ChangelogTaskLocalStateStore
- pruneCheckpoints(LongPredicate, boolean) - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
Pruning the useless checkpoints, it should be called only when holding the
TaskLocalStateStoreImpl.lock. - pruneMatchingCheckpoints(LongPredicate) - Method in class org.apache.flink.runtime.state.NoOpTaskLocalStateStoreImpl
- pruneMatchingCheckpoints(LongPredicate) - Method in interface org.apache.flink.runtime.state.TaskLocalStateStore
-
Remove all checkpoints from the store that match the given predicate.
- pruneMatchingCheckpoints(LongPredicate) - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
- publish(TaskEvent) - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
- publish(TaskEvent) - Method in class org.apache.flink.runtime.io.network.api.TaskEventHandler
-
Publishes the task event to all subscribed event listeners.
- publish(ResultPartitionID, TaskEvent) - Method in class org.apache.flink.runtime.io.network.TaskEventDispatcher
-
Publishes the event to the registered
EventListenerinstances. - publish(ResultPartitionID, TaskEvent) - Method in interface org.apache.flink.runtime.io.network.TaskEventPublisher
-
Publishes the event to the registered
EventListenerinstances. - publishLeaderInformation(String, LeaderInformation) - Method in interface org.apache.flink.runtime.leaderelection.LeaderElectionDriver
-
Publishes the leader information for the given component.
- publishLeaderInformation(String, LeaderInformation) - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionDriver
- publishQueryableStateIfEnabled(StateDescriptor<?, ?>, InternalKvState<?, ?, ?>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- PullingAsyncDataInput<T> - Interface in org.apache.flink.runtime.io
-
Interface defining couple of essential methods for asynchronous and non blocking data polling.
- PullingAsyncDataInput.EndOfDataStatus - Enum in org.apache.flink.runtime.io
-
Status for describing if we have reached the end of data.
- PURGE - org.apache.flink.streaming.api.windowing.triggers.TriggerResult
-
All elements in the window are cleared and the window is discarded, without evaluating the window function or emitting any elements.
- PurgingTrigger<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A trigger that can turn any
Triggerinto a purgingTrigger. - pushDownPages() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
- PushingAsyncDataInput<T> - Interface in org.apache.flink.streaming.runtime.io
-
The variant of
PullingAsyncDataInputthat is defined for handling both network input and source input in a unified way viaPushingAsyncDataInput.emitNext(DataOutput)instead of returningOptional.empty()viaPullingAsyncDataInput.pollNext(). - PushingAsyncDataInput.DataOutput<T> - Interface in org.apache.flink.streaming.runtime.io
-
Basic data output interface used in emitting the next element from data input.
- PushSorter<E> - Interface in org.apache.flink.runtime.operators.sort
-
A push-based
Sorter. - put(int, List<T>) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.index.FileDataIndexCache
-
Put regions to cache.
- put(A, B, V) - Method in class org.apache.flink.runtime.util.DualKeyLinkedMap
- put(G, K, V) - Method in class org.apache.flink.runtime.util.DefaultGroupCache
- put(G, K, V) - Method in interface org.apache.flink.runtime.util.GroupCache
-
Put group, key and value to cache.
- put(File, JobID, BlobKey) - Method in interface org.apache.flink.runtime.blob.BlobStore
-
Copies the local file to the blob store.
- put(File, JobID, BlobKey) - Method in class org.apache.flink.runtime.blob.FileSystemBlobStore
- put(File, JobID, BlobKey) - Method in class org.apache.flink.runtime.blob.VoidBlobStore
- put(K, int, N, S) - Method in class org.apache.flink.runtime.state.heap.StateTable
- put(K, N, S) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
- put(K, N, S) - Method in class org.apache.flink.runtime.state.heap.StateMap
-
Maps the specified key/namespace composite key to the specified value.
- put(K, V) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
- put(N, S) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Maps the composite of active key and given namespace to the specified state.
- put(JobVertexID, IntermediateDataSetID, JobVertexInputInfo) - Method in class org.apache.flink.runtime.executiongraph.VertexInputInfoStore
-
Put a
JobVertexInputInfo. - put(ExecutionGraphInfo) - Method in interface org.apache.flink.runtime.dispatcher.ExecutionGraphInfoStore
-
Store the given
ExecutionGraphInfoin the store. - put(ExecutionGraphInfo) - Method in class org.apache.flink.runtime.dispatcher.FileExecutionGraphInfoStore
- put(ExecutionGraphInfo) - Method in class org.apache.flink.runtime.dispatcher.MemoryExecutionGraphInfoStore
- put(Mail) - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
Enqueues the given mail to the mailbox and blocks until there is capacity for a successful put.
- put(Mail) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
- put(T) - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
-
Adds a buffer to a PriorityQueue in log(size) time.
- put(UK, UV) - Method in class org.apache.flink.runtime.state.v2.adaptor.MapStateAdaptor
- put(UK, V) - Method in class org.apache.flink.runtime.state.v2.AbstractMapState
- PUT - org.apache.flink.runtime.rest.HttpMethodWrapper
- putAll(Map<K, V>) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
- putAll(Map<UK, UV>) - Method in class org.apache.flink.runtime.state.v2.adaptor.MapStateAdaptor
- putAll(Map<UK, V>) - Method in class org.apache.flink.runtime.state.v2.AbstractMapState
- putAndGetOld(K, N, S) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
- putAndGetOld(K, N, S) - Method in class org.apache.flink.runtime.state.heap.StateMap
-
Maps the composite of active key and given namespace to the specified state.
- putFirst(Mail) - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
Adds the given action to the head of the mailbox.
- putFirst(Mail) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
- putIfAbsent(Object, Object) - Method in interface org.apache.flink.runtime.operators.coordination.CoordinatorStore
- putIfAbsent(Object, Object) - Method in class org.apache.flink.runtime.operators.coordination.CoordinatorStoreImpl
- putJobGraph(JobGraph) - Method in class org.apache.flink.runtime.jobmanager.DefaultJobGraphStore
- putJobGraph(JobGraph) - Method in interface org.apache.flink.runtime.jobmanager.JobGraphWriter
-
Adds the
JobGraphinstance. - putJobGraph(JobGraph) - Method in class org.apache.flink.runtime.jobmanager.StandaloneJobGraphStore
- putJobGraph(JobGraph) - Method in enum org.apache.flink.runtime.jobmanager.ThrowingJobGraphWriter
- putJobResourceRequirements(JobID, JobResourceRequirements) - Method in class org.apache.flink.runtime.jobmanager.DefaultJobGraphStore
- putJobResourceRequirements(JobID, JobResourceRequirements) - Method in interface org.apache.flink.runtime.jobmanager.JobGraphWriter
-
Persist
job resource requirementsfor the given job. - putJobResourceRequirements(JobID, JobResourceRequirements) - Method in class org.apache.flink.runtime.jobmanager.StandaloneJobGraphStore
- putJobResourceRequirements(JobID, JobResourceRequirements) - Method in enum org.apache.flink.runtime.jobmanager.ThrowingJobGraphWriter
- putNormalizedKey(Tuple2<byte[], INPUT>, MemorySegment, int, int) - Method in class org.apache.flink.streaming.api.operators.sortpartition.FixedLengthByteKeyAndValueComparator
- putNormalizedKey(Tuple2<byte[], INPUT>, MemorySegment, int, int) - Method in class org.apache.flink.streaming.api.operators.sortpartition.VariableLengthByteKeyAndValueComparator
- putPermanent(JobID, byte[]) - Method in class org.apache.flink.runtime.blob.BlobServer
- putPermanent(JobID, byte[]) - Method in interface org.apache.flink.runtime.blob.BlobWriter
-
Uploads the data of the given byte array for the given job to the BLOB server and makes it a permanent BLOB.
- putPermanent(JobID, byte[]) - Method in class org.apache.flink.runtime.blob.VoidBlobWriter
- putPermanent(JobID, InputStream) - Method in class org.apache.flink.runtime.blob.BlobServer
- putPermanent(JobID, InputStream) - Method in interface org.apache.flink.runtime.blob.BlobWriter
-
Uploads the data from the given input stream for the given job to the BLOB server and makes it a permanent BLOB.
- putPermanent(JobID, InputStream) - Method in class org.apache.flink.runtime.blob.VoidBlobWriter
- putState(int, OperatorSubtaskState) - Method in class org.apache.flink.runtime.checkpoint.FullyFinishedOperatorState
- putState(int, OperatorSubtaskState) - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- putState(int, SubtaskState) - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- putSubtaskStateByOperatorID(OperatorID, OperatorSubtaskState) - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
-
Maps the given operator id to the given subtask state.
- putTransient(byte[]) - Method in class org.apache.flink.runtime.blob.BlobServer
- putTransient(byte[]) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
- putTransient(byte[]) - Method in interface org.apache.flink.runtime.blob.TransientBlobService
-
Uploads the (job-unrelated) data of the given byte array to the BLOB server.
- putTransient(InputStream) - Method in class org.apache.flink.runtime.blob.BlobServer
- putTransient(InputStream) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
- putTransient(InputStream) - Method in interface org.apache.flink.runtime.blob.TransientBlobService
-
Uploads the (job-unrelated) data from the given input stream to the BLOB server.
- putTransient(JobID, byte[]) - Method in class org.apache.flink.runtime.blob.BlobServer
- putTransient(JobID, byte[]) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
- putTransient(JobID, byte[]) - Method in interface org.apache.flink.runtime.blob.TransientBlobService
-
Uploads the data of the given byte array for the given job to the BLOB server.
- putTransient(JobID, InputStream) - Method in class org.apache.flink.runtime.blob.BlobServer
- putTransient(JobID, InputStream) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
- putTransient(JobID, InputStream) - Method in interface org.apache.flink.runtime.blob.TransientBlobService
-
Uploads the data from the given input stream for the given job to the BLOB server.
- putVariables(Map<String, String>) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Enters all variables specific to this
AbstractMetricGroupand their associated values into the map. - putVariables(Map<String, String>) - Method in class org.apache.flink.runtime.metrics.groups.GenericValueMetricGroup
- putVariables(Map<String, String>) - Method in class org.apache.flink.runtime.metrics.groups.InternalOperatorMetricGroup
- putVariables(Map<String, String>) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
- putVariables(Map<String, String>) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerOperatorMetricGroup
- putVariables(Map<String, String>) - Method in class org.apache.flink.runtime.metrics.groups.JobMetricGroup
- putVariables(Map<String, String>) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
- putVariables(Map<String, String>) - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
Q
- QueryableAppendingStateOperator<IN> - Class in org.apache.flink.streaming.api.functions.query
-
Internal operator handling queryable AppendingState instances.
- QueryableAppendingStateOperator(String, StateDescriptor<? extends AppendingState<IN, ?>, ?>) - Constructor for class org.apache.flink.streaming.api.functions.query.QueryableAppendingStateOperator
- QueryableStateConfiguration - Class in org.apache.flink.runtime.taskexecutor
-
Simple configuration object for the parameters for the server-side of queryable state.
- QueryableStateConfiguration(Iterator<Integer>, Iterator<Integer>, int, int, int, int) - Constructor for class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
- QueryableStateStream<K,V> - Class in org.apache.flink.streaming.api.datastream
-
Deprecated.The Queryable State feature is deprecated since Flink 1.18, and will be removed in a future Flink major version.
- QueryableStateStream(String, StateDescriptor<?, V>, TypeSerializer<K>) - Constructor for class org.apache.flink.streaming.api.datastream.QueryableStateStream
-
Deprecated.Creates a queryable state stream.
- QueryableStateUtils - Class in org.apache.flink.runtime.query
-
Utility class to initialize entities used in queryable state.
- QueryableStateUtils() - Constructor for class org.apache.flink.runtime.query.QueryableStateUtils
- QueryableValueStateOperator<IN> - Class in org.apache.flink.streaming.api.functions.query
-
Internal operator handling queryable ValueState instances.
- QueryableValueStateOperator(String, StateDescriptor<ValueState<IN>, IN>) - Constructor for class org.apache.flink.streaming.api.functions.query.QueryableValueStateOperator
- queryMetrics(Duration) - Method in class org.apache.flink.runtime.metrics.dump.MetricQueryService
- queryMetrics(Duration) - Method in interface org.apache.flink.runtime.webmonitor.retriever.MetricQueryServiceGateway
- queryParam(String) - Method in class org.apache.flink.runtime.rest.handler.router.RouteResult
-
Extracts the first matching param in
queryParams. - queryParams() - Method in class org.apache.flink.runtime.rest.handler.router.RouteResult
-
Returns all params in the query part of the request URI.
- QueryScopeInfo - Class in org.apache.flink.runtime.metrics.dump
-
Container for scope related information as required by the MetricQueryService.
- QueryScopeInfo.JobManagerOperatorQueryScopeInfo - Class in org.apache.flink.runtime.metrics.dump
-
Container for the job manager operator scope.
- QueryScopeInfo.JobManagerQueryScopeInfo - Class in org.apache.flink.runtime.metrics.dump
-
Container for the job manager scope.
- QueryScopeInfo.JobQueryScopeInfo - Class in org.apache.flink.runtime.metrics.dump
-
Container for the job scope.
- QueryScopeInfo.OperatorQueryScopeInfo - Class in org.apache.flink.runtime.metrics.dump
-
Container for the operator scope.
- QueryScopeInfo.TaskManagerQueryScopeInfo - Class in org.apache.flink.runtime.metrics.dump
-
Container for the task manager scope.
- QueryScopeInfo.TaskQueryScopeInfo - Class in org.apache.flink.runtime.metrics.dump
-
Container for the task scope.
- queryServiceScopeInfo - Variable in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
The metrics query service scope represented by this group, lazily computed.
- queue - Variable in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
-
The array that represents the heap-organized priority queue.
- queueStatus() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationResult
- queueStatus() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
- queueStatus() - Method in interface org.apache.flink.runtime.rest.messages.queue.AsynchronouslyCreatedResource
-
Returns the status of the resource creation.
- QueueStatus - Class in org.apache.flink.runtime.rest.messages.queue
-
Response type for temporary queue resources, i.e., resources that are asynchronously created.
- QueueStatus(QueueStatus.Id) - Constructor for class org.apache.flink.runtime.rest.messages.queue.QueueStatus
- QueueStatus.Id - Enum in org.apache.flink.runtime.rest.messages.queue
-
Defines queue statuses.
- QueuingCallback<T> - Class in org.apache.flink.runtime.io.disk.iomanager
-
A
RequestDoneCallbackthat adds the memory segments to a blocking queue. - QueuingCallback(LinkedBlockingQueue<T>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.QueuingCallback
- QuickSort - Class in org.apache.flink.runtime.operators.sort
- QuickSort() - Constructor for class org.apache.flink.runtime.operators.sort.QuickSort
- quiesce() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
Quiesce the mailbox.
- quiesce() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
- quiesce() - Method in interface org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
-
This method puts the service into a state where it does not register new timers, but returns for each call to
ProcessingTimeService.registerTimer(long, org.apache.flink.api.common.operators.ProcessingTimeService.ProcessingTimeCallback)orProcessingTimeService.scheduleAtFixedRate(org.apache.flink.api.common.operators.ProcessingTimeService.ProcessingTimeCallback, long, long)a "mock" future and the "mock" future will be never completed. - quiesce() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
- QUIESCED - org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox.State
R
- RANDOM - org.apache.flink.streaming.api.windowing.assigners.WindowStagger
-
Stagger offset is sampled from uniform distribution U(0, WindowSize) when first event ingested in the partitioned operator.
- RandomAccessInputView - Class in org.apache.flink.runtime.io.disk
- RandomAccessInputView(ArrayList<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.RandomAccessInputView
- RandomAccessInputView(ArrayList<MemorySegment>, int, int) - Constructor for class org.apache.flink.runtime.io.disk.RandomAccessInputView
- RandomAccessOutputView - Class in org.apache.flink.runtime.io.disk
- RandomAccessOutputView(MemorySegment[], int) - Constructor for class org.apache.flink.runtime.io.disk.RandomAccessOutputView
- RandomAccessOutputView(MemorySegment[], int, int) - Constructor for class org.apache.flink.runtime.io.disk.RandomAccessOutputView
- randomEmit(T) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
This is used to send LatencyMarks to a random target subpartition.
- randomId() - Static method in class org.apache.flink.runtime.executiongraph.ExecutionAttemptID
- randomStateHandleId() - Static method in class org.apache.flink.runtime.state.StateHandleID
- RANGE - org.apache.flink.runtime.io.network.api.writer.SubtaskStateMapper
-
Remaps old ranges to new ranges.
- RangeBoundaryBuilder<T> - Class in org.apache.flink.runtime.operators.udf
-
Build RangeBoundaries with input records.
- RangeBoundaryBuilder(TypeComparatorFactory<T>, int) - Constructor for class org.apache.flink.runtime.operators.udf.RangeBoundaryBuilder
- RangeFraction - Class in org.apache.flink.runtime.util.config.memory
-
Range and fraction of a memory component, which is a capped fraction of another component.
- rate - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.MeterDump
- RawJson(String) - Constructor for class org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson
- RawJsonDeserializer - Class in org.apache.flink.runtime.rest.messages.json
-
Json deserializer which deserializes raw json.
- RawJsonDeserializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.RawJsonDeserializer
- rawKeyedStateInputs() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
-
Returns an iterable to obtain input streams for previously stored keyed state partitions that are assigned to this operator.
- rawKeyedStateInputs(Iterator<StateObjectCollection<KeyedStateHandle>>, StateObject.StateObjectSizeStatsCollector) - Method in class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
- rawOperatorStateInputs() - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateContext
-
Returns an iterable to obtain input streams for previously stored operator state partitions that are assigned to this stream operator.
- rawOperatorStateInputs(Iterator<StateObjectCollection<OperatorStateHandle>>, StateObject.StateObjectSizeStatsCollector) - Method in class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
- read() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileSegmentReader
- read() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileSegmentReader
- read() - Method in class org.apache.flink.runtime.state.BoundedInputStream
- read() - Method in class org.apache.flink.runtime.state.CompressibleFSDataInputStream
- read() - Method in class org.apache.flink.runtime.state.filesystem.FsSegmentDataInputStream
- read() - Method in class org.apache.flink.runtime.util.ForwardingInputStream
- read(byte[]) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
- read(byte[]) - Method in class org.apache.flink.runtime.state.BoundedInputStream
- read(byte[]) - Method in class org.apache.flink.runtime.state.filesystem.FsSegmentDataInputStream
- read(byte[]) - Method in class org.apache.flink.runtime.util.ForwardingInputStream
- read(byte[], int, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
- read(byte[], int, int) - Method in class org.apache.flink.runtime.state.BoundedInputStream
- read(byte[], int, int) - Method in class org.apache.flink.runtime.state.filesystem.FsSegmentDataInputStream
- read(byte[], int, int) - Method in class org.apache.flink.runtime.util.ForwardingInputStream
- read(DataInputView) - Method in class org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
- read(DataInputView) - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
- read(DataInputView) - Method in class org.apache.flink.runtime.io.network.api.EndOfData
- read(DataInputView) - Method in class org.apache.flink.runtime.io.network.api.EndOfPartitionEvent
- read(DataInputView) - Method in class org.apache.flink.runtime.io.network.api.EndOfSegmentEvent
- read(DataInputView) - Method in class org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
- read(DataInputView) - Method in class org.apache.flink.runtime.io.network.api.EventAnnouncement
- read(DataInputView) - Method in class org.apache.flink.runtime.io.network.api.RecoveryMetadata
- read(DataInputView) - Method in class org.apache.flink.runtime.io.network.api.SubtaskConnectionDescriptor
- read(DataInputView) - Method in class org.apache.flink.runtime.io.network.partition.consumer.EndOfChannelStateEvent
- read(DataInputView) - Method in class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
- read(DataInputView) - Method in class org.apache.flink.runtime.iterative.event.TerminationEvent
- read(DataInputView) - Method in class org.apache.flink.runtime.iterative.event.WorkerDoneEvent
- read(DataInputView) - Method in class org.apache.flink.runtime.plugable.NonReusingDeserializationDelegate
- read(DataInputView) - Method in class org.apache.flink.runtime.plugable.ReusingDeserializationDelegate
- read(DataInputView) - Method in class org.apache.flink.runtime.plugable.SerializationDelegate
- read(DataInputView) - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
- read(DataInputView) - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
- read(DataInputView, boolean) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
- read(StreamStateHandle, long) - Method in interface org.apache.flink.runtime.state.changelog.StateChangelogHandleStreamHandleReader.StateChangeIterator
- READ - org.apache.flink.runtime.operators.sort.StageRunner.SortStage
- READ_OUTPUT_DATA_DURATION - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- readableBytes() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Returns the number of readable bytes (same as
Buffer.getSize()-Buffer.getReaderIndex()). - readableBytes() - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- readableBytes() - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- readAndSetBroadcastInput(int, String, DistributedRuntimeUDFContext, int) - Method in class org.apache.flink.runtime.operators.BatchTask
- readBlock(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockReader
-
Issues a read request, which will asynchronously fill the given segment with the next block in the underlying file channel.
- readBlock(T) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelReader
-
Issues a read request, which will fill the given segment with the next block in the underlying file channel.
- readBoolean() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
- readBuffer(int, int) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyConnectionReader
-
Read a buffer from netty connection.
- readBuffer(int, int) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyConnectionReaderImpl
- readBuffer(TieredStoragePartitionId, TieredStorageSubpartitionId, int, int, MemorySegment, BufferRecycler, PartitionFileReader.ReadProgress, CompositeBuffer) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.PartitionFileReader
-
Read a buffer from the partition file.
- readBuffer(TieredStoragePartitionId, TieredStorageSubpartitionId, int, int, MemorySegment, BufferRecycler, PartitionFileReader.ReadProgress, CompositeBuffer) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.ProducerMergedPartitionFileReader
- readBuffer(TieredStoragePartitionId, TieredStorageSubpartitionId, int, int, MemorySegment, BufferRecycler, PartitionFileReader.ReadProgress, CompositeBuffer) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.SegmentPartitionFileReader
- readBufferFromFileChannel(Buffer) - Method in class org.apache.flink.runtime.io.disk.iomanager.BufferFileChannelReader
-
Reads data from the object's file channel into the given buffer.
- ReadBufferResult(List<Buffer>, boolean, PartitionFileReader.ReadProgress) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.PartitionFileReader.ReadBufferResult
- readByte() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
- readByteBufferFully(FileChannel, ByteBuffer) - Static method in class org.apache.flink.runtime.io.network.partition.BufferReaderWriterUtil
- readByteBufferFully(FileChannel, ByteBuffer, long) - Static method in class org.apache.flink.runtime.io.network.partition.BufferReaderWriterUtil
- readBytes(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- readChar() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
- readDouble() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
- readElement(DataInputView) - Method in interface org.apache.flink.runtime.state.KeyGroupPartitioner.ElementReaderFunction
- reader - Variable in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
- Reader<T extends org.apache.flink.core.io.IOReadableWritable> - Interface in org.apache.flink.runtime.io.network.api.reader
-
A record-oriented reader for immutable record types.
- ReaderBase - Interface in org.apache.flink.runtime.io.network.api.reader
-
The basic API for every reader.
- readerForVersion(StateTable<K, N, S>, int) - Static method in class org.apache.flink.runtime.state.heap.StateTableByKeyGroupReaders
-
Creates a new StateTableByKeyGroupReader that inserts de-serialized mappings into the given table, using the de-serialization algorithm that matches the given version.
- ReaderIterator<T> - Class in org.apache.flink.runtime.operators.util
-
A
MutableObjectIteratorthat wraps a reader from an input channel and produces the reader's records. - ReaderIterator(MutableReader<DeserializationDelegate<T>>, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.operators.util.ReaderIterator
-
Creates a new iterator, wrapping the given reader.
- ReaderRegistrationEvent - Class in org.apache.flink.runtime.source.event
-
An
OperatorEventthat registers aSourceReaderto the SourceCoordinator. - ReaderRegistrationEvent(int, String) - Constructor for class org.apache.flink.runtime.source.event.ReaderRegistrationEvent
- readEvent() - Method in class org.apache.flink.runtime.jobmaster.event.FileSystemJobEventStore
- readEvent() - Method in interface org.apache.flink.runtime.jobmaster.event.JobEventStore
-
Read a job event.
- readFile(FileInputFormat<OUT>, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Deprecated.Use
FileSource#forRecordStreamFormat()/forBulkFileFormat()/forRecordFileFormat() instead. An example of reading a file using a simpleTextLineInputFormat:FileSource<String> source = FileSource.forRecordStreamFormat( new TextLineInputFormat(), new Path("/foo/bar")) .build(); - readFile(FileInputFormat<OUT>, String, FileProcessingMode, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Deprecated.Use
FileSource#forRecordStreamFormat()/forBulkFileFormat()/forRecordFileFormat() instead. An example of reading a file using a simpleTextLineInputFormat:FileSource<String> source = FileSource.forRecordStreamFormat( new TextLineInputFormat(), new Path("/foo/bar")) .monitorContinuously(Duration.of(10, SECONDS)) .build(); - readFile(FileInputFormat<OUT>, String, FileProcessingMode, long, FilePathFilter) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Deprecated.Use
FileInputFormat.setFilesFilter(FilePathFilter)to set a filter andStreamExecutionEnvironment.readFile(FileInputFormat, String, FileProcessingMode, long) - readFile(FileInputFormat<OUT>, String, FileProcessingMode, long, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Deprecated.Use
FileSource#forRecordStreamFormat()/forBulkFileFormat()/forRecordFileFormat() instead. An example of reading a file using a simpleTextLineInputFormat:FileSource<String> source = FileSource.forRecordStreamFormat( new TextLineInputFormat(), new Path("/foo/bar")) .monitorContinuously(Duration.of(10, SECONDS)) .build(); - readFile(JobID, PermanentBlobKey) - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
-
Returns the content of the file for the BLOB with the provided job ID the blob key.
- readFile(JobID, PermanentBlobKey) - Method in interface org.apache.flink.runtime.blob.PermanentBlobService
-
Returns the content of the file for the BLOB with the provided job ID the blob key.
- readFileStream(String, long, FileMonitoringFunction.WatchType) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Deprecated.
- readFixedSizeRegionFromFile(FileChannel, ByteBuffer, long) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.index.FileRegionWriteReadUtils
- readFloat() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
- readFromByteChannel(FileChannel, ByteBuffer, MemorySegment, BufferRecycler) - Static method in class org.apache.flink.runtime.io.network.partition.BufferReaderWriterUtil
- readFromJobGraph(JobGraph) - Static method in class org.apache.flink.runtime.jobgraph.JobResourceRequirements
-
Read
resource requirementsfrom the configuration of a givenJobGraph. - readFully(byte[]) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
- readFully(byte[], int, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
- readIndexEntryAddress - Variable in class org.apache.flink.runtime.io.network.partition.SortBuffer
-
Index entry address of the current record or event to be read.
- readInputData(InputGate[]) - Method in interface org.apache.flink.runtime.checkpoint.channel.SequentialChannelStateReader
- readInputData(InputGate[]) - Method in class org.apache.flink.runtime.checkpoint.channel.SequentialChannelStateReaderImpl
- readInt() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
- readIntLE(byte[], int) - Static method in class org.apache.flink.runtime.io.compression.CompressorUtils
- readInto(MemorySegment) - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- readInto(Buffer) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileReader
- readInto(Buffer) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileReader
- readInto(Buffer) - Method in class org.apache.flink.runtime.io.disk.iomanager.SynchronousBufferFileReader
- readKey(TypeSerializer<K>, DataInputDeserializer, boolean) - Static method in class org.apache.flink.runtime.state.CompositeKeySerializationUtils
- readKeyGroup(int, DataInputView) - Static method in class org.apache.flink.runtime.state.CompositeKeySerializationUtils
- readLeaderInformation(byte[]) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
- readLine() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
- readLong() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
- readMappingsInKeyGroup(DataInputView, int) - Method in interface org.apache.flink.runtime.state.StateSnapshotKeyGroupReader
-
Read the data for the specified key-group from the input.
- readNamespace(TypeSerializer<N>, DataInputDeserializer, boolean) - Static method in class org.apache.flink.runtime.state.CompositeKeySerializationUtils
- ReadOnlyContext() - Constructor for class org.apache.flink.streaming.api.functions.co.BaseBroadcastProcessFunction.ReadOnlyContext
- ReadOnlyContext() - Constructor for class org.apache.flink.streaming.api.functions.co.BroadcastProcessFunction.ReadOnlyContext
- ReadOnlyContext() - Constructor for class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.ReadOnlyContext
- readOnlySlice() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Returns a read-only slice of this buffer's readable bytes, i.e. between
Buffer.getReaderIndex()andBuffer.getSize(). - readOnlySlice() - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- readOnlySlice() - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- readOnlySlice() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- readOnlySlice() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- readOnlySlice(int, int) - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Returns a read-only slice of this buffer.
- readOnlySlice(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- readOnlySlice(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- readOnlySlice(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- readOnlySlice(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- ReadOnlySlicedNetworkBuffer - Class in org.apache.flink.runtime.io.network.buffer
-
Minimal best-effort read-only sliced
Bufferimplementation wrapping aNetworkBuffer's sub-region based on io.netty.buffer.SlicedByteBuf and io.netty.buffer.ReadOnlyByteBuf. - readOrderIndex - Variable in class org.apache.flink.runtime.io.network.partition.SortBuffer
-
Used to index the current available subpartition to read data from.
- readOutputData(ResultPartitionWriter[], boolean) - Method in interface org.apache.flink.runtime.checkpoint.channel.SequentialChannelStateReader
- readOutputData(ResultPartitionWriter[], boolean) - Method in class org.apache.flink.runtime.checkpoint.channel.SequentialChannelStateReaderImpl
- readPhase - Variable in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
- readRecordAt(long) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
- readRecordAt(long, T) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
- readRegionFromFile(FileChannel, long) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.index.FileDataIndexRegionHelper
-
Read a region from the file.
- readResolve() - Method in class org.apache.flink.runtime.messages.Acknowledge
-
Read resolve to preserve the singleton object property.
- readResolve() - Method in class org.apache.flink.runtime.state.CheckpointStorageLocationReference
-
readResolve() preserves the singleton property of the default value.
- readShort() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
- readStateMetaInfoSnapshot(DataInputView, ClassLoader) - Method in interface org.apache.flink.runtime.state.metainfo.StateMetaInfoReader
-
Reads a snapshot from the given input view.
- readTimersSnapshot(DataInputView) - Method in interface org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.InternalTimersSnapshotReader
-
Reads a timers snapshot from the provided input view.
- readUnsignedByte() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
- readUnsignedShort() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
- readUTF() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
- readVariableIntBytes(DataInputView, int) - Static method in class org.apache.flink.runtime.state.CompositeKeySerializationUtils
- readVersionAndDeserializeList(SimpleVersionedSerializer<T>, DataInputView) - Static method in class org.apache.flink.streaming.runtime.operators.sink.committables.SinkV1CommittableDeserializer
- readWithKeyDenormalization(Tuple2<byte[], INPUT>, DataInputView) - Method in class org.apache.flink.streaming.api.operators.sortpartition.FixedLengthByteKeyAndValueComparator
- readWithKeyDenormalization(Tuple2<byte[], INPUT>, DataInputView) - Method in class org.apache.flink.streaming.api.operators.sortpartition.VariableLengthByteKeyAndValueComparator
- readWriteLock - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
-
Lock guarding concurrent file accesses.
- rebalance() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStreamso that the output elements are distributed evenly to instances of the next operation in a round-robin fashion. - RebalancePartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that distributes the data equally by cycling through the output channels.
- RebalancePartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
- rebound(long) - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl
- rebound(long) - Method in interface org.apache.flink.runtime.state.changelog.ChangelogStateBackendHandle
- rebound(long) - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendLocalHandle
- rebound(long) - Method in interface org.apache.flink.runtime.state.CheckpointBoundKeyedStateHandle
-
Returns a new
CheckpointBoundKeyedStateHandleRebounding checkpoint id to a specific checkpoint id. - rebound(long) - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
- rebound(long) - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
- recalculateBufferSize(long, int) - Method in class org.apache.flink.runtime.throughput.BufferDebloater
- receive(ByteBuffer, TieredStorageSubpartitionId, Buffer.DataType, boolean) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.BufferAccumulator
-
Receives the records from tiered store producer, these records will be accumulated and transformed into finished buffers.
- receive(ByteBuffer, TieredStorageSubpartitionId, Buffer.DataType, boolean) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.HashBufferAccumulator
- receive(ByteBuffer, TieredStorageSubpartitionId, Buffer.DataType, boolean) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.SortBufferAccumulator
- receiveAcknowledgeMessage(AcknowledgeCheckpoint, String) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Receives an AcknowledgeCheckpoint message and returns whether the message was associated with a pending checkpoint.
- RECEIVED - org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestState
- receiveDeclineMessage(DeclineCheckpoint, String) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Receives a
DeclineCheckpointmessage for a pending checkpoint. - receiveHeartbeat(ResourceID, I) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatSender
- receiveHeartbeat(ResourceID, I) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatTarget
-
Sends a heartbeat response to the target.
- receiveHeartbeat(ResourceID, I) - Method in class org.apache.flink.runtime.heartbeat.NoOpHeartbeatManager
- recentPendingRequestIds - Variable in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator
-
A list of recent request IDs to identify late messages vs. invalid ones.
- reconcileExecutionDeployments(ResourceID, ExecutionDeploymentReport, Map<ExecutionAttemptID, ExecutionDeploymentState>) - Method in class org.apache.flink.runtime.jobmaster.DefaultExecutionDeploymentReconciler
- reconcileExecutionDeployments(ResourceID, ExecutionDeploymentReport, Map<ExecutionAttemptID, ExecutionDeploymentState>) - Method in interface org.apache.flink.runtime.jobmaster.ExecutionDeploymentReconciler
-
Reconciles the deployment states between all reported/expected executions for the given task executor.
- RECONCILING - org.apache.flink.runtime.execution.ExecutionState
- reconnect(JobID) - Method in class org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService
- reconnect(JobID) - Method in interface org.apache.flink.runtime.taskexecutor.JobLeaderService
-
Triggers reconnection to the last known leader of the given job.
- RECORD_ORDER - org.apache.flink.streaming.runtime.operators.asyncprocessing.ElementOrder
-
Treat the record processing as a whole, meaning that any
processElementcall for the elements with same key should follow the order of record arrival AND no parallel run is allowed. - RecordAttributes - Class in org.apache.flink.streaming.runtime.streamrecord
-
A RecordAttributes describes the attributes of records from the current RecordAttributes until the next one is received.
- RecordAttributes(boolean) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.RecordAttributes
- RecordAttributesBuilder - Class in org.apache.flink.streaming.runtime.streamrecord
-
The builder class for
RecordAttributes. - RecordAttributesBuilder(List<RecordAttributes>) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.RecordAttributesBuilder
-
This constructor takes a list of the last RecordAttributes received from each of the operator's inputs.
- RecordAttributesCombiner - Class in org.apache.flink.streaming.runtime.io
-
RecordAttributesValve combine RecordAttributes from different input channels.
- RecordAttributesCombiner(int) - Constructor for class org.apache.flink.streaming.runtime.io.RecordAttributesCombiner
- RecordContext<K> - Class in org.apache.flink.runtime.asyncprocessing
-
A context that preserves the necessary variables required by each operation, all operations for one record will share the same element context.
- RecordContext(Object, K, Consumer<RecordContext<K>>, int, EpochManager.Epoch) - Constructor for class org.apache.flink.runtime.asyncprocessing.RecordContext
- RecordContext.DisposerRunner - Interface in org.apache.flink.runtime.asyncprocessing
- RecordDeserializer<T extends org.apache.flink.core.io.IOReadableWritable> - Interface in org.apache.flink.runtime.io.network.api.serialization
-
Interface for turning sequences of memory segments into records.
- RecordDeserializer.DeserializationResult - Enum in org.apache.flink.runtime.io.network.api.serialization
-
Status of the deserialization result.
- recordDeserializers - Variable in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
- recordEmitted(long) - Method in class org.apache.flink.runtime.metrics.groups.InternalSourceReaderMetricGroup
-
Called when a new record was emitted with the given timestamp.
- recordModification(ExecutionVertexID) - Method in class org.apache.flink.runtime.scheduler.ExecutionVertexVersioner
- recordPartitionInfo(int, ResultPartitionBytes) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.AllToAllBlockingResultInfo
- recordPartitionInfo(int, ResultPartitionBytes) - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.BlockingResultInfo
-
Record the information of the result partition.
- RecordProcessorUtils - Class in org.apache.flink.streaming.runtime.io
-
Utility class for creating record processor for
InputStreamOperator. - RecordReader<T extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.reader
-
Record oriented reader for immutable types.
- RecordReader(InputGate, Class<T>, String[]) - Constructor for class org.apache.flink.runtime.io.network.api.reader.RecordReader
-
Creates a new RecordReader that de-serializes records from the given input gate and can spill partial records to disk, if they grow large.
- recordRemainingBytes - Variable in class org.apache.flink.runtime.io.network.partition.SortBuffer
-
Record bytes remaining after last copy, which must be read first in next copy.
- recordSize() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
- recordSize() - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
-
Gets the size of each record, the number of bytes separating the head of successive records.
- recordSize() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
- recordsPerSegment() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
- recordsPerSegment() - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
-
Gets the number of elements in each memory segment.
- recordsPerSegment() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
- recordSplitAssignment(SplitsAssignment<SplitT>) - Method in class org.apache.flink.runtime.source.coordinator.SplitAssignmentTracker
-
Record a new split assignment.
- recordTaskEndOfData(ExecutionAttemptID) - Method in class org.apache.flink.runtime.scheduler.VertexEndOfDataListener
- recordTaskFailure(Execution, Throwable) - Method in class org.apache.flink.runtime.scheduler.DefaultScheduler
- recordVertexModifications(Collection<ExecutionVertexID>) - Method in class org.apache.flink.runtime.scheduler.ExecutionVertexVersioner
- recordWriter - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
- RecordWriter<T extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.writer
-
An abstract record-oriented runtime result writer.
- RecordWriterBuilder<T extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.writer
-
Utility class to encapsulate the logic of building a
RecordWriterinstance. - RecordWriterBuilder() - Constructor for class org.apache.flink.runtime.io.network.api.writer.RecordWriterBuilder
- RecordWriterDelegate<T extends org.apache.flink.core.io.IOReadableWritable> - Interface in org.apache.flink.runtime.io.network.api.writer
-
The record writer delegate provides the availability function for task processor, and it might represent a single
RecordWriteror multipleRecordWriterinstances in specific implementations. - RecordWriterOutput<OUT> - Class in org.apache.flink.streaming.runtime.io
-
Implementation of
Outputthat sends data using aRecordWriter. - RecordWriterOutput(RecordWriter<SerializationDelegate<StreamRecord<OUT>>>, TypeSerializer<OUT>, OutputTag, boolean) - Constructor for class org.apache.flink.streaming.runtime.io.RecordWriterOutput
- RecoverableError - org.apache.flink.runtime.throwable.ThrowableType
-
This indicates a problem that is recoverable.
- RecoverableStreamTaskInput<T> - Interface in org.apache.flink.streaming.runtime.io
-
A
StreamTaskInputused during recovery of in-flight data. - RecoverableStreamWrapper - Class in org.apache.flink.runtime.state.filesystem
-
Implementation of
MetadataOutputStreamWrapperencapsulates theRecoverableFsDataOutputStreamforFsCheckpointMetadataOutputStream. - RecoverableStreamWrapper(RecoverableFsDataOutputStream) - Constructor for class org.apache.flink.runtime.state.filesystem.RecoverableStreamWrapper
- recoverCheckpointStore(int, StoreType, SharedStateRegistryFactory, Executor, RecoveryClaimMode) - Method in interface org.apache.flink.runtime.checkpoint.PerJobCheckpointRecoveryFactory.CheckpointStoreRecoveryHelper
- RecoveredInputChannel - Class in org.apache.flink.runtime.io.network.partition.consumer
-
An input channel reads recovered state from previous unaligned checkpoint snapshots.
- recoverExecution(ExecutionAttemptID, TaskManagerLocation, Map<String, Accumulator<?, ?>>, IOMetrics) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Recover the execution attempt status after JM failover.
- recoverJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.DefaultJobGraphStore
- recoverJobGraph(JobID) - Method in interface org.apache.flink.runtime.jobmanager.JobGraphStore
- recoverJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.StandaloneJobGraphStore
- recoverProducedPartitions(Map<IntermediateResultPartitionID, ResultPartitionDeploymentDescriptor>) - Method in class org.apache.flink.runtime.executiongraph.Execution
- RECOVERY - org.apache.flink.runtime.dispatcher.Dispatcher.ExecutionType
- RECOVERY_COMPLETION - org.apache.flink.runtime.io.network.buffer.Buffer.DataType
-
Indicates that this subpartition state is fully recovered (emitted).
- RECOVERY_METADATA - org.apache.flink.runtime.io.network.buffer.Buffer.DataType
-
Contains the metadata used during a recovery process.
- RecoveryMetadata - Class in org.apache.flink.runtime.io.network.api
-
RecoveryMetadatacontains the metadata used during a recovery process. - RecoveryMetadata(int) - Constructor for class org.apache.flink.runtime.io.network.api.RecoveryMetadata
- RecreateOnResetOperatorCoordinator - Class in org.apache.flink.runtime.operators.coordination
-
A class that will recreate a new
OperatorCoordinatorinstance when reset to checkpoint. - RecreateOnResetOperatorCoordinator.Provider - Class in org.apache.flink.runtime.operators.coordination
-
The provider for a private RecreateOnResetOperatorCoordinator.
- recursionLevel - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
- recycle(Collection<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.BatchShuffleReadBufferPool
-
Recycles a collection of buffers to this buffer pool.
- recycle(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.BatchShuffleReadBufferPool
-
Recycles the target buffer to this buffer pool.
- recycle(MemorySegment) - Method in class org.apache.flink.runtime.io.network.buffer.BufferRecycler.DummyBufferRecycler
- recycle(MemorySegment) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferRecycler
-
Recycles the
MemorySegmentto its originalBufferPoolinstance. - recycle(MemorySegment) - Method in class org.apache.flink.runtime.io.network.buffer.FreeingBufferRecycler
-
Frees the given memory segment.
- recycle(MemorySegment) - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
- recycle(MemorySegment) - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferManager
-
Exclusive buffer is recycled to this channel manager directly and it may trigger return extra floating buffer based on numRequiredBuffers.
- recycle(MemorySegment) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskIOScheduler
- recycleBuffer() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Releases this buffer once, i.e. reduces the reference count and recycles the buffer if the reference count reaches 0.
- recycleBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- recycleBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- recycleBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- recycleBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- recyclePooledMemorySegment(MemorySegment) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
Corresponding to
NetworkBufferPool.requestPooledMemorySegmentsBlocking(int)andNetworkBufferPool.requestPooledMemorySegment(), this method is for pooled memory segments recycling. - recycleUnpooledMemorySegments(Collection<MemorySegment>) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
Corresponding to
NetworkBufferPool.requestUnpooledMemorySegments(int), this method is for unpooled memory segments recycling. - RedirectingSslHandler - Class in org.apache.flink.runtime.net
-
SSL handler which automatically redirects Non-SSL requests to SSL address.
- RedirectingSslHandler(String, CompletableFuture<String>, SSLHandlerFactory) - Constructor for class org.apache.flink.runtime.net.RedirectingSslHandler
- redirectSystemOutAndError(Configuration) - Static method in class org.apache.flink.runtime.taskexecutor.SystemOutRedirectionUtils
-
Redirect
System.outandSystem.errbased onTaskManagerOptions.TASK_MANAGER_SYSTEM_OUT_MODErelated options. - reDistributeInputChannelStates(TaskStateAssignment) - Method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
- reDistributePartitionableStates(Map<OperatorID, OperatorState>, int, Function<OperatorSubtaskState, StateObjectCollection<T>>, OperatorStateRepartitioner<T>, Map<OperatorInstanceID, List<T>>) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
- reDistributeResultSubpartitionStates(TaskStateAssignment) - Method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
- reduce(ReduceFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies a reduce function to the window.
- reduce(ReduceFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedPartitionWindowedStream
- reduce(ReduceFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies a reduce transformation on the grouped data stream grouped on by the given key position.
- reduce(ReduceFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.NonKeyedPartitionWindowedStream
- reduce(ReduceFunction<T>) - Method in interface org.apache.flink.streaming.api.datastream.PartitionWindowedStream
-
Applies a reduce transformation on the records of the window.
- reduce(ReduceFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies a reduce function to the window.
- reduce(ReduceFunction<T>, AllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>, AllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>, ProcessAllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>, ProcessAllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>, ProcessWindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>, ProcessWindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
- reduce(ReduceFunction<T>, ProcessWindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>, WindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- reduce(ReduceFunction<T>, WindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
- reduce(ReduceFunction<T>, WindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies the given window function to each window.
- reduce(T, T) - Method in class org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
- reduce(T, T) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumAggregator
- ReduceApplyAllWindowFunction<W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
Internal
AllWindowFunctionthat is used for implementing a fold on a window configuration that only allowsAllWindowFunctionand cannot directly execute aReduceFunction. - ReduceApplyAllWindowFunction(ReduceFunction<T>, AllWindowFunction<T, R, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyAllWindowFunction
- ReduceApplyProcessAllWindowFunction<W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
Internal
ProcessAllWindowFunctionthat is used for implementing a fold on a window configuration that only allowsAllWindowFunctionand cannot directly execute aReduceFunction. - ReduceApplyProcessAllWindowFunction(ReduceFunction<T>, ProcessAllWindowFunction<T, R, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
- ReduceApplyProcessWindowFunction<K,W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
Internal
ProcessWindowFunctionthat is used for implementing a fold on a window configuration that only allowsAllWindowFunctionand cannot directly execute aReduceFunction. - ReduceApplyProcessWindowFunction(ReduceFunction<T>, ProcessWindowFunction<T, R, K, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
- ReduceApplyWindowFunction<K,W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
-
Internal
WindowFunctionthat is used for implementing a fold on a window configuration that only allowsWindowFunctionand cannot directly execute aReduceFunction. - ReduceApplyWindowFunction(ReduceFunction<T>, WindowFunction<T, R, K, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyWindowFunction
- ReduceCombineDriver<T> - Class in org.apache.flink.runtime.operators
-
Combine operator for Reduce functions, standalone (not chained).
- ReduceCombineDriver() - Constructor for class org.apache.flink.runtime.operators.ReduceCombineDriver
- ReduceDriver<T> - Class in org.apache.flink.runtime.operators
-
Reduce driver which is executed by a Task Manager.
- ReduceDriver() - Constructor for class org.apache.flink.runtime.operators.ReduceDriver
- ReduceFacade(ReduceFunction<T>, Collector<T>, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.ReduceFacade
- reduceFunction - Variable in class org.apache.flink.runtime.state.v2.AbstractReducingState
- ReduceTransformation<IN,K> - Class in org.apache.flink.streaming.api.transformations
-
A
Transformationthat describes a reduce operation on aKeyedStream. - ReduceTransformation(String, int, Transformation<IN>, ReduceFunction<IN>, KeySelector<IN, K>, TypeInformation<K>, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.ReduceTransformation
- ReduceTransformationTranslator<IN,KEY> - Class in org.apache.flink.streaming.runtime.translators
-
A
TransformationTranslatorfor theReduceTransformation. - ReduceTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.ReduceTransformationTranslator
- REDUCING - org.apache.flink.runtime.state.v2.StateDescriptor.Type
- REDUCING_ADD - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Add element into reducing state,
AppendingState.asyncAdd(Object). - REDUCING_GET - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Get from reducing state,
AppendingState.asyncGet(). - REDUCING_REMOVE - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Remove element from reducing state.
- ReducingStateAdaptor<K,N,V> - Class in org.apache.flink.runtime.state.v2.adaptor
-
An adaptor that transforms
InternalReducingStateintoInternalReducingState. - ReducingStateAdaptor(InternalReducingState<K, N, V>) - Constructor for class org.apache.flink.runtime.state.v2.adaptor.ReducingStateAdaptor
- ReducingStateDescriptor<T> - Class in org.apache.flink.runtime.state.v2
-
StateDescriptorforReducingState. - ReducingStateDescriptor(String, ReduceFunction<T>, TypeInformation<T>) - Constructor for class org.apache.flink.runtime.state.v2.ReducingStateDescriptor
-
Creates a new
ReducingStateDescriptorwith the given name and default value. - ReducingStateDescriptor(String, ReduceFunction<T>, TypeInformation<T>, SerializerConfig) - Constructor for class org.apache.flink.runtime.state.v2.ReducingStateDescriptor
-
Creates a new
ReducingStateDescriptorwith the given name and default value. - refCnt() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
The current reference counter.
- refCnt() - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- refCnt() - Method in class org.apache.flink.runtime.rest.handler.router.RoutedRequest
- ReferenceCounted<ReleaseHelper> - Class in org.apache.flink.runtime.asyncprocessing
-
An object that can be reference counted, the internal resource would be released when the reference count reaches zero.
- ReferenceCounted(int) - Constructor for class org.apache.flink.runtime.asyncprocessing.ReferenceCounted
- referenceCountReachedZero(RecordContext.DisposerRunner) - Method in class org.apache.flink.runtime.asyncprocessing.RecordContext
- referenceCountReachedZero(ReleaseHelper) - Method in class org.apache.flink.runtime.asyncprocessing.ReferenceCounted
-
A method called when the reference count reaches zero.
- refresh() - Method in class org.apache.flink.runtime.security.DynamicConfiguration
- REGION_SIZE - Static variable in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.ProducerMergedPartitionFileIndex.FixedSizeRegion
- RegionPartitionGroupReleaseStrategy - Class in org.apache.flink.runtime.executiongraph.failover.partitionrelease
-
Releases blocking intermediate result partitions that are incident to a
SchedulingPipelinedRegion, as soon as the region's execution vertices are finished. - RegionPartitionGroupReleaseStrategy(SchedulingTopology) - Constructor for class org.apache.flink.runtime.executiongraph.failover.partitionrelease.RegionPartitionGroupReleaseStrategy
- RegionPartitionGroupReleaseStrategy.Factory - Class in org.apache.flink.runtime.executiongraph.failover.partitionrelease
-
Factory for
PartitionGroupReleaseStrategy. - register(String, LeaderContender) - Method in class org.apache.flink.runtime.leaderelection.DefaultLeaderElectionService
- register(MetricOptions.JobStatusMetricsSettings, MetricGroup, StateTimeMetric, String) - Static method in interface org.apache.flink.runtime.scheduler.metrics.StateTimeMetric
- register(Metric, String, AbstractMetricGroup) - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
-
Registers a new
Metricwith this registry. - register(Metric, String, AbstractMetricGroup) - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
- register(Metric, String, AbstractMetricGroup) - Method in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
- register(JobManagerRunner) - Method in class org.apache.flink.runtime.dispatcher.DefaultJobManagerRunnerRegistry
- register(JobManagerRunner) - Method in interface org.apache.flink.runtime.dispatcher.JobManagerRunnerRegistry
-
Registers the given
JobManagerRunnerinstance. - register(JobManagerRunner) - Method in class org.apache.flink.runtime.dispatcher.OnMainThreadJobManagerRunnerRegistry
- register(StreamStateHandle, long) - Method in interface org.apache.flink.runtime.state.changelog.LocalChangelogRegistry
-
Called upon ChangelogKeyedStateBackend#notifyCheckpointComplete.
- register(StreamStateHandle, long) - Method in class org.apache.flink.runtime.state.changelog.LocalChangelogRegistryImpl
- register(Logger) - Static method in class org.apache.flink.runtime.util.SignalHandler
-
Register some signal handlers.
- registerAll(Iterable<? extends CompositeStateHandle>, long) - Method in interface org.apache.flink.runtime.state.SharedStateRegistry
-
Register given shared states in the registry.
- registerAll(Iterable<? extends CompositeStateHandle>, long) - Method in class org.apache.flink.runtime.state.SharedStateRegistryImpl
- registerAllAfterRestored(CompletedCheckpoint, RecoveryClaimMode) - Method in interface org.apache.flink.runtime.state.SharedStateRegistry
-
Set the lowest checkpoint ID below which no state is discarded, inclusive.
- registerAllAfterRestored(CompletedCheckpoint, RecoveryClaimMode) - Method in class org.apache.flink.runtime.state.SharedStateRegistryImpl
- registerAllRequestsProcessedListener(NotificationListener) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileWriter
- registerAllRequestsProcessedListener(NotificationListener) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
Registers a listener to be notified when all outstanding requests have been processed.
- registerAllRequestsProcessedListener(NotificationListener) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileWriter
-
Registers a listener, which is notified after all outstanding requests have been processed.
- registerAndStartNewCoordinators(Collection<OperatorCoordinatorHolder>, ComponentMainThreadExecutor, int) - Method in class org.apache.flink.runtime.scheduler.DefaultOperatorCoordinatorHandler
- registerAndStartNewCoordinators(Collection<OperatorCoordinatorHolder>, ComponentMainThreadExecutor, int) - Method in interface org.apache.flink.runtime.scheduler.OperatorCoordinatorHandler
-
Register and start new operator coordinators.
- registerAvailabilityAndPriorityNotifier(BiConsumer<TieredStoragePartitionId, TieredStorageSubpartitionId>) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteStorageScanner
- registerAvailabilityListener(Runnable) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyConnectionWriterImpl
- registerAvailabilityNotifier(AvailabilityNotifier) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageConsumerClient
- registerAvailabilityNotifier(AvailabilityNotifier) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskTierConsumerAgent
- registerAvailabilityNotifier(AvailabilityNotifier) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory.MemoryTierConsumerAgent
- registerAvailabilityNotifier(AvailabilityNotifier) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierConsumerAgent
- registerAvailabilityNotifier(AvailabilityNotifier) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierConsumerAgent
-
Register the notifier to notify the availability of a subpartition.
- registerBackPressureListener(TimerGauge.StartStopListener) - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- registerBlocklistListener(BlocklistListener) - Method in interface org.apache.flink.runtime.blocklist.BlocklistHandler
-
Register a new blocklist listener.
- registerBlocklistListener(BlocklistListener) - Method in class org.apache.flink.runtime.blocklist.DefaultBlocklistHandler
- registerBlocklistListener(BlocklistListener) - Method in class org.apache.flink.runtime.blocklist.NoOpBlocklistHandler
- registerCachedFile(String, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Registers a file at the distributed cache under the given name.
- registerCachedFile(String, String, boolean) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Registers a file at the distributed cache under the given name.
- registerCacheTransformation(AbstractID, CacheTransformation<T>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
- registerClassLoaderLease(JobID) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
- registerClassLoaderLease(JobID) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
-
Registers a new class loader lease for the given jobId.
- registerCleanupTimer(W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Registers a timer to cleanup the content of the window.
- registerCollectIterator(CollectResultIterator<?>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
- registerConsumedPartitionGroup(ConsumedPartitionGroup) - Method in class org.apache.flink.runtime.executiongraph.EdgeManager
- registerConsumer(TieredStoragePartitionId, TieredStorageSubpartitionId) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.TieredStorageNettyService
-
TierConsumerAgentwill register toTieredStorageNettyServiceand get a future ofNettyConnectionReader. - registerConsumer(TieredStoragePartitionId, TieredStorageSubpartitionId) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.TieredStorageNettyServiceImpl
- registerDebloatingTaskMetrics(SingleInputGate[], MetricGroup) - Static method in class org.apache.flink.runtime.io.network.metrics.NettyShuffleMetricFactory
- RegisteredBroadcastStateBackendMetaInfo<K,V> - Class in org.apache.flink.runtime.state
- RegisteredBroadcastStateBackendMetaInfo(String, OperatorStateHandle.Mode, TypeSerializer<K>, TypeSerializer<V>) - Constructor for class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
- RegisteredBroadcastStateBackendMetaInfo(StateMetaInfoSnapshot) - Constructor for class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
- RegisteredBroadcastStateBackendMetaInfo(RegisteredBroadcastStateBackendMetaInfo<K, V>) - Constructor for class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
- RegisteredKeyValueStateBackendMetaInfo<N,S> - Class in org.apache.flink.runtime.state
-
Compound meta information for a registered state in a keyed state backend.
- RegisteredKeyValueStateBackendMetaInfo<N,S> - Class in org.apache.flink.runtime.state.v2
-
Compound meta information for a registered state in a keyed state backend.
- RegisteredKeyValueStateBackendMetaInfo(String, StateDescriptor.Type, TypeSerializer<N>, TypeSerializer<S>) - Constructor for class org.apache.flink.runtime.state.v2.RegisteredKeyValueStateBackendMetaInfo
- RegisteredKeyValueStateBackendMetaInfo(String, StateDescriptor.Type, TypeSerializer<N>, TypeSerializer<S>, StateSnapshotTransformer.StateSnapshotTransformFactory<S>) - Constructor for class org.apache.flink.runtime.state.v2.RegisteredKeyValueStateBackendMetaInfo
- RegisteredKeyValueStateBackendMetaInfo(StateDescriptor.Type, String, TypeSerializer<N>, TypeSerializer<S>) - Constructor for class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
- RegisteredKeyValueStateBackendMetaInfo(StateDescriptor.Type, String, TypeSerializer<N>, TypeSerializer<S>, StateSnapshotTransformer.StateSnapshotTransformFactory<S>) - Constructor for class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
- RegisteredKeyValueStateBackendMetaInfo(StateMetaInfoSnapshot) - Constructor for class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
- RegisteredKeyValueStateBackendMetaInfo(StateMetaInfoSnapshot) - Constructor for class org.apache.flink.runtime.state.v2.RegisteredKeyValueStateBackendMetaInfo
- RegisteredOperatorStateBackendMetaInfo<S> - Class in org.apache.flink.runtime.state
-
Compound meta information for a registered state in an operator state backend.
- RegisteredOperatorStateBackendMetaInfo(String, TypeSerializer<S>, OperatorStateHandle.Mode) - Constructor for class org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
- RegisteredOperatorStateBackendMetaInfo(StateMetaInfoSnapshot) - Constructor for class org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
- RegisteredPriorityQueueStateBackendMetaInfo<T> - Class in org.apache.flink.runtime.state
-
Meta information about a priority queue state in a backend.
- RegisteredPriorityQueueStateBackendMetaInfo(String, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.state.RegisteredPriorityQueueStateBackendMetaInfo
- RegisteredPriorityQueueStateBackendMetaInfo(StateMetaInfoSnapshot) - Constructor for class org.apache.flink.runtime.state.RegisteredPriorityQueueStateBackendMetaInfo
- registeredReaders() - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinatorContext
- registeredReadersOfAttempts() - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinatorContext
- RegisteredRpcConnection<F extends Serializable,G extends org.apache.flink.runtime.rpc.RpcGateway,S extends RegistrationResponse.Success,R extends RegistrationResponse.Rejection> - Class in org.apache.flink.runtime.registration
-
This utility class implements the basis of RPC connecting from one component to another component, for example the RPC connection from TaskExecutor to ResourceManager.
- RegisteredRpcConnection(Logger, String, F, Executor) - Constructor for class org.apache.flink.runtime.registration.RegisteredRpcConnection
- RegisteredStateMetaInfoBase - Class in org.apache.flink.runtime.state
-
Base class for all registered state in state backends.
- RegisteredStateMetaInfoBase(String) - Constructor for class org.apache.flink.runtime.state.RegisteredStateMetaInfoBase
- RegisteredStateMetaInfoBase.Key - Class in org.apache.flink.runtime.state
-
Wrapper class that can be used to represent the wrapped
RegisteredStateMetaInfoBaseas key in aMap. - registerEventHandler(OperatorID, OperatorEventHandler) - Method in interface org.apache.flink.runtime.operators.coordination.OperatorEventDispatcher
-
Register a listener that is notified every time an OperatorEvent is sent from the OperatorCoordinator (of the operator with the given OperatorID) to this subtask.
- registerEventHandler(OperatorID, OperatorEventHandler) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorEventDispatcherImpl
- registerEventTimeTimer(long) - Method in class org.apache.flink.streaming.api.SimpleTimerService
- registerEventTimeTimer(long) - Method in interface org.apache.flink.streaming.api.TimerService
-
Registers a timer to be fired when the event time watermark passes the given time.
- registerEventTimeTimer(long) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Register an event-time callback.
- registerEventTimeTimer(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
- registerEventTimeTimer(N, long) - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
-
Registers a timer to be fired when event time watermark passes the given time.
- registerEventTimeTimer(N, long) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
- registerEventTimeTimer(N, long) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
- registerExecution(Execution) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- registerExecution(Execution) - Method in interface org.apache.flink.runtime.executiongraph.InternalExecutionGraphAccessor
- registerInputMetrics(boolean, MetricGroup, SingleInputGate[]) - Static method in class org.apache.flink.runtime.io.network.metrics.NettyShuffleMetricFactory
- registerJob(JobID) - Method in interface org.apache.flink.runtime.blob.JobPermanentBlobService
-
Register the given job.
- registerJob(JobID) - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
-
Registers use of job-related BLOBs.
- registerJob(JobID, TierShuffleHandler) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMasterClient
- registerJob(JobID, TierShuffleHandler) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.NoOpMasterAgent
- registerJob(JobID, TierShuffleHandler) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierMasterAgent
- registerJob(JobID, TierShuffleHandler) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierMasterAgent
-
Register a job id with a
TierShuffleHandler. - registerJob(JobShuffleContext) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredInternalShuffleMaster
-
Registers the target job together with the corresponding
JobShuffleContextto this shuffle master. - registerJob(JobShuffleContext) - Method in class org.apache.flink.runtime.shuffle.NettyShuffleMaster
- registerJob(JobShuffleContext) - Method in interface org.apache.flink.runtime.shuffle.ShuffleMaster
-
Registers the target job together with the corresponding
JobShuffleContextto this shuffle master. - registerJobListener(JobListener) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Register a
JobListenerin this environment. - registerJobMaster(JobMasterId, ResourceID, String, JobID, Duration) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- registerJobMaster(JobMasterId, ResourceID, String, JobID, Duration) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Register a
JobMasterat the resource manager. - registerJobMetrics(MetricGroup, JobStatusProvider, Gauge<Long>, DeploymentStateTimeMetrics, Consumer<JobStatusListener>, long, MetricOptions.JobStatusMetricsSettings) - Static method in class org.apache.flink.runtime.scheduler.SchedulerBase
- registerJobStatusHook(JobStatusHook) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Registers the JobStatusHook.
- registerJobStatusListener(JobStatusListener) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- registerJobStatusListener(JobStatusListener) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- registerKeySelectionListener(KeyedStateBackend.KeySelectionListener<K>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- registerKeySelectionListener(KeyedStateBackend.KeySelectionListener<K>) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
-
State backend will call
KeyedStateBackend.KeySelectionListener.keySelected(K)when key context is switched if supported. - registerKeySelectionListener(KeyedStateBackend.KeySelectionListener<K>) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
- registerKvState(JobID, JobVertexID, KeyGroupRange, String, InternalKvState<?, ?, ?>, ClassLoader) - Method in class org.apache.flink.runtime.query.KvStateRegistry
-
Registers the KvState instance and returns the assigned ID.
- registerKvState(KeyGroupRange, String, InternalKvState<?, ?, ?>, ClassLoader) - Method in class org.apache.flink.runtime.query.TaskKvStateRegistry
-
Registers the KvState instance at the KvStateRegistry.
- registerKvState(KeyGroupRange, KvStateID, InetSocketAddress) - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Registers a KvState instance for the given key group index.
- registerListener(JobID, KvStateRegistryListener) - Method in class org.apache.flink.runtime.query.KvStateRegistry
-
Registers a listener with the registry.
- registerListener(PartitionRequestListener) - Method in class org.apache.flink.runtime.io.network.partition.PartitionRequestListenerManager
- registerListener(TimerGauge.StartStopListener) - Method in class org.apache.flink.runtime.metrics.TimerGauge
- registerMailboxSizeSupplier(TaskIOMetricGroup.SizeSupplier<Integer>) - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- registerMetrics() - Method in class org.apache.flink.runtime.resourcemanager.active.ActiveResourceManager
- registerMetrics() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- registerMetrics(MetricGroup) - Method in class org.apache.flink.runtime.scheduler.metrics.DeploymentStateTimeMetrics
- registerMetrics(MetricGroup) - Method in class org.apache.flink.runtime.scheduler.metrics.JobStatusMetrics
- registerMetrics(MetricGroup) - Method in interface org.apache.flink.runtime.scheduler.metrics.MetricsRegistrar
- registerMetrics(FileMergingSnapshotManager.SpaceStat) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingMetricGroup
- registerNewSerializerForRestoredState(TypeSerializer<T>) - Method in class org.apache.flink.runtime.state.StateSerializerProvider
-
For restored state, register a new serializer that potentially has a new serialization schema.
- registerNewSlotsListener(DeclarativeSlotPool.NewSlotsListener) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPool
-
Registers a listener which is called whenever new slots become available.
- registerNewSlotsListener(DeclarativeSlotPool.NewSlotsListener) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultDeclarativeSlotPool
- registerOngoingOperation(K, CompletableFuture<R>) - Method in class org.apache.flink.runtime.rest.handler.async.CompletedOperationCache
-
Registers an ongoing operation with the cache.
- registerOutputMetrics(boolean, MetricGroup, ResultPartition[]) - Static method in class org.apache.flink.runtime.io.network.metrics.NettyShuffleMetricFactory
- registerPartition(ResultPartitionID) - Method in class org.apache.flink.runtime.io.network.TaskEventDispatcher
-
Registers the given partition for incoming task events allowing calls to
TaskEventDispatcher.subscribeToEvent(ResultPartitionID, EventListener, Class). - registerPartitionWithProducer(JobID, PartitionDescriptor, ProducerDescriptor) - Method in class org.apache.flink.runtime.shuffle.NettyShuffleMaster
- registerPartitionWithProducer(JobID, PartitionDescriptor, ProducerDescriptor) - Method in interface org.apache.flink.runtime.shuffle.ShuffleMaster
-
Asynchronously register a partition and its producer with the shuffle service.
- registerProcessingTimeTimer(long) - Method in class org.apache.flink.streaming.api.SimpleTimerService
- registerProcessingTimeTimer(long) - Method in interface org.apache.flink.streaming.api.TimerService
-
Registers a timer to be fired when processing time passes the given time.
- registerProcessingTimeTimer(long) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
-
Register a system time callback.
- registerProcessingTimeTimer(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
- registerProcessingTimeTimer(N, long) - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
-
Registers a timer to be fired when processing time passes the given time.
- registerProcessingTimeTimer(N, long) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
- registerProcessingTimeTimer(N, long) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
- registerProducedPartitions(TaskManagerLocation) - Method in class org.apache.flink.runtime.executiongraph.Execution
- registerProducer(TieredStoragePartitionId, NettyServiceProducer) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.TieredStorageNettyService
-
TierProducerAgentwill provide a callback namedNettyServiceProducerto register toTieredStorageNettyService. - registerProducer(TieredStoragePartitionId, NettyServiceProducer) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.TieredStorageNettyServiceImpl
- registerQueueLengthMetrics(MetricGroup, SingleInputGate[]) - Static method in class org.apache.flink.runtime.io.network.metrics.InputGateMetrics
- registerQueueLengthMetrics(MetricGroup, ResultPartition[]) - Static method in class org.apache.flink.runtime.io.network.metrics.ResultPartitionMetrics
- registerReference(SharedStateRegistryKey, StreamStateHandle, long) - Method in interface org.apache.flink.runtime.state.SharedStateRegistry
-
Shortcut for
SharedStateRegistry.registerReference(SharedStateRegistryKey, StreamStateHandle, long, boolean)with preventDiscardingCreatedCheckpoint = false. - registerReference(SharedStateRegistryKey, StreamStateHandle, long, boolean) - Method in interface org.apache.flink.runtime.state.SharedStateRegistry
-
Register a reference to the given shared state in the registry.
- registerReference(SharedStateRegistryKey, StreamStateHandle, long, boolean) - Method in class org.apache.flink.runtime.state.SharedStateRegistryImpl
- registerRequester(Object) - Method in class org.apache.flink.runtime.io.disk.BatchShuffleReadBufferPool
- registerResource(TieredStorageDataIdentifier, TieredStorageResource) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageResourceRegistry
-
Register a new resource for the given owner.
- registerResultPartition(ResultPartition) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
- registerResultPartitionBytesCounter(IntermediateResultPartitionID, ResultPartitionBytesCounter) - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- registerSchedulingTopologyListener(SchedulingTopologyListener) - Method in class org.apache.flink.runtime.scheduler.adapter.DefaultExecutionTopology
- registerSchedulingTopologyListener(SchedulingTopologyListener) - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingTopology
-
Register a scheduling topology listener.
- registerSharedStates(SharedStateRegistry, long) - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- registerSharedStates(SharedStateRegistry, long) - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
- registerSharedStates(SharedStateRegistry, long) - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
Deprecated.
- registerSharedStates(SharedStateRegistry, long) - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- registerSharedStates(SharedStateRegistry, long) - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
- registerSharedStates(SharedStateRegistry, long) - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl
- registerSharedStates(SharedStateRegistry, long) - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendLocalHandle
- registerSharedStates(SharedStateRegistry, long) - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateHandleStreamImpl
- registerSharedStates(SharedStateRegistry, long) - Method in class org.apache.flink.runtime.state.changelog.inmemory.InMemoryChangelogStateHandle
- registerSharedStates(SharedStateRegistry, long) - Method in interface org.apache.flink.runtime.state.CompositeStateHandle
-
Register both newly created and already referenced shared states in the given
SharedStateRegistry. - registerSharedStates(SharedStateRegistry, long) - Method in class org.apache.flink.runtime.state.filemerging.FileMergingOperatorStreamStateHandle
- registerSharedStates(SharedStateRegistry, long) - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
- registerSharedStates(SharedStateRegistry, long) - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
- registerSharedStates(SharedStateRegistry, long) - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
- registerSharedStatesAfterRestored(SharedStateRegistry, RecoveryClaimMode) - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
Register all shared states in the given registry.
- registerShuffleMetrics(MetricGroup, NetworkBufferPool) - Static method in class org.apache.flink.runtime.io.network.metrics.NettyShuffleMetricFactory
- registerSlots(Collection<? extends SlotOffer>, TaskManagerLocation, TaskManagerGateway, long) - Method in class org.apache.flink.runtime.jobmaster.slotpool.BlocklistDeclarativeSlotPool
- registerSlots(Collection<? extends SlotOffer>, TaskManagerLocation, TaskManagerGateway, long) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPool
-
Registers the given set of slots at the slot pool.
- registerSlots(Collection<? extends SlotOffer>, TaskManagerLocation, TaskManagerGateway, long) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultDeclarativeSlotPool
- registerSlotSharingGroup(SlotSharingGroup) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Register a slot sharing group with its resource spec.
- registerSubtaskForSharedStates(FileMergingSnapshotManager.SubtaskKey) - Method in interface org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager
-
Register a subtask and create the managed directory for shared states.
- registerSubtaskForSharedStates(FileMergingSnapshotManager.SubtaskKey) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
- registerTask(Callable<?>, Duration) - Method in interface org.apache.flink.streaming.runtime.io.checkpointing.BarrierAlignmentUtil.DelayableTimer
-
Register a task to be executed some time later.
- registerTaskEventListener(EventListener<TaskEvent>, Class<? extends TaskEvent>) - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
- registerTaskEventListener(EventListener<TaskEvent>, Class<? extends TaskEvent>) - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
- registerTaskExecutor(TaskExecutorRegistration, Duration) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- registerTaskExecutor(TaskExecutorRegistration, Duration) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Register a
TaskExecutorat the resource manager. - registerTaskManager(JobID, TaskManagerRegistrationInformation, Duration) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- registerTaskManager(JobID, TaskManagerRegistrationInformation, Duration) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Registers the task manager at the job manager.
- registerTaskManager(ResourceID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolService
- registerTaskManager(ResourceID) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Registers a TaskExecutor with the given
ResourceIDatSlotPool. - registerTaskManager(ResourceID) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolService
-
Registers a TaskExecutor with the given
ResourceIDatSlotPoolService. - registerTaskManager(TaskExecutorConnection, SlotReport, ResourceProfile, ResourceProfile) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedSlotManager
- registerTaskManager(TaskExecutorConnection, SlotReport, ResourceProfile, ResourceProfile) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Registers a new task manager at the slot manager.
- registerTimeout(K, long, TimeUnit) - Method in class org.apache.flink.runtime.taskexecutor.slot.DefaultTimerService
- registerTimeout(K, long, TimeUnit) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TimerService
-
Register a timeout for the given key which shall occur in the given delay.
- registerTimer(long, ProcessingTimeService.ProcessingTimeCallback) - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
-
Registers a task to be executed no sooner than time
timestamp, but without strong guarantees of order. - RegistrationConnectionListener<T extends RegisteredRpcConnection<?,?,S,?>,S extends RegistrationResponse.Success,R extends RegistrationResponse.Rejection> - Interface in org.apache.flink.runtime.registration
-
Classes which want to be notified about the registration result by the
RegisteredRpcConnectionhave to implement this interface. - RegistrationResponse - Class in org.apache.flink.runtime.registration
-
Base class for responses given to registration attempts from
RetryingRegistration. - RegistrationResponse() - Constructor for class org.apache.flink.runtime.registration.RegistrationResponse
- RegistrationResponse.Failure - Class in org.apache.flink.runtime.registration
-
A registration failure.
- RegistrationResponse.Rejection - Class in org.apache.flink.runtime.registration
-
A rejected (declined) registration.
- RegistrationResponse.Success - Class in org.apache.flink.runtime.registration
-
Base class for a successful registration.
- RegistrationTimeoutException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
-
Exception which indicates that the
TaskExecutorcould not register at the master in time. - RegistrationTimeoutException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.RegistrationTimeoutException
- RegistrationTimeoutException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.RegistrationTimeoutException
- RegistrationTimeoutException(Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.RegistrationTimeoutException
- registry - Variable in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
The registry that this metrics group belongs to.
- RegularOperatorChain<OUT,OP extends StreamOperator<OUT>> - Class in org.apache.flink.streaming.runtime.tasks
-
A regular non finished on restore
OperatorChain. - RegularOperatorChain(StreamTask<OUT, OP>, RecordWriterDelegate<SerializationDelegate<StreamRecord<OUT>>>) - Constructor for class org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
- RegularToMutableObjectIterator<T> - Class in org.apache.flink.runtime.util
- RegularToMutableObjectIterator(Iterator<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.util.RegularToMutableObjectIterator
- REJECTED - org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager.RegistrationResult
- Rejection() - Constructor for class org.apache.flink.runtime.registration.RegistrationResponse.Rejection
- relations() - Method in class org.apache.flink.streaming.api.lineage.DefaultLineageGraph
- relations() - Method in interface org.apache.flink.streaming.api.lineage.LineageGraph
- RelativeFileStateHandle - Class in org.apache.flink.runtime.state.filesystem
-
A
StreamStateHandlefor state that was written to a file stream. - RelativeFileStateHandle(Path, String, long) - Constructor for class org.apache.flink.runtime.state.filesystem.RelativeFileStateHandle
- relativeTimeMillis() - Method in class org.apache.flink.streaming.api.operators.util.PausableRelativeClock
- relativeTimeNanos() - Method in class org.apache.flink.streaming.api.operators.util.PausableRelativeClock
- release() - Method in class org.apache.flink.runtime.asyncprocessing.ReferenceCounted
- release() - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager.ClassLoaderLease
-
Releases the lease to the user code class loader for the associated job.
- release() - Method in interface org.apache.flink.runtime.io.network.partition.DataBuffer
-
Releases this
DataBufferwhich releases all resources. - release() - Method in class org.apache.flink.runtime.io.network.partition.HashBasedDataBuffer
- release() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.PartitionFileReader
-
Release the
PartitionFileReader. - release() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.PartitionFileWriter
-
Release all the resources of the
PartitionFileWriter. - release() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.ProducerMergedPartitionFileReader
- release() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.ProducerMergedPartitionFileWriter
- release() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.SegmentPartitionFileReader
- release() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.SegmentPartitionFileWriter
- release() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemoryManager
-
Release all the resources(if exists) and check the state of the
TieredStorageMemoryManager. - release() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemoryManagerImpl
- release() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageResource
-
Release all the resources, e.g. delete the files, recycle the occupied memory, etc.
- release() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskIOScheduler
- release() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartition
- release() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- release() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
- release() - Method in class org.apache.flink.runtime.io.network.partition.SortBuffer
- release() - Method in class org.apache.flink.runtime.rest.handler.router.RoutedRequest
- release() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMapSnapshot
- release() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTableSnapshot
- release() - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueStateSnapshot
- release() - Method in class org.apache.flink.runtime.state.heap.StateMapSnapshot
-
Release the snapshot.
- release() - Method in interface org.apache.flink.runtime.state.SnapshotResources
-
Cleans up the resources after the asynchronous part is done.
- release() - Method in interface org.apache.flink.runtime.state.StateSnapshot
-
Release the snapshot.
- release(int) - Method in class org.apache.flink.runtime.rest.handler.router.RoutedRequest
- release(Object, K) - Method in class org.apache.flink.runtime.asyncprocessing.KeyAccountingUnit
-
Release a key, which is invoked when a
RecordContextis released. - release(String) - Method in interface org.apache.flink.runtime.persistence.StateHandleStore
-
Releases the lock on the specific state handle so that it could be deleted by other
StateHandleStore. - release(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Releases the lock from the node under the given ZooKeeper path.
- release(String, Object, LongConsumer) - Method in class org.apache.flink.runtime.memory.SharedResources
-
Releases a lease (identified by the lease holder object) for the given type.
- release(Throwable) - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
Releases the partition writer which releases the produced data and no reader can consume the partition any more.
- release(Throwable) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- release(Throwable) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlot.Payload
-
Releases the payload.
- release(Throwable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
A release of the payload by the
AllocatedSlottriggers a release of the payload of the logical slot. - release(Collection<MemorySegment>) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Tries to release many memory segments together.
- release(MemorySegment) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Tries to release the memory for the specified segment.
- release(ResourceProfile) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceBudgetManager
- release(ReleaseHelper) - Method in class org.apache.flink.runtime.asyncprocessing.ReferenceCounted
- releaseAll() - Method in interface org.apache.flink.runtime.persistence.StateHandleStore
-
Releases all the locks on corresponding state handle so that it could be deleted by other
StateHandleStore. - releaseAll() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Releases all lock nodes of this ZooKeeperStateHandleStore.
- releaseAll(Object) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Releases all memory segments for the given owner.
- releaseAllMemory(Object) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Releases all reserved memory chunks from an owner to this memory manager.
- releaseAllReferencesFromTask(BatchTask<?, ?>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableManager
- releaseAllResources() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
- releaseAllResources() - Method in class org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionDirectTransferReader
- releaseAllResources() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.TieredStorageResultSubpartitionView
- releaseAllResources() - Method in class org.apache.flink.runtime.io.network.partition.NoOpResultSubpartitionView
- releaseAllResources() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedApproximateSubpartitionView
-
Pipelined ResultPartition relies on its subpartition view's release to decide whether the partition is ready to release.
- releaseAllResources() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartitionView
- releaseAllResources() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
- releaseAllResources() - Method in class org.apache.flink.runtime.io.network.partition.UnionResultSubpartitionView
- releaseAndTryRemove(String) - Method in interface org.apache.flink.runtime.persistence.StateHandleStore
-
Releases the lock for the given state handle and tries to remove the state handle if it is no longer locked.
- releaseAndTryRemove(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Releases the lock for the given state node and tries to remove the state node if it is no longer locked.
- releaseBroadcastVariables(String, int, DistributedRuntimeUDFContext) - Method in class org.apache.flink.runtime.operators.BatchTask
- releaseClusterPartitions(Collection<IntermediateDataSetID>, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- releaseClusterPartitions(Collection<IntermediateDataSetID>, Duration) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Releases all cluster partitions belong to any of the given data sets.
- releaseClusterPartitions(Collection<IntermediateDataSetID>, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- releaseClusterPartitions(ResourceID, Set<IntermediateDataSetID>) - Method in interface org.apache.flink.runtime.io.network.partition.TaskExecutorClusterPartitionReleaser
- releaseClusterPartitions(IntermediateDataSetID) - Method in interface org.apache.flink.runtime.io.network.partition.ClusterPartitionManager
-
Releases all partitions associated with the given dataset.
- releaseClusterPartitions(IntermediateDataSetID) - Method in interface org.apache.flink.runtime.io.network.partition.ResourceManagerPartitionTracker
-
Issues a release calls to all task executors that are hosting partitions of the given data set.
- releaseClusterPartitions(IntermediateDataSetID) - Method in class org.apache.flink.runtime.io.network.partition.ResourceManagerPartitionTrackerImpl
- releaseClusterPartitions(IntermediateDataSetID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- releaseDeserializer(InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
- releaseFreeSlotsOnTaskManager(ResourceID, Exception) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolService
- releaseFreeSlotsOnTaskManager(ResourceID, Exception) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolService
-
Releases all free slots belonging to the owning TaskExecutor if it has been registered.
- releaseIdleSlots(long) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPool
-
Releases slots which have exceeded the idle slot timeout and are no longer needed to fulfill the resource requirements.
- releaseIdleSlots(long) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultDeclarativeSlotPool
- releaseInternal() - Method in class org.apache.flink.runtime.io.network.partition.BufferWritingResultPartition
- releaseInternal() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartition
- releaseInternal() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Releases all produced data including both those stored in memory and persisted on disk.
- releaseInternal() - Method in class org.apache.flink.runtime.io.network.partition.SortMergeResultPartition
- releaseJob(JobID) - Method in interface org.apache.flink.runtime.blob.JobPermanentBlobService
-
Release the given job.
- releaseJob(JobID) - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
-
Unregisters use of job-related BLOBs and allow them to be released.
- releaseJob(JobID, ExecutionAttemptID) - Method in class org.apache.flink.runtime.filecache.FileCache
- releaseListener() - Method in class org.apache.flink.runtime.io.network.netty.NettyPartitionRequestListener
- releaseListener() - Method in interface org.apache.flink.runtime.io.network.partition.PartitionRequestListener
-
Release this listener.
- releaseLocalStateForAllocationId(AllocationID) - Method in class org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager
- releaseMemory(Object, long) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Releases a memory chunk of a certain size from an owner to this memory manager.
- releaseMergingSnapshotManagerForJob(JobID) - Method in class org.apache.flink.runtime.state.TaskExecutorFileMergingManager
-
Release file merging snapshot manager of one job when
org.apache.flink.runtime.taskexecutor.TaskExecutor#releaseJobResourcescalled. - releaseMergingSnapshotManagerForTask(JobID, ExecutionAttemptID) - Method in class org.apache.flink.runtime.state.TaskExecutorFileMergingManager
- releasePartition(TierShuffleDescriptor) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.NoOpMasterAgent
- releasePartition(TierShuffleDescriptor) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierMasterAgent
- releasePartition(TierShuffleDescriptor) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierMasterAgent
-
Release a tiered storage partition.
- releasePartition(ResultPartitionID, Throwable) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
- releasePartition(ShuffleDescriptor) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredInternalShuffleMaster
- releasePartition(ShuffleDescriptor) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMasterClient
- releasePartitionExternally(ShuffleDescriptor) - Method in class org.apache.flink.runtime.shuffle.NettyShuffleMaster
- releasePartitionExternally(ShuffleDescriptor) - Method in interface org.apache.flink.runtime.shuffle.ShuffleMaster
-
Release any external resources occupied by the given partition.
- releasePartitionRequestListener(PartitionRequestListener) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
- releasePartitionRequestListener(PartitionRequestListener) - Method in interface org.apache.flink.runtime.io.network.partition.ResultPartitionProvider
-
Release the given listener in this result partition provider.
- releasePartitions(JobID, Set<ResultPartitionID>) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Batch release intermediate result partitions.
- releasePartitions(JobID, Set<ResultPartitionID>) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
- releasePartitions(JobID, Set<ResultPartitionID>) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- releasePartitions(JobID, Set<ResultPartitionID>) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Batch release intermediate result partitions.
- releasePartitions(JobID, Set<ResultPartitionID>) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- releasePartitionsLocally(Collection<ResultPartitionID>) - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
- releasePartitionsLocally(Collection<ResultPartitionID>) - Method in interface org.apache.flink.runtime.shuffle.ShuffleEnvironment
-
Release local resources occupied by the given partitions.
- releaseQuietly() - Method in class org.apache.flink.runtime.io.network.partition.PartitionedFileWriter
-
Used to close and delete the failed
PartitionedFilewhen any exception occurs. - releaseReference(String, int, BatchTask<?, ?>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableManager
- releaseReference(BroadcastVariableKey, BatchTask<?, ?>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableManager
- releaseResource(WorkerType) - Method in interface org.apache.flink.runtime.resourcemanager.active.ResourceManagerDriver
-
Release resource to the external resource manager.
- releaseResourcesForJob(JobID) - Method in class org.apache.flink.runtime.state.TaskExecutorChannelStateExecutorFactoryManager
- releaseResourcesForJob(JobID) - Method in class org.apache.flink.runtime.state.TaskExecutorStateChangelogStoragesManager
- releaseSlot() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Deprecated.Added because extended the actual releaseSlot method with cause parameter.
- releaseSlot(Throwable) - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Releases this slot.
- releaseSlot(Throwable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
- releaseSlot(AllocationID, Exception) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPool
-
Releases the slot specified by allocationId if one exists.
- releaseSlot(AllocationID, Exception) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultDeclarativeSlotPool
- releaseSlot(SlotRequestId, Throwable) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotActions
-
Releases the slot with the given
SlotRequestId. - releaseSlot(SlotRequestId, Throwable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolBridge
- releaseSlots(ResourceID, Exception) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPool
-
Releases all slots belonging to the owning TaskExecutor if it has been registered.
- releaseSlots(ResourceID, Exception) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultDeclarativeSlotPool
- releaseSnapshot(StateMapSnapshot<K, N, S, ? extends StateMap<K, N, S>>) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
Releases a snapshot for this
CopyOnWriteStateMap. - releaseSnapshot(StateMapSnapshot<K, N, S, ? extends StateMap<K, N, S>>) - Method in class org.apache.flink.runtime.state.heap.StateMap
-
Releases a snapshot for this
StateMap. - releaseTable() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Releases the table (the array of buckets) and returns the occupied memory segments to the list of free segments.
- releaseTable() - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
- releaseTaskManager(ResourceID, Exception) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolService
- releaseTaskManager(ResourceID, Exception) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Releases a TaskExecutor with the given
ResourceIDfrom theSlotPool. - releaseTaskManager(ResourceID, Exception) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolService
-
Releases a TaskExecutor with the given
ResourceIDfrom theSlotPoolService. - remainingCapacity() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
-
Returns the remaining capacity of the backing array.
- REMOTE - org.apache.flink.runtime.state.StateObject.StateObjectLocation
- RemoteChannelStateChecker - Class in org.apache.flink.runtime.io.network.partition.consumer
-
Handles the response of
PartitionProducerStateProvider. - RemoteChannelStateChecker(ResultPartitionID, String) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.RemoteChannelStateChecker
- RemoteEnvironmentConfigUtils - Class in org.apache.flink.streaming.util
-
A set of tools used by batch and streaming remote environments when preparing their configurations.
- RemoteEnvironmentConfigUtils() - Constructor for class org.apache.flink.streaming.util.RemoteEnvironmentConfigUtils
- RemoteInputChannel - Class in org.apache.flink.runtime.io.network.partition.consumer
-
An input channel, which requests a remote partition queue.
- RemoteInputChannel(SingleInputGate, int, ResultPartitionID, ResultSubpartitionIndexSet, ConnectionID, ConnectionManager, int, int, int, int, Counter, Counter, ChannelStateWriter) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- RemoteRecoveredInputChannel - Class in org.apache.flink.runtime.io.network.partition.consumer
-
An input channel reads recovered state from previous unaligned checkpoint snapshots and then converts into
RemoteInputChannelfinally. - RemoteStorageScanner - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote
-
The
RemoteStorageScanneris introduced to notify asynchronously for file reading on remote storage. - RemoteStorageScanner(String) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteStorageScanner
- RemoteStreamEnvironment - Class in org.apache.flink.streaming.api.environment
-
A
StreamExecutionEnvironmentfor executing on a cluster. - RemoteStreamEnvironment(String, int, String...) - Constructor for class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
Creates a new RemoteStreamEnvironment that points to the master (JobManager) described by the given host name and port.
- RemoteStreamEnvironment(String, int, Configuration, String...) - Constructor for class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
Creates a new RemoteStreamEnvironment that points to the master (JobManager) described by the given host name and port.
- RemoteStreamEnvironment(String, int, Configuration, String[], URL[]) - Constructor for class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
Creates a new RemoteStreamEnvironment that points to the master (JobManager) described by the given host name and port.
- RemoteStreamEnvironment(String, int, Configuration, String[], URL[], SavepointRestoreSettings) - Constructor for class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
-
Creates a new RemoteStreamEnvironment that points to the master (JobManager) described by the given host name and port.
- RemoteStreamEnvironment(PipelineExecutorServiceLoader, String, int, Configuration, String[], URL[], SavepointRestoreSettings) - Constructor for class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
- RemoteTierConsumerAgent - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote
-
The data client is used to fetch data from remote tier.
- RemoteTierConsumerAgent(List<TieredStorageConsumerSpec>, RemoteStorageScanner, PartitionFileReader, int) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierConsumerAgent
- RemoteTierFactory - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote
-
The implementation of
TierFactoryfor remote tier. - RemoteTierFactory() - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierFactory
- RemoteTierMasterAgent - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote
-
The implementation of
TierMasterAgentfor the remote tier. - RemoteTierProducerAgent - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote
-
The implementation of
TierProducerAgentfor the remote tier. - RemoteTierShuffleDescriptor - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote
-
The shuffle descriptor implementation for remote tier.
- RemoteTierShuffleDescriptor(TieredStoragePartitionId) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierShuffleDescriptor
- RemoteTransportException - Exception in org.apache.flink.runtime.io.network.netty.exception
- RemoteTransportException(String, SocketAddress) - Constructor for exception org.apache.flink.runtime.io.network.netty.exception.RemoteTransportException
- RemoteTransportException(String, SocketAddress, Throwable) - Constructor for exception org.apache.flink.runtime.io.network.netty.exception.RemoteTransportException
- remove() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable.SimpleIterator
- remove() - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
- remove() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
- remove() - Method in class org.apache.flink.runtime.operators.util.metrics.CountingIterator
- remove() - Method in class org.apache.flink.runtime.util.EmptyIterator
-
Throws a
UnsupportedOperationException. - remove() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator.ValuesIterator
- remove() - Method in class org.apache.flink.runtime.util.NonReusingMutableToRegularIteratorWrapper
- remove() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator.ValuesIterator
- remove() - Method in class org.apache.flink.runtime.util.ReusingMutableToRegularIteratorWrapper
- remove() - Method in class org.apache.flink.runtime.util.SingleElementIterator
- remove(Object) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- remove(String) - Method in class org.apache.flink.runtime.iterative.concurrent.Broker
-
Blocking retrieval and removal of the object to share.
- remove(String) - Method in class org.apache.flink.runtime.leaderelection.DefaultLeaderElectionService
- remove(K) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
- remove(K, N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
- remove(K, N) - Method in class org.apache.flink.runtime.state.heap.StateMap
-
Removes the mapping for the composite of active key and given namespace.
- remove(N) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Removes the mapping for the composite of active key and given namespace.
- remove(ExecutionAttemptID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
Remove the task identified by the given execution attempt id.
- remove(InputChannelID) - Method in class org.apache.flink.runtime.io.network.partition.PartitionRequestListenerManager
- remove(StateEntry<K, N, V>) - Method in interface org.apache.flink.runtime.state.internal.InternalKvState.StateIncrementalVisitor
- remove(T) - Method in class org.apache.flink.runtime.io.network.partition.DeduplicatedQueue
- remove(T) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
- remove(T) - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueSet
-
In contrast to the superclass and to maintain set semantics, removal here is based on comparing the given element via
Object.equals(Object). - remove(T) - Method in class org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
- remove(T) - Method in interface org.apache.flink.runtime.state.InternalPriorityQueue
-
Removes the given element from the set, if is contained in the set.
- remove(T) - Method in class org.apache.flink.streaming.runtime.watermarkstatus.HeapPriorityQueue
- remove(UK) - Method in class org.apache.flink.runtime.state.v2.AbstractMapState
- remove(UK) - Method in class org.apache.flink.runtime.state.v2.adaptor.MapStateAdaptor
- REMOVE_KEY_OPTION - Static variable in class org.apache.flink.runtime.entrypoint.parser.ConfigurationCommandLineOptions
- REMOVE_KEY_VALUE_OPTION - Static variable in class org.apache.flink.runtime.entrypoint.parser.ConfigurationCommandLineOptions
- removeAll(Collection<?>) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- removeAndGetOld(K, N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
- removeAndGetOld(K, N) - Method in class org.apache.flink.runtime.state.heap.StateMap
-
Removes the mapping for the composite of active key and given namespace, returning the state that was found under the entry.
- removeAndGetOld(N) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Removes the mapping for the composite of active key and given namespace, returning the state that was found under the entry.
- removeExpiration(long, long, Collection<PartitionRequestListener>) - Method in class org.apache.flink.runtime.io.network.partition.PartitionRequestListenerManager
-
Remove the expire partition request listener and add it to the given timeoutListeners.
- removeIf(Predicate<? super T>) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- removeInputChannel(RemoteInputChannel) - Method in interface org.apache.flink.runtime.io.network.NetworkClientHandler
- removeInternal(int) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
-
Implements how to remove the element at the given index from the queue.
- removeInternal(int) - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueue
- removeJob(JobID) - Method in class org.apache.flink.runtime.resourcemanager.DefaultJobLeaderIdService
- removeJob(JobID) - Method in interface org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
Remove the given job from being monitored by the service.
- removeJob(JobID) - Method in class org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService
- removeJob(JobID) - Method in interface org.apache.flink.runtime.taskexecutor.JobLeaderService
-
Remove the given job from being monitored by the job leader service.
- removeJob(JobID, Exception) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- removeJobMetricsGroup(JobID) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
- removeKeyA(A) - Method in class org.apache.flink.runtime.util.DualKeyLinkedMap
- removeKeyB(B) - Method in class org.apache.flink.runtime.util.DualKeyLinkedMap
- removeLast() - Method in class org.apache.flink.runtime.util.IntArrayList
- removeLong(int) - Method in class org.apache.flink.runtime.util.LongArrayList
- removeMetric(Metric) - Method in class org.apache.flink.runtime.metrics.dump.MetricQueryService
- removePathPattern(String) - Method in class org.apache.flink.runtime.rest.handler.router.Router
-
Removes the route specified by the path pattern.
- removePendingTaskManager(PendingTaskManagerId) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- RemoveRangeIndex<T> - Class in org.apache.flink.runtime.operators.udf
- RemoveRangeIndex() - Constructor for class org.apache.flink.runtime.operators.udf.RemoveRangeIndex
- removeSlot(AllocationID) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotPool
-
Removes the slot with the given allocationId from the slot pool.
- removeSlot(AllocationID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultAllocatedSlotPool
- removeSlots(ResourceID) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotPool
-
Removes all slots belonging to the owning TaskExecutor identified by owner.
- removeSlots(ResourceID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultAllocatedSlotPool
- removeTask(ExecutionAttemptID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Remove the task with the given execution attempt id from its task slot.
- removeTask(ExecutionAttemptID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- removeTaskManager(InstanceID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- removeTaskMetricGroup(ExecutionAttemptID) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
- removeTimeoutNodes(long) - Method in interface org.apache.flink.runtime.blocklist.BlocklistTracker
-
Remove timeout nodes.
- removeTimeoutNodes(long) - Method in class org.apache.flink.runtime.blocklist.DefaultBlocklistTracker
- removeVertexFromGroup(JobVertexID) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
- reopen(Iterator<T>) - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
- ReOpenableHashPartition<BT,PT> - Class in org.apache.flink.runtime.operators.hash
- ReOpenableMutableHashTable<BT,PT> - Class in org.apache.flink.runtime.operators.hash
- ReOpenableMutableHashTable(TypeSerializer<BT>, TypeSerializer<PT>, TypeComparator<BT>, TypeComparator<PT>, TypePairComparator<PT, BT>, List<MemorySegment>, IOManager, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
- reopenProbe(MutableObjectIterator<PT>) - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
- reopenProbe(MutableObjectIterator<V1>) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondReOpenableHashJoinIterator
-
Set new input for probe side
- reopenProbe(MutableObjectIterator<V1>) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondReOpenableHashJoinIterator
-
Set new input for probe side
- reopenProbe(MutableObjectIterator<V2>) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstReOpenableHashJoinIterator
-
Set new input for probe side
- reopenProbe(MutableObjectIterator<V2>) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstReOpenableHashJoinIterator
-
Set new input for probe side
- repartitionState(List<List<OperatorStateHandle>>, int, int) - Method in class org.apache.flink.runtime.checkpoint.RoundRobinOperatorStateRepartitioner
- repartitionState(List<List<T>>, int, int) - Method in class org.apache.flink.runtime.checkpoint.MappingBasedRepartitioner
- repartitionState(List<List<T>>, int, int) - Method in interface org.apache.flink.runtime.checkpoint.OperatorStateRepartitioner
- replace(String, IntegerResourceVersion, T) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Replaces a state handle in ZooKeeper and discards the old state handle.
- replace(String, R, T) - Method in interface org.apache.flink.runtime.persistence.StateHandleStore
-
Replaces a state handle in the distributed coordination system and discards the old state handle.
- replace(X) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Replace the currently stored value by the given new value.
- replace(X, long) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Replace the currently stored value by the given new value and the currently stored timestamp with the new timestamp.
- REPLACE_KEY_VALUE_OPTION - Static variable in class org.apache.flink.runtime.entrypoint.parser.ConfigurationCommandLineOptions
- replaceAllPendingAllocations(Map<JobID, ResourceCounter>) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingTaskManager
- replaceAllPendingAllocations(Map<PendingTaskManagerId, Map<JobID, ResourceCounter>>) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedTaskManagerTracker
- replaceHandle(StreamStateHandle) - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle.HandleAndLocalPath
-
Replace the StreamStateHandle with the registry returned one.
- replay(JobEventReplayHandler) - Method in class org.apache.flink.runtime.jobmaster.event.JobEventManager
-
Replay all job events that have been record.
- replayOneEvent(JobEvent) - Method in interface org.apache.flink.runtime.jobmaster.event.JobEventReplayHandler
-
Called to replay one job event.
- replayOneEvent(JobEvent) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DefaultBatchJobRecoveryHandler
- reportAllElementKeyGroups() - Method in class org.apache.flink.runtime.state.KeyGroupPartitioner
-
This method iterates over the input data and reports the key-group for each element.
- reportCheckpointMetrics(long, ExecutionAttemptID, CheckpointMetrics) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
- reportCheckpointMetrics(JobID, ExecutionAttemptID, long, CheckpointMetrics) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointCoordinatorGateway
- reportCheckpointMetrics(JobID, ExecutionAttemptID, long, CheckpointMetrics) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- reportCheckpointMetrics(JobID, ExecutionAttemptID, long, CheckpointMetrics) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- reportCheckpointMetrics(JobID, ExecutionAttemptID, long, CheckpointMetrics) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- reportCheckpointMetrics(JobID, ExecutionAttemptID, long, CheckpointMetrics) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
- reportCheckpointMetrics(JobID, ExecutionAttemptID, long, CheckpointMetrics) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcCheckpointResponder
- reportCheckpointMetrics(JobID, ExecutionAttemptID, long, CheckpointMetrics) - Method in interface org.apache.flink.runtime.taskmanager.CheckpointResponder
-
Report metrics for the given checkpoint.
- reportCheckpointMetrics(ExecutionAttemptID, long, CheckpointMetrics) - Method in class org.apache.flink.runtime.scheduler.ExecutionGraphHandler
- reportClusterPartitions(ResourceID, ClusterPartitionReport) - Method in interface org.apache.flink.runtime.io.network.partition.ClusterPartitionManager
-
Report the cluster partitions status in the task executor.
- reportClusterPartitions(ResourceID, ClusterPartitionReport) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- reportCompletedCheckpoint(CompletedCheckpointStats) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
-
Callback when a checkpoint completes.
- reportCompletedCheckpoint(CompletedCheckpointStats) - Method in class org.apache.flink.runtime.checkpoint.DefaultCheckpointStatsTracker
- reportCompletedCheckpoint(CompletedCheckpointStats) - Method in enum org.apache.flink.runtime.checkpoint.NoOpCheckpointStatsTracker
- ReportedWatermarkEvent - Class in org.apache.flink.runtime.source.event
-
Reports last emitted
Watermarkfrom a subtask to theSourceCoordinator. - ReportedWatermarkEvent(long) - Constructor for class org.apache.flink.runtime.source.event.ReportedWatermarkEvent
- ReporterScopedSettings - Class in org.apache.flink.runtime.metrics.groups
-
Encapsulates all settings that are defined per reporter.
- ReporterScopedSettings(int, char, MetricFilter, Set<String>, Map<String, String>) - Constructor for class org.apache.flink.runtime.metrics.groups.ReporterScopedSettings
- ReporterSetup - Class in org.apache.flink.runtime.metrics
-
Encapsulates everything needed for the instantiation and configuration of a
MetricReporter. - ReporterSetup(String, MetricConfig, MetricReporter, MetricFilter, Map<String, String>) - Constructor for class org.apache.flink.runtime.metrics.ReporterSetup
- reportFailedCheckpoint(FailedCheckpointStats) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
- reportFailedCheckpoint(FailedCheckpointStats) - Method in class org.apache.flink.runtime.checkpoint.DefaultCheckpointStatsTracker
- reportFailedCheckpoint(FailedCheckpointStats) - Method in enum org.apache.flink.runtime.checkpoint.NoOpCheckpointStatsTracker
- reportFailedCheckpointsWithoutInProgress() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
-
Callback when a checkpoint failure without in progress checkpoint.
- reportFailedCheckpointsWithoutInProgress() - Method in class org.apache.flink.runtime.checkpoint.DefaultCheckpointStatsTracker
- reportFailedCheckpointsWithoutInProgress() - Method in enum org.apache.flink.runtime.checkpoint.NoOpCheckpointStatsTracker
- reportHeartbeat() - Method in class org.apache.flink.runtime.heartbeat.DefaultHeartbeatMonitor
- reportHeartbeat() - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatMonitor
-
Report heartbeat from the monitored target.
- reportHeartbeat(long) - Method in class org.apache.flink.runtime.minicluster.MiniClusterJobClient
- reportHeartbeat(JobID, long) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- reportHeartbeatRpcFailure() - Method in class org.apache.flink.runtime.heartbeat.DefaultHeartbeatMonitor
- reportHeartbeatRpcFailure() - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatMonitor
-
Reports that the heartbeat rpc could not be sent to the target.
- reportHeartbeatRpcSuccess() - Method in class org.apache.flink.runtime.heartbeat.DefaultHeartbeatMonitor
- reportHeartbeatRpcSuccess() - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatMonitor
-
Reports that the heartbeat rpc could be sent to the target.
- reportIncompleteStats(long, ExecutionAttemptID, CheckpointMetrics) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
- reportIncompleteStats(long, ExecutionAttemptID, CheckpointMetrics) - Method in class org.apache.flink.runtime.checkpoint.DefaultCheckpointStatsTracker
- reportIncompleteStats(long, ExecutionAttemptID, CheckpointMetrics) - Method in enum org.apache.flink.runtime.checkpoint.NoOpCheckpointStatsTracker
- reportIncompleteTaskStateSnapshots(CheckpointMetaData, CheckpointMetrics) - Method in interface org.apache.flink.runtime.state.TaskStateManager
-
Report the stats for state snapshots for an aborted checkpoint.
- reportIncompleteTaskStateSnapshots(CheckpointMetaData, CheckpointMetrics) - Method in class org.apache.flink.runtime.state.TaskStateManagerImpl
- reportInitializationMetrics(JobID, ExecutionAttemptID, SubTaskInitializationMetrics) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointCoordinatorGateway
- reportInitializationMetrics(JobID, ExecutionAttemptID, SubTaskInitializationMetrics) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- reportInitializationMetrics(JobID, ExecutionAttemptID, SubTaskInitializationMetrics) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- reportInitializationMetrics(JobID, ExecutionAttemptID, SubTaskInitializationMetrics) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- reportInitializationMetrics(JobID, ExecutionAttemptID, SubTaskInitializationMetrics) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
- reportInitializationMetrics(JobID, ExecutionAttemptID, SubTaskInitializationMetrics) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcCheckpointResponder
- reportInitializationMetrics(JobID, ExecutionAttemptID, SubTaskInitializationMetrics) - Method in interface org.apache.flink.runtime.taskmanager.CheckpointResponder
- reportInitializationMetrics(SubTaskInitializationMetrics) - Method in interface org.apache.flink.runtime.state.TaskStateManager
- reportInitializationMetrics(SubTaskInitializationMetrics) - Method in class org.apache.flink.runtime.state.TaskStateManagerImpl
- reportInitializationMetrics(ExecutionAttemptID, SubTaskInitializationMetrics) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
- reportInitializationMetrics(ExecutionAttemptID, SubTaskInitializationMetrics) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
- reportInitializationMetrics(ExecutionAttemptID, SubTaskInitializationMetrics) - Method in class org.apache.flink.runtime.checkpoint.DefaultCheckpointStatsTracker
- reportInitializationMetrics(ExecutionAttemptID, SubTaskInitializationMetrics) - Method in enum org.apache.flink.runtime.checkpoint.NoOpCheckpointStatsTracker
- reportInitializationMetrics(ExecutionAttemptID, SubTaskInitializationMetrics) - Method in class org.apache.flink.runtime.scheduler.ExecutionGraphHandler
- reportInitializationStarted(Set<ExecutionAttemptID>, long) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
- reportInitializationStarted(Set<ExecutionAttemptID>, long) - Method in class org.apache.flink.runtime.checkpoint.DefaultCheckpointStatsTracker
- reportInitializationStarted(Set<ExecutionAttemptID>, long) - Method in enum org.apache.flink.runtime.checkpoint.NoOpCheckpointStatsTracker
- reportJobClientHeartbeat(JobID, long, Duration) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- reportJobClientHeartbeat(JobID, long, Duration) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
The client reports the heartbeat to the dispatcher for aliveness.
- reportJobFailure(FailureHandlingResult, Map<String, String>) - Method in class org.apache.flink.runtime.scheduler.adaptive.JobFailureMetricReporter
- reportJobFailure(FailureResult, Map<String, String>) - Method in class org.apache.flink.runtime.scheduler.adaptive.JobFailureMetricReporter
- reportKeyGroupOfElementAtIndex(int, int) - Method in class org.apache.flink.runtime.state.KeyGroupPartitioner
-
This method reports in the bookkeeping data that the element at the given index belongs to the given key-group.
- reportLatency(LatencyMarker) - Method in class org.apache.flink.streaming.util.LatencyStats
- reportOrForwardLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- reportOrForwardLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- reportOrForwardLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.StreamSink
- reportPayload(ResourceID, I) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatListener
-
Callback which is called whenever a heartbeat with an associated payload is received.
- reportPendingCheckpoint(long, long, CheckpointProperties, Map<JobVertexID, Integer>) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
-
Creates a new pending checkpoint tracker.
- reportPendingCheckpoint(long, long, CheckpointProperties, Map<JobVertexID, Integer>) - Method in class org.apache.flink.runtime.checkpoint.DefaultCheckpointStatsTracker
- reportPendingCheckpoint(long, long, CheckpointProperties, Map<JobVertexID, Integer>) - Method in enum org.apache.flink.runtime.checkpoint.NoOpCheckpointStatsTracker
- reportRestoredCheckpoint(long, CheckpointProperties, String, long) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
- reportRestoredCheckpoint(long, CheckpointProperties, String, long) - Method in class org.apache.flink.runtime.checkpoint.DefaultCheckpointStatsTracker
- reportRestoredCheckpoint(long, CheckpointProperties, String, long) - Method in enum org.apache.flink.runtime.checkpoint.NoOpCheckpointStatsTracker
- reportSlotStatus(InstanceID, SlotReport) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.DefaultSlotStatusSyncer
- reportSlotStatus(InstanceID, SlotReport) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedSlotManager
-
Reports the current slot allocations for a task manager identified by the given instance id.
- reportSlotStatus(InstanceID, SlotReport) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Reports the current slot allocations for a task manager identified by the given instance id.
- reportSlotStatus(InstanceID, SlotReport) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotStatusSyncer
-
Reconcile the slot status with the slot report.
- reportTaskFinishedOnRestore(ExecutionVertex) - Method in class org.apache.flink.runtime.checkpoint.DefaultCheckpointPlan
- reportTaskFinishedOnRestore(ExecutionVertex) - Method in interface org.apache.flink.runtime.checkpoint.FinishedTaskStateProvider
-
Reports the
taskis finished on restoring. - reportTaskHasFinishedOperators(ExecutionVertex) - Method in class org.apache.flink.runtime.checkpoint.DefaultCheckpointPlan
- reportTaskHasFinishedOperators(ExecutionVertex) - Method in interface org.apache.flink.runtime.checkpoint.FinishedTaskStateProvider
-
Reports the
taskhas finished all the operators. - reportTaskStateSnapshots(CheckpointMetaData, CheckpointMetrics, TaskStateSnapshot, TaskStateSnapshot) - Method in interface org.apache.flink.runtime.state.TaskStateManager
-
Report the state snapshots for the operator instances running in the owning task.
- reportTaskStateSnapshots(CheckpointMetaData, CheckpointMetrics, TaskStateSnapshot, TaskStateSnapshot) - Method in class org.apache.flink.runtime.state.TaskStateManagerImpl
- reportThrowable(Throwable) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
Reports a throwable for rethrowing from the mailbox thread.
- reportWatermark(Watermark, int) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- REPROCESS_WITH_APPENDED - org.apache.flink.streaming.api.functions.source.legacy.FileMonitoringFunction.WatchType
-
Deprecated.
- RequestBody - Interface in org.apache.flink.runtime.rest.messages
-
Marker interface for all requests of the REST API.
- requestBuffer() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
Returns a
Bufferinstance from the buffer provider, if one is available. - requestBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
- requestBuffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
Requests buffer from input channel directly for receiving network data.
- requestBufferBlocking() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RecoveredInputChannel
- requestBufferBlocking() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.HashBufferAccumulator
- requestBufferBlocking() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.HashSubpartitionBufferAccumulatorContext
-
Request
BufferBuilderfrom theBufferPool. - requestBufferBlocking(Object) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemoryManager
-
Request a
BufferBuilderinstance for a specific owner. - requestBufferBlocking(Object) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemoryManagerImpl
- requestBufferBuilder() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
Returns a
BufferBuilderinstance from the buffer provider. - requestBufferBuilder() - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
- requestBufferBuilder(int) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
Returns a
BufferBuilderinstance from the buffer provider. - requestBufferBuilder(int) - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
- requestBufferBuilderBlocking() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
Returns a
BufferBuilderinstance from the buffer provider. - requestBufferBuilderBlocking() - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
- requestBufferBuilderBlocking() - Method in interface org.apache.flink.runtime.io.network.partition.CheckpointedResultPartition
- requestBufferBuilderBlocking() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedResultPartition
- requestBufferBuilderBlocking(int) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
Returns a
BufferBuilderinstance from the buffer provider. - requestBufferBuilderBlocking(int) - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
- requestBuffers() - Method in class org.apache.flink.runtime.io.disk.BatchShuffleReadBufferPool
-
Requests a collection of buffers (determined by
BatchShuffleReadBufferPool.numBuffersPerRequest) from this buffer pool. - requestCheckpointStats() - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- requestCheckpointStats() - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- requestCheckpointStats() - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
-
Returns the checkpoint statistics for a given job.
- requestCheckpointStats(Duration) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- requestCheckpointStats(Duration) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Requests the
CheckpointStatsSnapshotof the job. - requestCheckpointStats(JobID, Duration) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- requestCheckpointStats(JobID, Duration) - Method in class org.apache.flink.runtime.webmonitor.NonLeaderRetrievalRestfulGateway
- requestCheckpointStats(JobID, Duration) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Requests the
CheckpointStatsSnapshotcontaining checkpointing information. - requestClusterOverview() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- requestClusterOverview(Duration) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- requestClusterOverview(Duration) - Method in class org.apache.flink.runtime.webmonitor.NonLeaderRetrievalRestfulGateway
- requestClusterOverview(Duration) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Requests the cluster status overview.
- RequestDoneCallback<T> - Interface in org.apache.flink.runtime.io.disk.iomanager
-
Callback to be executed on completion of an asynchronous I/O request.
- requestExecutionGraphInfo(JobID, Duration) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- requestExecutionGraphInfo(JobID, Duration) - Method in class org.apache.flink.runtime.webmonitor.NonLeaderRetrievalRestfulGateway
- requestExecutionGraphInfo(JobID, Duration) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Requests the
ExecutionGraphInfocontaining additional information besides theArchivedExecutionGraph. - requestFailed(T, IOException) - Method in class org.apache.flink.runtime.io.disk.iomanager.QueuingCallback
- requestFailed(T, IOException) - Method in interface org.apache.flink.runtime.io.disk.iomanager.RequestDoneCallback
- requestFileUpload(ResourceManagerGateway, Tuple2<ResourceID, String>) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.AbstractTaskManagerFileHandler
- requestFileUpload(ResourceManagerGateway, Tuple2<ResourceID, String>) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerCustomLogHandler
- requestFileUpload(ResourceManagerGateway, Tuple2<ResourceID, String>) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerLogFileHandler
- requestFileUpload(ResourceManagerGateway, Tuple2<ResourceID, String>) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerProfilingFileHandler
- requestFileUpload(ResourceManagerGateway, Tuple2<ResourceID, String>) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerStdoutFileHandler
- requestFileUploadByName(String, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- requestFileUploadByName(String, Duration) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Requests the file upload of the specified name to the cluster's
BlobServer. - requestFileUploadByName(String, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- requestFileUploadByNameAndType(String, FileType, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- requestFileUploadByNameAndType(String, FileType, Duration) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Requests the file upload of the specified name and file type to the cluster's
BlobServer. - requestFileUploadByNameAndType(String, FileType, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- requestFileUploadByType(FileType, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- requestFileUploadByType(FileType, Duration) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Requests the file upload of the specified type to the cluster's
BlobServer. - requestFileUploadByType(FileType, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- requestHeartbeat(ResourceID, I) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatReceiver
- requestHeartbeat(ResourceID, I) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatTarget
-
Requests a heartbeat from the target.
- requestHeartbeat(ResourceID, I) - Method in class org.apache.flink.runtime.heartbeat.NoOpHeartbeatManager
- requestId - Variable in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator.PendingStatsRequest
-
ID of the sampling request to this coordinator.
- requestIdCounter - Variable in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator
-
Sample ID counter.
- requestJob() - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- requestJob() - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- requestJob() - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
- requestJob(Duration) - Method in class org.apache.flink.runtime.dispatcher.cleanup.CheckpointResourcesCleanupRunner
- requestJob(Duration) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerRunner
-
Requests the
ExecutionGraphInfoof the executed job. - requestJob(Duration) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- requestJob(Duration) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Requests the
ExecutionGraphInfoof the executed job. - requestJob(Duration) - Method in class org.apache.flink.runtime.jobmaster.JobMasterServiceLeadershipRunner
- requestJob(JobID, Duration) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Requests the
ArchivedExecutionGraphfor the given jobId. - requestJobDetails(Duration) - Method in class org.apache.flink.runtime.dispatcher.cleanup.CheckpointResourcesCleanupRunner
- requestJobDetails(Duration) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerRunner
-
Request the details of the executed job.
- requestJobDetails(Duration) - Method in class org.apache.flink.runtime.jobmaster.JobMasterServiceLeadershipRunner
- RequestJobDetails - Class in org.apache.flink.runtime.messages.webmonitor
-
This message requests an overview of the jobs on the JobManager, including running jobs and/or finished jobs.
- RequestJobDetails(boolean, boolean) - Constructor for class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
- requestJobResourceRequirements() - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- requestJobResourceRequirements() - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Read current
job resource requirements. - requestJobResourceRequirements() - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- requestJobResourceRequirements() - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
-
Read current
job resource requirements. - requestJobResourceRequirements(JobID) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- requestJobResourceRequirements(JobID) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Read current
job resource requirementsfor a given job. - requestJobResult(JobID) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- requestJobResult(JobID, Duration) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- requestJobResult(JobID, Duration) - Method in class org.apache.flink.runtime.dispatcher.MiniDispatcher
- requestJobResult(JobID, Duration) - Method in class org.apache.flink.runtime.webmonitor.NonLeaderRetrievalRestfulGateway
- requestJobResult(JobID, Duration) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Requests the
JobResultof a job specified by the given jobId. - RequestJobsOverview - Class in org.apache.flink.runtime.messages.webmonitor
-
This message requests an overview of how many jobs are in which status.
- requestJobStatus() - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- requestJobStatus() - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- requestJobStatus() - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
- requestJobStatus(Duration) - Method in class org.apache.flink.runtime.dispatcher.cleanup.CheckpointResourcesCleanupRunner
- requestJobStatus(Duration) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerRunner
-
Requests the current job status.
- requestJobStatus(Duration) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- requestJobStatus(Duration) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Requests the current job status.
- requestJobStatus(Duration) - Method in class org.apache.flink.runtime.jobmaster.JobMasterServiceLeadershipRunner
- requestJobStatus(JobID, Duration) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- requestJobStatus(JobID, Duration) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Request the
JobStatusof the given job. - RequestJobsWithIDsOverview - Class in org.apache.flink.runtime.messages.webmonitor
-
This message requests an overview of how many jobs are in which status.
- requestKvStateLocation(JobID, String) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- requestKvStateLocation(JobID, String) - Method in interface org.apache.flink.runtime.jobmaster.KvStateLocationOracle
-
Requests a
KvStateLocationfor the specifiedInternalKvStateregistration name. - requestKvStateLocation(JobID, String) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- requestKvStateLocation(JobID, String) - Method in class org.apache.flink.runtime.scheduler.KvStateHandler
- requestKvStateLocation(JobID, String) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- requestKvStateLocation(JobID, String) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
- requestLogList(Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- requestLogList(Duration) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Requests for the historical log file names on the TaskManager.
- requestLogList(Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- requestMemorySegment() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
Returns a
MemorySegmentinstance from the buffer provider. - requestMemorySegment() - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
- requestMemorySegmentBlocking() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
Returns a
MemorySegmentinstance from the buffer provider. - requestMemorySegmentBlocking() - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
- requestMetricQueryServiceAddress(Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- requestMetricQueryServiceAddress(Duration) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Returns the gateway of Metric Query Service on the TaskManager.
- requestMetricQueryServiceAddress(Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- requestMetricQueryServiceAddresses(Duration) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- requestMetricQueryServiceAddresses(Duration) - Method in class org.apache.flink.runtime.webmonitor.NonLeaderRetrievalRestfulGateway
- requestMetricQueryServiceAddresses(Duration) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Requests the addresses of the
MetricQueryServiceto query. - requestMultipleJobDetails(Duration) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- requestMultipleJobDetails(Duration) - Method in class org.apache.flink.runtime.webmonitor.NonLeaderRetrievalRestfulGateway
- requestMultipleJobDetails(Duration) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Requests job details currently being executed on the Flink cluster.
- requestNewAllocatedBatchSlot(SlotRequestId, ResourceProfile) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Requests the allocation of a new batch slot from the resource manager.
- requestNewAllocatedBatchSlot(SlotRequestId, ResourceProfile, Collection<AllocationID>) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolBridge
- requestNewAllocatedBatchSlot(SlotRequestId, ResourceProfile, Collection<AllocationID>) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
- requestNewAllocatedSlot(SlotRequestId, ResourceProfile, Duration) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Request the allocation of a new slot from the resource manager.
- requestNewAllocatedSlot(SlotRequestId, ResourceProfile, Collection<AllocationID>, Duration) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolBridge
- requestNewAllocatedSlot(SlotRequestId, ResourceProfile, Collection<AllocationID>, Duration) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Request the allocation of a new slot from the resource manager.
- requestNewWorker(WorkerResourceSpec) - Method in class org.apache.flink.runtime.resourcemanager.active.ActiveResourceManager
-
Allocates a resource using the worker resource specification.
- requestNextInputSplit(JobVertexID, ExecutionAttemptID) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- requestNextInputSplit(JobVertexID, ExecutionAttemptID) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Requests the next input split for the
ExecutionJobVertex. - requestNextInputSplit(JobVertexID, ExecutionAttemptID) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- requestNextInputSplit(JobVertexID, ExecutionAttemptID) - Method in class org.apache.flink.runtime.scheduler.ExecutionGraphHandler
- requestNextInputSplit(JobVertexID, ExecutionAttemptID) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- requestNextInputSplit(JobVertexID, ExecutionAttemptID) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
- requestPartitionProducerState(JobID, IntermediateDataSetID, ResultPartitionID) - Method in interface org.apache.flink.runtime.taskexecutor.PartitionProducerStateChecker
-
Requests the execution state of the execution producing a result partition.
- requestPartitionProducerState(JobID, IntermediateDataSetID, ResultPartitionID) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcPartitionStateChecker
- requestPartitionProducerState(IntermediateDataSetID, ResultPartitionID, Consumer<? super PartitionProducerStateProvider.ResponseHandle>) - Method in interface org.apache.flink.runtime.io.network.partition.PartitionProducerStateProvider
-
Trigger the producer execution state request.
- requestPartitionProducerState(IntermediateDataSetID, ResultPartitionID, Consumer<? super PartitionProducerStateProvider.ResponseHandle>) - Method in class org.apache.flink.runtime.taskmanager.Task
- requestPartitions() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
- requestPartitions() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- requestPartitions() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
- requestPartitions() - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
- requestPartitionState(IntermediateDataSetID, ResultPartitionID) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- requestPartitionState(IntermediateDataSetID, ResultPartitionID) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Requests the current state of the partition.
- requestPartitionState(IntermediateDataSetID, ResultPartitionID) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- requestPartitionState(IntermediateDataSetID, ResultPartitionID) - Method in class org.apache.flink.runtime.scheduler.ExecutionGraphHandler
- requestPartitionState(IntermediateDataSetID, ResultPartitionID) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- requestPartitionState(IntermediateDataSetID, ResultPartitionID) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
- requestPooledMemorySegment() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
Different from
NetworkBufferPool.requestUnpooledMemorySegments(int)for unpooled segments allocation. - requestPooledMemorySegmentsBlocking(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
- requestProfiling(int, ProfilingInfo.ProfilingMode, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- requestProfiling(int, ProfilingInfo.ProfilingMode, Duration) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Requests the profiling from this TaskManager.
- requestProfiling(int, ProfilingInfo.ProfilingMode, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- requestProfiling(String, long, ProfilingInfo.ProfilingMode) - Method in class org.apache.flink.runtime.util.profiler.ProfilingService
- requestProfiling(ResourceID, int, ProfilingInfo.ProfilingMode, Duration) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- requestProfiling(ResourceID, int, ProfilingInfo.ProfilingMode, Duration) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Requests the profiling instance from the given
TaskExecutor. - requestProfilingList(Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- requestProfilingList(Duration) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Requests for the historical profiling file names on the TaskManager.
- requestProfilingList(Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- requestQueue - Variable in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
A request queue for submitting asynchronous requests to the corresponding IO worker thread.
- RequestQueue<E> - Class in org.apache.flink.runtime.io.disk.iomanager
-
A
LinkedBlockingQueuethat is extended with closing methods. - RequestQueue() - Constructor for class org.apache.flink.runtime.io.disk.iomanager.RequestQueue
- requestResource(TaskExecutorProcessSpec) - Method in interface org.apache.flink.runtime.resourcemanager.active.ResourceManagerDriver
-
Request resource from the external resource manager.
- requestResourceOverview(Duration) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- requestResourceOverview(Duration) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Requests the resource overview.
- requestSlot(SlotID, JobID, AllocationID, ResourceProfile, String, ResourceManagerId, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- requestSlot(SlotID, JobID, AllocationID, ResourceProfile, String, ResourceManagerId, Duration) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Requests a slot from the TaskManager.
- requestSlot(SlotID, JobID, AllocationID, ResourceProfile, String, ResourceManagerId, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- RequestSlotMatchingStrategy - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
Strategy to match slot requests to slots.
- RequestSlotMatchingStrategy.RequestSlotMatch - Class in org.apache.flink.runtime.jobmaster.slotpool
-
Result class representing matches.
- requestsNotReturned - Variable in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
An atomic integer that counts the number of requests that we still wait for to return.
- RequestSplitEvent - Class in org.apache.flink.runtime.source.event
-
An event to request splits, sent typically from the Source Reader to the Source Enumerator.
- RequestSplitEvent() - Constructor for class org.apache.flink.runtime.source.event.RequestSplitEvent
-
Creates a new
RequestSplitEventwith no host information. - RequestSplitEvent(String) - Constructor for class org.apache.flink.runtime.source.event.RequestSplitEvent
-
Creates a new
RequestSplitEventwith a hostname. - RequestStatusOverview - Class in org.apache.flink.runtime.messages.webmonitor
-
This message requests an overview of the status, such as how many TaskManagers are currently connected, how many slots are available, how many are free, ...
- requestSubpartition(ResultPartitionID, ResultSubpartitionIndexSet, RemoteInputChannel, int) - Method in class org.apache.flink.runtime.io.network.netty.NettyPartitionRequestClient
-
Requests a remote intermediate result partition queue.
- requestSubpartition(ResultPartitionID, ResultSubpartitionIndexSet, RemoteInputChannel, int) - Method in interface org.apache.flink.runtime.io.network.PartitionRequestClient
-
Requests a range of remote sub partitions.
- requestSubpartitions() - Method in class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
- requestSubpartitions() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
Requests a remote subpartition.
- requestSubpartitionViewOrRegisterListener(ResultPartitionProvider, ResultPartitionID, ResultSubpartitionIndexSet) - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
When the netty server receives the downstream task's partition request and the upstream task has registered its partition, it will process the partition request immediately, otherwise it will create a
PartitionRequestListenerfor givenResultPartitionIDinResultPartitionManagerand notify the listener when the upstream task registers its partition. - requestSuccessful(T) - Method in class org.apache.flink.runtime.io.disk.iomanager.QueuingCallback
- requestSuccessful(T) - Method in interface org.apache.flink.runtime.io.disk.iomanager.RequestDoneCallback
- requestTaskExecutorThreadInfoGateway(ResourceID, Duration) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- requestTaskExecutorThreadInfoGateway(ResourceID, Duration) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Requests the
TaskExecutorGateway. - requestTaskManagerDetailsInfo(ResourceID, Duration) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- requestTaskManagerDetailsInfo(ResourceID, Duration) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Requests detail information about the given
TaskExecutor. - requestTaskManagerFileUploadByNameAndType(ResourceID, String, FileType, Duration) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- requestTaskManagerFileUploadByNameAndType(ResourceID, String, FileType, Duration) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Request the file upload from the given
TaskExecutorto the cluster'sBlobServer. - requestTaskManagerFileUploadByType(ResourceID, FileType, Duration) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- requestTaskManagerFileUploadByType(ResourceID, FileType, Duration) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Request the file upload from the given
TaskExecutorto the cluster'sBlobServer. - requestTaskManagerInfo(Duration) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- requestTaskManagerInfo(Duration) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Requests information about the registered
TaskExecutor. - requestTaskManagerLogList(ResourceID, Duration) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- requestTaskManagerLogList(ResourceID, Duration) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Request log list from the given
TaskExecutor. - requestTaskManagerMetricQueryServiceAddresses(Duration) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- requestTaskManagerMetricQueryServiceAddresses(Duration) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- requestTaskManagerMetricQueryServiceAddresses(Duration) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Requests the paths for the TaskManager's
MetricQueryServiceto query. - requestTaskManagerMetricQueryServiceAddresses(Duration) - Method in class org.apache.flink.runtime.webmonitor.NonLeaderRetrievalRestfulGateway
- requestTaskManagerMetricQueryServiceAddresses(Duration) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Requests the addresses for the TaskManagers'
MetricQueryServiceto query. - requestTaskManagerProfilingList(ResourceID, Duration) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- requestTaskManagerProfilingList(ResourceID, Duration) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Request profiling list from the given
TaskExecutor. - requestTermination() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
- requestTermination() - Method in class org.apache.flink.runtime.iterative.task.IterationSynchronizationSinkTask
- requestTermination() - Method in interface org.apache.flink.runtime.iterative.task.Terminable
- requestThreadDump(Duration) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- requestThreadDump(Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- requestThreadDump(Duration) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Requests the thread dump from this TaskManager.
- requestThreadDump(Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- requestThreadDump(Duration) - Method in class org.apache.flink.runtime.webmonitor.NonLeaderRetrievalRestfulGateway
- requestThreadDump(Duration) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Requests the thread dump from the JobManager.
- requestThreadDump(ResourceID, Duration) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- requestThreadDump(ResourceID, Duration) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Requests the thread dump from the given
TaskExecutor. - requestThreadInfoSamples(Collection<ExecutionAttemptID>, ThreadInfoSamplesRequest, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- requestThreadInfoSamples(Collection<ExecutionAttemptID>, ThreadInfoSamplesRequest, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- requestThreadInfoSamples(Collection<ExecutionAttemptID>, ThreadInfoSamplesRequest, Duration) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorThreadInfoGateway
-
Request a thread info sample from the given tasks.
- requestTimeout - Variable in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator
-
Request time out of the triggered tasks stats request.
- requestUnpooledMemorySegments(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
Unpooled memory segments are requested directly from
NetworkBufferPool, as opposed to pooled segments, that are requested throughBufferPoolthat was created from thisNetworkBufferPool(seeNetworkBufferPool.createBufferPool(int, int)). - RequirementMatcher - Interface in org.apache.flink.runtime.slots
-
A matcher for resource profiles to requirements.
- requiresAnnouncement() - Method in enum org.apache.flink.runtime.io.network.buffer.Buffer.DataType
- requiresComparator() - Method in enum org.apache.flink.runtime.operators.shipping.ShipStrategyType
- requiresComparator() - Method in enum org.apache.flink.runtime.operators.util.LocalStrategy
- requiresExternalizedCheckpoints() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
This method returns whether the completed checkpoint store requires checkpoints to be externalized.
- requiresExternalizedCheckpoints() - Method in enum org.apache.flink.runtime.checkpoint.DeactivatedCheckpointCompletedCheckpointStore
- requiresExternalizedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.DefaultCompletedCheckpointStore
- requiresExternalizedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.EmbeddedCompletedCheckpointStore
- requiresExternalizedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
- requiresLegacySynchronousTimerSnapshots(SnapshotType) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- requiresSorting(StreamConfig.InputConfig) - Static method in class org.apache.flink.streaming.api.graph.StreamConfig
- rescale() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStreamso that the output elements are distributed evenly to a subset of instances of the next operation in a round-robin fashion. - RescaleMappings - Class in org.apache.flink.runtime.checkpoint
-
Contains the fine-grain channel mappings that occur when a connected operator has been rescaled.
- RescalePartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that distributes the data equally by cycling through the output channels.
- RescalePartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
- RESCALING - org.apache.flink.runtime.checkpoint.InflightDataRescalingDescriptor.InflightDataGateOrPartitionRescalingDescriptor.MappingType
- RescalingHandlers - Class in org.apache.flink.runtime.rest.handler.job.rescaling
-
Rest handler to trigger and poll the rescaling of a running job.
- RescalingHandlers(Duration) - Constructor for class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers
- RescalingHandlers.RescalingStatusHandler - Class in org.apache.flink.runtime.rest.handler.job.rescaling
-
Handler which reports the status of the rescaling operation.
- RescalingHandlers.RescalingTriggerHandler - Class in org.apache.flink.runtime.rest.handler.job.rescaling
-
Handler which triggers the rescaling of the specified job.
- rescalingParallelismQueryParameter - Variable in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerMessageParameters
- RescalingParallelismQueryParameter - Class in org.apache.flink.runtime.rest.messages
-
Parallelism for the rescaling of jobs specified as a
MessageQueryParameter. - RescalingParallelismQueryParameter() - Constructor for class org.apache.flink.runtime.rest.messages.RescalingParallelismQueryParameter
- RescalingStatusHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingStatusHandler
- RescalingStatusHeaders - Class in org.apache.flink.runtime.rest.handler.job.rescaling
-
Message headers for polling the status of an ongoing rescaling operation.
- RescalingStatusMessageParameters - Class in org.apache.flink.runtime.rest.handler.job.rescaling
-
MessageParametersfor polling the status of a rescaling operation. - RescalingStatusMessageParameters() - Constructor for class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusMessageParameters
- RescalingStreamTaskNetworkInput<T> - Class in org.apache.flink.streaming.runtime.io.recovery
-
A
StreamTaskNetworkInputimplementation that demultiplexes virtual channels. - RescalingStreamTaskNetworkInput(CheckpointedInputGate, TypeSerializer<T>, IOManager, StatusWatermarkValve, int, InflightDataRescalingDescriptor, Function<Integer, StreamPartitioner<?>>, TaskInfo, StreamTask.CanEmitBatchOfRecordsChecker) - Constructor for class org.apache.flink.streaming.runtime.io.recovery.RescalingStreamTaskNetworkInput
- RescalingTriggerHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingTriggerHandler
- RescalingTriggerHeaders - Class in org.apache.flink.runtime.rest.handler.job.rescaling
-
Message headers for triggering the rescaling of a job.
- RescalingTriggerMessageParameters - Class in org.apache.flink.runtime.rest.handler.job.rescaling
-
MessageParametersfor triggering the rescaling of a job. - RescalingTriggerMessageParameters() - Constructor for class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerMessageParameters
- reserve(ResourceProfile) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceBudgetManager
- ReservedSlots - Class in org.apache.flink.runtime.scheduler.adaptive.allocator
-
Container for the set of reserved slots for
ExecutionVertexID. - reserveFreeSlot(AllocationID) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotPool
-
Reserves the free slot specified by the given allocationId.
- reserveFreeSlot(AllocationID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultAllocatedSlotPool
- reserveFreeSlot(AllocationID, ResourceProfile) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPool
-
Reserves the free slot identified by the given allocationId and maps it to the given requiredSlotProfile.
- reserveFreeSlot(AllocationID, ResourceProfile) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultDeclarativeSlotPool
- reserveMemory(Object, long) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Reserves a memory chunk of a certain size for an owner from this memory manager.
- reserveSegments(int) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
Reserves the target number of segments to this pool.
- reserveSegments(int) - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
- reserveSlot(AllocationID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultFreeSlotTracker
- reserveSlot(AllocationID) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.FreeSlotTracker
-
Reserve free slot when it is used.
- reserveSlot(AllocationID, ResourceProfile) - Method in interface org.apache.flink.runtime.scheduler.adaptive.allocator.ReserveSlotFunction
-
Reserves the slot identified by the given allocation ID for the given resource profile.
- ReserveSlotFunction - Interface in org.apache.flink.runtime.scheduler.adaptive.allocator
-
A function for reserving slots.
- reset() - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
-
This method is called by the checkpoint coordinator to reset the hook when execution is restarted in the absence of any checkpoint state.
- reset() - Method in class org.apache.flink.runtime.io.disk.SimpleCollectingOutputView
- reset() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
- reset() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
- reset() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
- reset() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.HashBucketIterator
- reset() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
- reset() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
- reset() - Method in class org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
- reset() - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
- reset() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
- reset() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
- reset() - Method in interface org.apache.flink.runtime.operators.ResettableDriver
- reset() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
Resets the sort buffer back to the state where it is empty.
- reset() - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Resets the sort buffer back to the state where it is empty.
- reset() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
Resets the sort buffer back to the state where it is empty.
- reset() - Method in class org.apache.flink.runtime.operators.util.BloomFilter
- reset() - Method in class org.apache.flink.runtime.state.BoundedInputStream
- reset() - Method in class org.apache.flink.runtime.state.filesystem.FsSegmentDataInputStream
- reset() - Method in class org.apache.flink.runtime.util.ForwardingInputStream
- reset() - Method in interface org.apache.flink.runtime.util.ResettableIterator
-
Resets the iterator.
- reset() - Method in interface org.apache.flink.runtime.util.ResettableMutableObjectIterator
-
Resets the iterator.
- reset() - Method in class org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
-
Clear the whole buffer and discard all results.
- reset(Collection<MasterTriggerRestoreHook<?>>, Logger) - Static method in class org.apache.flink.runtime.checkpoint.hooks.MasterHooks
-
Resets the master hooks.
- reset(SequenceNumber, SequenceNumber, long) - Method in interface org.apache.flink.runtime.state.changelog.StateChangelogWriter
-
Reset the state the given state changes.
- resetAlignment() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointBarrierHandler
- resetAllInputs() - Method in class org.apache.flink.runtime.operators.BatchTask
- resetAvailable() - Method in class org.apache.flink.runtime.io.AvailabilityProvider.AvailabilityHelper
-
Resets the constant completed
AvailabilityProvider.AVAILABLEas the current state. - resetContextEnvironment() - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
- resetEndOfSuperstep() - Method in class org.apache.flink.runtime.iterative.task.SyncEventHandler
- resetForNewExecution() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
Archives the current Execution and creates a new Execution for this vertex.
- resetForNewExecution() - Method in class org.apache.flink.runtime.executiongraph.SpeculativeExecutionVertex
- resetForNewExecution(ExecutionVertexID) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.AdaptiveBatchScheduler
- resetForNewExecution(ExecutionVertexID) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DefaultSpeculativeExecutionHandler
- resetForNewExecution(ExecutionVertexID) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DummySpeculativeExecutionHandler
- resetForNewExecution(ExecutionVertexID) - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.SpeculativeExecutionHandler
-
Resets the state of the component for a new execution of a specific execution vertex.
- resetForNewExecution(ExecutionVertexID) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- resetForNewExecutions(Collection<ExecutionVertexID>) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.AdaptiveBatchScheduler
- resetForNewExecutions(Collection<ExecutionVertexID>) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- resetOverflowBuckets() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
resets overflow bucket counters and returns freed memory and should only be used for resizing
- resetPartitionInfo(int) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.AllToAllBlockingResultInfo
- resetPartitionInfo(int) - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.BlockingResultInfo
-
Reset the information of the result partition.
- resetRecordCounter() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
sets record counter to zero and should only be used on compaction partition
- resetRWViews() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
resets read and write views and should only be used on compaction partition
- resetSplitState() - Method in interface org.apache.flink.streaming.api.functions.source.TimestampedInputSplit
-
Sets the state of the split to
null. - ResettableDriver<S extends org.apache.flink.api.common.functions.Function,OT> - Interface in org.apache.flink.runtime.operators
-
This interface marks a
Driveras resettable, meaning that will reset part of their internal state but otherwise reuse existing data structures. - resettableInputs - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The resettable inputs in the case where no temp barrier is needed.
- ResettableIterator<E> - Interface in org.apache.flink.runtime.util
-
The resettable iterator is a specialization of the iterator, allowing to reset the iterator and re-retrieve elements.
- ResettableMutableObjectIterator<E> - Interface in org.apache.flink.runtime.util
-
The resettable iterator is a specialization of the iterator, allowing to reset the iterator and re-retrieve elements.
- resetToCheckpoint(long, byte[]) - Method in interface org.apache.flink.runtime.checkpoint.OperatorCoordinatorCheckpointContext
-
Resets the coordinator to the checkpoint with the given state.
- resetToCheckpoint(long, byte[]) - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator
-
Resets the coordinator to the given checkpoint.
- resetToCheckpoint(long, byte[]) - Method in class org.apache.flink.runtime.operators.coordination.OperatorCoordinatorHolder
- resetToCheckpoint(long, byte[]) - Method in class org.apache.flink.runtime.operators.coordination.RecreateOnResetOperatorCoordinator
- resetToCheckpoint(long, byte[]) - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinator
- resetToCheckpoint(long, byte[]) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
- resetToUnAvailable() - Method in class org.apache.flink.streaming.runtime.io.MultipleFuturesAvailabilityHelper
- resetUnavailable() - Method in class org.apache.flink.runtime.io.AvailabilityProvider.AvailabilityHelper
-
Judges to reset the current available state as unavailable.
- resetVerticesInRecovering(Set<ExecutionVertexID>) - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.BatchJobRecoveryContext
-
Resets vertices specified by their IDs during recovery process.
- resizeForBulkLoad(int) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
- resizeQueueArray(int, int) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
- resolve(X) - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Resolves this parameter for the given value.
- resolveCheckpoint(String) - Method in interface org.apache.flink.runtime.state.CheckpointStorage
-
Resolves the given pointer to a checkpoint/savepoint into a checkpoint location.
- resolveCheckpoint(String) - Method in interface org.apache.flink.runtime.state.CheckpointStorageCoordinatorView
-
Resolves the given pointer to a checkpoint/savepoint into a checkpoint location.
- resolveCheckpoint(String) - Method in class org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
-
Deprecated.
- resolveCheckpoint(String) - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorageAccess
- resolveCheckpoint(String) - Method in class org.apache.flink.runtime.state.storage.FileSystemCheckpointStorage
- resolveCheckpoint(String) - Method in class org.apache.flink.runtime.state.storage.JobManagerCheckpointStorage
- resolveCheckpoint(String) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionCheckpointStorage
- resolveCheckpointPointer(String) - Static method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorageAccess
-
Takes the given string (representing a pointer to a checkpoint) and resolves it to a file status for the checkpoint's metadata file.
- resolveCheckpointStorageLocation(long, CheckpointStorageLocationReference) - Method in interface org.apache.flink.runtime.state.CheckpointStorageWorkerView
-
Resolves a storage location reference into a CheckpointStreamFactory.
- resolveCheckpointStorageLocation(long, CheckpointStorageLocationReference) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageAccess
- resolveCheckpointStorageLocation(long, CheckpointStorageLocationReference) - Method in class org.apache.flink.runtime.state.filesystem.FsMergingCheckpointStorageAccess
- resolveCheckpointStorageLocation(long, CheckpointStorageLocationReference) - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorageAccess
- resolveFromString(String) - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Resolves this parameter for the given string value representation.
- resolveJobId(JobID) - Method in class org.apache.flink.runtime.rest.messages.JobCancellationMessageParameters
- resolveJobId(JobID) - Method in class org.apache.flink.runtime.rest.messages.JobClientHeartbeatParameters
- resolveParametersAndCreate(R, M, Map<String, String>, Map<String, List<String>>, Collection<File>) - Static method in class org.apache.flink.runtime.rest.handler.HandlerRequest
-
Creates a new
HandlerRequestafter resolving the givenMessageParametersagainst the given query/path parameter maps. - resolveTerminationMode(TerminationModeQueryParameter.TerminationMode) - Method in class org.apache.flink.runtime.rest.messages.JobCancellationMessageParameters
- resolveUrl(String, MessageParameters) - Static method in class org.apache.flink.runtime.rest.messages.MessageParameters
-
Resolves the given URL (e.g "jobs/:jobid") using the given path/query parameters.
- resource() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationResult
- resource() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
- resource() - Method in interface org.apache.flink.runtime.rest.messages.queue.AsynchronouslyCreatedResource
-
Returns the resource if it is available,
nullotherwise. - RESOURCE_MANAGER_NAME - Static variable in class org.apache.flink.runtime.resourcemanager.ResourceManager
- RESOURCE_MANAGER_NODE - Static variable in class org.apache.flink.runtime.util.ZooKeeperUtils
-
The prefix of the resource manager node.
- ResourceAllocationResult - Class in org.apache.flink.runtime.resourcemanager.slotmanager
-
Contains the results of the
ResourceAllocationStrategy. - ResourceAllocationResult.Builder - Class in org.apache.flink.runtime.resourcemanager.slotmanager
- ResourceAllocationStrategy - Interface in org.apache.flink.runtime.resourcemanager.slotmanager
-
Strategy for allocating slots and task managers to fulfill the unfulfilled requirements.
- ResourceAllocator - Interface in org.apache.flink.runtime.resourcemanager.slotmanager
-
Resource related actions which the
SlotManagercan perform. - ResourceBudgetManager - Class in org.apache.flink.runtime.clusterframework.types
-
Budget manager for
ResourceProfile. - ResourceBudgetManager(ResourceProfile) - Constructor for class org.apache.flink.runtime.clusterframework.types.ResourceBudgetManager
- ResourceCleaner - Interface in org.apache.flink.runtime.dispatcher.cleanup
-
ResourceCleanerexecutes instances on the givenJobID. - ResourceCleanerFactory - Interface in org.apache.flink.runtime.dispatcher.cleanup
-
ResourceCleanerFactoryprovides methods to createResourceCleanerfor local and global cleanup. - ResourceCounter - Class in org.apache.flink.runtime.util
-
Counter for
ResourceProfiles. - ResourceDeclaration - Class in org.apache.flink.runtime.resourcemanager.slotmanager
-
ResourceDeclaration for
ResourceAllocator. - ResourceDeclaration(WorkerResourceSpec, int, Collection<InstanceID>) - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceDeclaration
- ResourceEventHandler<WorkerType extends ResourceIDRetrievable> - Interface in org.apache.flink.runtime.resourcemanager.active
-
Callback interfaces for handling resource events from external resource managers.
- ResourceEventListener - Interface in org.apache.flink.runtime.resourcemanager.slotmanager
-
Listener for resource events of
SlotManager. - resourceHandle() - Method in interface org.apache.flink.runtime.memory.SharedResources.ResourceAndSize
- ResourceID - Class in org.apache.flink.runtime.clusterframework.types
-
Class for Resource Ids identifying Flink's distributed components.
- ResourceID(String) - Constructor for class org.apache.flink.runtime.clusterframework.types.ResourceID
- ResourceID(String, String) - Constructor for class org.apache.flink.runtime.clusterframework.types.ResourceID
- ResourceIDDeserializer - Class in org.apache.flink.runtime.rest.messages.json
-
Json deserializer for
ResourceID. - ResourceIDDeserializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.ResourceIDDeserializer
- ResourceIDRetrievable - Interface in org.apache.flink.runtime.clusterframework.types
-
An interface to retrieve the ResourceID of an object.
- ResourceIDSerializer - Class in org.apache.flink.runtime.rest.messages.json
-
Json serializer for
InstanceID. - ResourceIDSerializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.ResourceIDSerializer
- ResourceManager<WorkerType extends ResourceIDRetrievable> - Class in org.apache.flink.runtime.resourcemanager
-
ResourceManager implementation.
- ResourceManager(RpcService, UUID, ResourceID, HeartbeatServices, DelegationTokenManager, SlotManager, ResourceManagerPartitionTrackerFactory, BlocklistHandler.Factory, JobLeaderIdService, ClusterInformation, FatalErrorHandler, ResourceManagerMetricGroup, Duration, Executor) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceManager
- ResourceManagerAddress - Class in org.apache.flink.runtime.jobmaster
-
Current address and fencing token of the leading ResourceManager.
- ResourceManagerAddress(String, ResourceManagerId) - Constructor for class org.apache.flink.runtime.jobmaster.ResourceManagerAddress
- ResourceManagerDriver<WorkerType extends ResourceIDRetrievable> - Interface in org.apache.flink.runtime.resourcemanager.active
-
A
ResourceManagerDriveris responsible for requesting and releasing resources from/to a particular external resource manager. - ResourceManagerException - Exception in org.apache.flink.runtime.resourcemanager.exceptions
-
Base class for
ResourceManagerexceptions. - ResourceManagerException(String) - Constructor for exception org.apache.flink.runtime.resourcemanager.exceptions.ResourceManagerException
- ResourceManagerException(String, Throwable) - Constructor for exception org.apache.flink.runtime.resourcemanager.exceptions.ResourceManagerException
- ResourceManagerException(Throwable) - Constructor for exception org.apache.flink.runtime.resourcemanager.exceptions.ResourceManagerException
- ResourceManagerFactory<T extends ResourceIDRetrievable> - Class in org.apache.flink.runtime.resourcemanager
-
ResourceManagerfactory. - ResourceManagerFactory() - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceManagerFactory
- ResourceManagerGateway - Interface in org.apache.flink.runtime.resourcemanager
-
The
ResourceManager's RPC gateway interface. - ResourceManagerId - Class in org.apache.flink.runtime.resourcemanager
-
Fencing token for the
ResourceManager. - resourceManagerMetricGroup - Variable in class org.apache.flink.runtime.resourcemanager.ResourceManager
- ResourceManagerMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
Metric group which is used by the
ResourceManagerto register metrics. - ResourceManagerPartitionTracker - Interface in org.apache.flink.runtime.io.network.partition
-
Utility for tracking and releasing partitions on the ResourceManager.
- ResourceManagerPartitionTrackerFactory - Interface in org.apache.flink.runtime.io.network.partition
-
Factory for
ResourceManagerPartitionTracker. - ResourceManagerPartitionTrackerImpl - Class in org.apache.flink.runtime.io.network.partition
-
Default
ResourceManagerPartitionTrackerimplementation. - ResourceManagerPartitionTrackerImpl(TaskExecutorClusterPartitionReleaser) - Constructor for class org.apache.flink.runtime.io.network.partition.ResourceManagerPartitionTrackerImpl
- ResourceManagerProcessContext - Class in org.apache.flink.runtime.resourcemanager
-
This class contains information and services needed for creating a
ResourceManager, which do not change during the lifetime of the process and can be reused between multiple resource manager instances in the process. - ResourceManagerProcessContext(Configuration, ResourceID, ResourceManagerRuntimeServicesConfiguration, RpcService, HighAvailabilityServices, HeartbeatServices, DelegationTokenManager, FatalErrorHandler, ClusterInformation, String, MetricRegistry, String, Executor) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceManagerProcessContext
- ResourceManagerRuntimeServices - Class in org.apache.flink.runtime.resourcemanager
-
Container class for the
ResourceManagerservices. - ResourceManagerRuntimeServices(SlotManager, JobLeaderIdService) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
- ResourceManagerRuntimeServicesConfiguration - Class in org.apache.flink.runtime.resourcemanager
-
Configuration class for the
ResourceManagerRuntimeServicesclass. - ResourceManagerRuntimeServicesConfiguration(Duration, SlotManagerConfiguration) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
- ResourceManagerService - Interface in org.apache.flink.runtime.resourcemanager
-
Service that maintains lifecycle of
ResourceManager. - ResourceManagerServiceImpl - Class in org.apache.flink.runtime.resourcemanager
-
Default implementation of
ResourceManagerService. - ResourceManagerUtils - Class in org.apache.flink.runtime.util
-
Common utils for ResourceManager.
- ResourceManagerUtils() - Constructor for class org.apache.flink.runtime.util.ResourceManagerUtils
- ResourceOverview - Class in org.apache.flink.runtime.resourcemanager
-
Class containing information about the available cluster resources.
- ResourceOverview(int, int, int, int, int, ResourceProfile, ResourceProfile) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceOverview
- ResourceProfile - Class in org.apache.flink.runtime.clusterframework.types
-
Describe the immutable resource profile of the slot, either when requiring or offering it.
- ResourceProfile.Builder - Class in org.apache.flink.runtime.clusterframework.types
-
Builder for the
ResourceProfile. - ResourceProfileInfo - Class in org.apache.flink.runtime.rest.messages
-
Contains information of a
ResourceProfile. - ResourceProfileInfo(double, int, int, int, int, Map<String, Double>) - Constructor for class org.apache.flink.runtime.rest.messages.ResourceProfileInfo
- ResourceReconcileResult - Class in org.apache.flink.runtime.resourcemanager.slotmanager
-
Contains the results of the
ResourceAllocationStrategy. - ResourceReconcileResult(List<PendingTaskManager>, List<PendingTaskManager>, List<TaskManagerInfo>) - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceReconcileResult
- ResourceReconcileResult.Builder - Class in org.apache.flink.runtime.resourcemanager.slotmanager
- ResourceRequirement - Class in org.apache.flink.runtime.slots
-
Represents the number of required resources for a specific
ResourceProfile. - ResourceRequirements - Class in org.apache.flink.runtime.slots
-
Represents the total resource requirements for a job, and the information required to connect to the corresponding job master.
- resourceSpecFromConfigForLocalExecution(Configuration) - Static method in class org.apache.flink.runtime.taskexecutor.TaskExecutorResourceUtils
- ResourceTracker - Interface in org.apache.flink.runtime.resourcemanager.slotmanager
-
Tracks for each job how many resource are required/acquired.
- ResourceVersion<R> - Interface in org.apache.flink.runtime.persistence
-
Resource version for specific state handle on the underlying storage.
- respondAsLeader(ChannelHandlerContext, RoutedRequest, T) - Method in class org.apache.flink.runtime.rest.handler.AbstractHandler
- respondAsLeader(ChannelHandlerContext, RoutedRequest, T) - Method in class org.apache.flink.runtime.rest.handler.LeaderRetrievalHandler
- respondAsLeader(ChannelHandlerContext, RoutedRequest, T) - Method in class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
- respondToRequest(ChannelHandlerContext, HttpRequest, HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.cluster.AbstractJobManagerFileHandler
- respondToRequest(ChannelHandlerContext, HttpRequest, HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.AbstractTaskManagerFileHandler
- respondToRequest(ChannelHandlerContext, HttpRequest, HandlerRequest<R>, T) - Method in class org.apache.flink.runtime.rest.handler.AbstractHandler
-
Respond to the given
HandlerRequest. - respondToRequest(ChannelHandlerContext, HttpRequest, HandlerRequest<R>, T) - Method in class org.apache.flink.runtime.rest.handler.AbstractRestHandler
- ResponseBody - Interface in org.apache.flink.runtime.rest.messages
-
Marker interface for all responses of the REST API.
- responseHeaders - Variable in class org.apache.flink.runtime.rest.handler.LeaderRetrievalHandler
- responseHeaders - Variable in class org.apache.flink.runtime.rest.RestServerEndpoint
- REST_CONTENT_TYPE - Static variable in enum org.apache.flink.runtime.rest.util.RestConstants
- RestAPIVersion<T extends RestAPIVersion<T>> - Interface in org.apache.flink.runtime.rest.versioning
-
Interface for all versions of the REST API.
- restartable(Execution, Throwable, long, CompletableFuture<Map<String, String>>, Set<ExecutionVertexID>, long, boolean, boolean) - Static method in class org.apache.flink.runtime.executiongraph.failover.FailureHandlingResult
-
Creates a result of a set of tasks to restart to recover from the failure.
- RestartAllFailoverStrategy - Class in org.apache.flink.runtime.executiongraph.failover
-
A failover strategy that proposes to restart all vertices when a vertex fails.
- RestartAllFailoverStrategy(SchedulingTopology) - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartAllFailoverStrategy
- RestartAllFailoverStrategy.Factory - Class in org.apache.flink.runtime.executiongraph.failover
-
The factory to instantiate
RestartAllFailoverStrategy. - RestartBackoffTimeStrategy - Interface in org.apache.flink.runtime.executiongraph.failover
-
Strategy to decide whether to restart failed tasks and the delay to do the restarting.
- RestartBackoffTimeStrategy.Factory - Interface in org.apache.flink.runtime.executiongraph.failover
-
The factory to instantiate
RestartBackoffTimeStrategy. - RestartBackoffTimeStrategyFactoryLoader - Class in org.apache.flink.runtime.executiongraph.failover
-
A utility class to load
RestartBackoffTimeStrategy.Factoryfrom the configuration. - restartOrFail(FailureResult, T, StateWithExecutionGraph) - Static method in class org.apache.flink.runtime.scheduler.adaptive.FailureResultUtil
- RestartPipelinedRegionFailoverStrategy - Class in org.apache.flink.runtime.executiongraph.failover
-
A failover strategy that proposes to restart involved regions when a vertex fails.
- RestartPipelinedRegionFailoverStrategy(SchedulingTopology) - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionFailoverStrategy
-
Creates a new failover strategy to restart pipelined regions that works on the given topology.
- RestartPipelinedRegionFailoverStrategy(SchedulingTopology, ResultPartitionAvailabilityChecker) - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionFailoverStrategy
-
Creates a new failover strategy to restart pipelined regions that works on the given topology.
- RestartPipelinedRegionFailoverStrategy.Factory - Class in org.apache.flink.runtime.executiongraph.failover
-
The factory to instantiate
RestartPipelinedRegionFailoverStrategy. - restartTasks(Set<ExecutionVertexID>) - Method in class org.apache.flink.runtime.scheduler.strategy.PipelinedRegionSchedulingStrategy
- restartTasks(Set<ExecutionVertexID>) - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingStrategy
-
Called whenever vertices need to be restarted (due to task failure).
- restartTasks(Set<ExecutionVertexID>) - Method in class org.apache.flink.runtime.scheduler.strategy.VertexwiseSchedulingStrategy
- RestClient - Class in org.apache.flink.runtime.rest
-
This client is the counter-part to the
RestServerEndpoint. - RestClient(Configuration, Executor) - Constructor for class org.apache.flink.runtime.rest.RestClient
- RestClient(Configuration, Executor, String, int) - Constructor for class org.apache.flink.runtime.rest.RestClient
- RestClientConfiguration - Class in org.apache.flink.runtime.rest
-
A configuration object for
RestClients. - RestClientException - Exception in org.apache.flink.runtime.rest.util
-
An exception that is thrown if the failure of a REST operation was detected on the client.
- RestClientException(String, Throwable, HttpResponseStatus) - Constructor for exception org.apache.flink.runtime.rest.util.RestClientException
- RestClientException(String, HttpResponseStatus) - Constructor for exception org.apache.flink.runtime.rest.util.RestClientException
- restConfiguration - Variable in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
- RestConstants - Enum in org.apache.flink.runtime.rest.util
-
This class contains constants to be used by rest components.
- RestEndpointFactory<T extends RestfulGateway> - Interface in org.apache.flink.runtime.rest
-
WebMonitorEndpointfactory. - RestfulGateway - Interface in org.apache.flink.runtime.webmonitor
-
Gateway for restful endpoints.
- RestHandlerConfiguration - Class in org.apache.flink.runtime.rest.handler
-
Configuration object containing values for the rest handler configuration.
- RestHandlerConfiguration(long, int, Duration, int, Duration, File, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
- RestHandlerException - Exception in org.apache.flink.runtime.rest.handler
-
An exception that is thrown if the failure of a REST operation was detected by a handler.
- RestHandlerException(String, HttpResponseStatus) - Constructor for exception org.apache.flink.runtime.rest.handler.RestHandlerException
- RestHandlerException(String, HttpResponseStatus, Throwable) - Constructor for exception org.apache.flink.runtime.rest.handler.RestHandlerException
- RestHandlerException(String, HttpResponseStatus, RestHandlerException.LoggingBehavior) - Constructor for exception org.apache.flink.runtime.rest.handler.RestHandlerException
- RestHandlerException.LoggingBehavior - Enum in org.apache.flink.runtime.rest.handler
-
Enum to control logging behavior of RestHandlerExceptions.
- RestHandlerSpecification - Interface in org.apache.flink.runtime.rest.handler
-
Rest handler interface which all rest handler implementation have to implement.
- RestHandlerUrlComparator() - Constructor for class org.apache.flink.runtime.rest.RestServerEndpoint.RestHandlerUrlComparator
- RestMapperUtils - Class in org.apache.flink.runtime.rest.util
-
This class contains utilities for mapping requests and responses to/from JSON.
- RestMapperUtils() - Constructor for class org.apache.flink.runtime.rest.util.RestMapperUtils
- restore() - Method in class org.apache.flink.runtime.checkpoint.filemerging.SubtaskFileMergingManagerRestoreOperation
- restore() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
- restore() - Method in interface org.apache.flink.runtime.jobgraph.tasks.TaskInvokable
-
This method can be called before
TaskInvokable.invoke()to restore an invokable object for the last valid state, if it has it. - restore() - Method in class org.apache.flink.runtime.state.heap.HeapRestoreOperation
- restore() - Method in class org.apache.flink.runtime.state.heap.HeapSavepointRestoreOperation
- restore() - Method in class org.apache.flink.runtime.state.OperatorStateRestoreOperation
- restore() - Method in class org.apache.flink.runtime.state.restore.FullSnapshotRestoreOperation
- restore() - Method in interface org.apache.flink.runtime.state.RestoreOperation
-
Restores state that was previously snapshot-ed from the provided state handles.
- restore() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- restore(List<Tuple2<StreamStateHandle, Long>>, KeyGroupRange, long, long, String, StateHandleID) - Static method in class org.apache.flink.runtime.state.changelog.ChangelogStateHandleStreamImpl
- restore(List<StateChange>, SequenceNumber, SequenceNumber, KeyGroupRange, StateHandleID) - Static method in class org.apache.flink.runtime.state.changelog.inmemory.InMemoryChangelogStateHandle
- restore(List<KeyedStateHandle>, List<ChangelogStateHandle>, KeyGroupRange, long, long, long, StateHandleID) - Static method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl
- restore(UUID, KeyGroupRange, long, List<IncrementalKeyedStateHandle.HandleAndLocalPath>, List<IncrementalKeyedStateHandle.HandleAndLocalPath>, StreamStateHandle, long, StateHandleID) - Static method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
- restore(KeyGroupRangeOffsets, StreamStateHandle, StateHandleID) - Static method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
- RESTORE_ASYNC_COMPACTION_DURATION - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- RESTORE_STATE_DURATION - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- restoreCheckpoint(long, T) - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
-
This method is called by the checkpoint coordinator prior to restoring the state of a checkpoint.
- RESTORED_STATE_SIZE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- RestoredCheckpointStatistics(long, long, boolean, String) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
- RestoredCheckpointStats - Class in org.apache.flink.runtime.checkpoint
-
Statistics for a restored checkpoint.
- restoreFunctionState(StateInitializationContext, Function) - Static method in class org.apache.flink.streaming.util.functions.StreamingFunctionUtils
- restoreInitialCheckpointIfPresent(Set<ExecutionJobVertex>) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Restores the latest checkpointed at the beginning of the job execution.
- restoreLatestCheckpointedStateToAll(Set<ExecutionJobVertex>, boolean) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Restores the latest checkpointed state to all tasks and all coordinators.
- restoreLatestCheckpointedStateToSubtasks(Set<ExecutionJobVertex>) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Restores the latest checkpointed state to a set of subtasks.
- restoreMasterHooks(Map<String, MasterTriggerRestoreHook<?>>, Collection<MasterState>, long, boolean, Logger) - Static method in class org.apache.flink.runtime.checkpoint.hooks.MasterHooks
-
Calls the restore method given checkpoint master hooks and passes the given master state to them where state with a matching name is found.
- RestoreOperation<R> - Interface in org.apache.flink.runtime.state
-
Interface for restore operation.
- restoreSavepoint() - Method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
-
Returns whether to restore from savepoint.
- restoreSavepoint(SavepointRestoreSettings, Map<JobVertexID, ExecutionJobVertex>, ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Restore the state with given savepoint.
- restoreState(List<ShuffleMasterSnapshot>) - Method in interface org.apache.flink.runtime.shuffle.ShuffleMaster
-
Restores the state of the shuffle master from the provided snapshots.
- restoreState(List<T>) - Method in interface org.apache.flink.streaming.api.checkpoint.ListCheckpointed
-
Deprecated.Restores the state of the function or operator to that of a previous checkpoint.
- restoreState(Set<ExecutionVertexID>, boolean) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- restoreState(SimpleVersionedSerializer<SplitT>, byte[]) - Method in class org.apache.flink.runtime.source.coordinator.SplitAssignmentTracker
-
Restore the state of the SplitAssignmentTracker.
- restoreStateHandles - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
- restoreStateHandles - Variable in class org.apache.flink.runtime.state.DefaultOperatorStateBackendBuilder
-
State handles for restore.
- restoreStateHandles(long, FileMergingSnapshotManager.SubtaskKey, Stream<SegmentFileStateHandle>) - Method in interface org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager
-
Restore and re-register the SegmentFileStateHandles into FileMergingSnapshotManager.
- restoreStateHandles(long, FileMergingSnapshotManager.SubtaskKey, Stream<SegmentFileStateHandle>) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
- restoreTimersForKeyGroup(InternalTimersSnapshot<?, ?>, int) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
-
Restore the timers (both processing and event time ones) for a given
keyGroupIdx. - restoreVertices(Set<ExecutionVertexID>) - Method in class org.apache.flink.runtime.scheduler.VertexEndOfDataListener
- RestServerEndpoint - Class in org.apache.flink.runtime.rest
-
An abstract class for netty-based REST server endpoints.
- RestServerEndpoint(Configuration) - Constructor for class org.apache.flink.runtime.rest.RestServerEndpoint
- RestServerEndpoint.RestHandlerUrlComparator - Class in org.apache.flink.runtime.rest
-
Comparator for Rest URLs.
- RestServerEndpoint.RestHandlerUrlComparator.CaseInsensitiveOrderComparator - Class in org.apache.flink.runtime.rest
-
Comparator for Rest URLs.
- RestServerEndpointConfiguration - Class in org.apache.flink.runtime.rest
-
A configuration object for
RestServerEndpoints. - RestService - Interface in org.apache.flink.runtime.rest
-
Rest service interface.
- Result<VID extends VertexID,RID extends ResultID,V extends Vertex<VID,RID,V,R>,R extends Result<VID,RID,V,R>> - Interface in org.apache.flink.runtime.topology
- Result(SlotRequestId, PhysicalSlot) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlotRequest.Result
- resultFuture - Variable in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator.PendingStatsRequest
-
The future with the final result.
- resultHandler - Variable in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
Handler for completed requests
- ResultID - Interface in org.apache.flink.runtime.topology
-
ID of a
Result. - ResultPartition - Class in org.apache.flink.runtime.io.network.partition
-
A result partition for data produced by a single task.
- ResultPartition(String, int, ResultPartitionID, ResultPartitionType, int, int, ResultPartitionManager, BufferCompressor, SupplierWithException<BufferPool, IOException>) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultPartition
- ResultPartitionAvailabilityChecker - Interface in org.apache.flink.runtime.executiongraph.failover
-
This checker helps to query result partition availability.
- resultPartitionBytes - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
- resultPartitionBytes - Variable in class org.apache.flink.runtime.io.network.partition.ResultPartition
- ResultPartitionBytes - Class in org.apache.flink.runtime.executiongraph
-
This class represents a snapshot of the result partition bytes metrics.
- ResultPartitionBytes(long[]) - Constructor for class org.apache.flink.runtime.executiongraph.ResultPartitionBytes
- ResultPartitionBytesCounter - Class in org.apache.flink.runtime.io.network.metrics
-
This counter will count the data size of a partition.
- ResultPartitionBytesCounter(int) - Constructor for class org.apache.flink.runtime.io.network.metrics.ResultPartitionBytesCounter
- ResultPartitionDeploymentDescriptor - Class in org.apache.flink.runtime.deployment
-
Deployment descriptor for a result partition.
- ResultPartitionDeploymentDescriptor(PartitionDescriptor, ShuffleDescriptor, int) - Constructor for class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
- ResultPartitionFactory - Class in org.apache.flink.runtime.io.network.partition
-
Factory for
ResultPartitionto use inNettyShuffleEnvironment. - ResultPartitionFactory(ResultPartitionManager, FileChannelManager, BufferPoolFactory, BatchShuffleReadBufferPool, ScheduledExecutorService, BoundedBlockingSubpartitionType, int, int, int, boolean, NettyShuffleEnvironmentOptions.CompressionCodec, int, int, int, boolean, int, TieredResultPartitionFactory) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultPartitionFactory
- ResultPartitionID - Class in org.apache.flink.runtime.io.network.partition
-
Runtime identifier of a produced
IntermediateResultPartition. - ResultPartitionID() - Constructor for class org.apache.flink.runtime.io.network.partition.ResultPartitionID
- ResultPartitionID(byte[]) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultPartitionID
- ResultPartitionID(IntermediateResultPartitionID, ExecutionAttemptID) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultPartitionID
- ResultPartitionManager - Class in org.apache.flink.runtime.io.network.partition
-
The result partition manager keeps track of all currently produced/consumed partitions of a task manager.
- ResultPartitionManager() - Constructor for class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
- ResultPartitionManager(int, ScheduledExecutor) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
- ResultPartitionMetrics - Class in org.apache.flink.runtime.io.network.metrics
-
Collects metrics of a result partition.
- ResultPartitionProvider - Interface in org.apache.flink.runtime.io.network.partition
-
Interface for creating result partitions.
- ResultPartitionState - Enum in org.apache.flink.runtime.scheduler.strategy
-
State of a
SchedulingResultPartition. - ResultPartitionType - Enum in org.apache.flink.runtime.io.network.partition
-
Type of a result partition.
- ResultPartitionWriter - Interface in org.apache.flink.runtime.io.network.api.writer
-
A record-oriented runtime result writer API for producing results.
- ResultSubpartition - Class in org.apache.flink.runtime.io.network.partition
-
A single subpartition of a
ResultPartitioninstance. - ResultSubpartition(int, ResultPartition) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultSubpartition
- ResultSubpartition.BufferAndBacklog - Class in org.apache.flink.runtime.io.network.partition
-
A combination of a
Bufferand the backlog length indicating how many non-event buffers are available in the subpartition. - ResultSubpartitionIndexSet - Class in org.apache.flink.runtime.io.network.partition
-
A collection of subpartition indexes.
- ResultSubpartitionIndexSet(int) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultSubpartitionIndexSet
- ResultSubpartitionIndexSet(int, int) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultSubpartitionIndexSet
- ResultSubpartitionIndexSet(IndexRange) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultSubpartitionIndexSet
- ResultSubpartitionInfo - Class in org.apache.flink.runtime.checkpoint.channel
-
Identifies
ResultSubpartitionin a given subtask. - ResultSubpartitionInfo(int, int) - Constructor for class org.apache.flink.runtime.checkpoint.channel.ResultSubpartitionInfo
- ResultSubpartitionStateHandle - Class in org.apache.flink.runtime.state
-
Handleto aResultSubpartitionstate. - ResultSubpartitionStateHandle(int, ResultSubpartitionInfo, StreamStateHandle, List<Long>, long) - Constructor for class org.apache.flink.runtime.state.ResultSubpartitionStateHandle
- ResultSubpartitionStateHandle(int, ResultSubpartitionInfo, StreamStateHandle, AbstractChannelStateHandle.StateContentMetaInfo) - Constructor for class org.apache.flink.runtime.state.ResultSubpartitionStateHandle
- ResultSubpartitionStateHandle(ResultSubpartitionInfo, StreamStateHandle, List<Long>) - Constructor for class org.apache.flink.runtime.state.ResultSubpartitionStateHandle
- ResultSubpartitionView - Interface in org.apache.flink.runtime.io.network.partition
-
A view to consume a
ResultSubpartitioninstance. - ResultSubpartitionView.AvailabilityWithBacklog - Class in org.apache.flink.runtime.io.network.partition
-
Availability of the
ResultSubpartitionViewand the backlog in the correspondingResultSubpartition. - resume() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.MailboxDefaultAction.Suspension
-
Resume execution of the default action.
- resumeConsumption() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
Resumes data consumption after an exactly once checkpoint.
- resumeConsumption() - Method in class org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionDirectTransferReader
- resumeConsumption() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
After sending a
CheckpointBarrierof exactly-once mode, the upstream will be blocked and become unavailable. - resumeConsumption() - Method in class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
- resumeConsumption() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RecoveredInputChannel
- resumeConsumption() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- resumeConsumption() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.TieredStorageResultSubpartitionView
- resumeConsumption() - Method in class org.apache.flink.runtime.io.network.partition.NoOpResultSubpartitionView
- resumeConsumption() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartitionView
- resumeConsumption() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
- resumeConsumption() - Method in class org.apache.flink.runtime.io.network.partition.UnionResultSubpartitionView
- resumeConsumption(InputChannelInfo) - Method in interface org.apache.flink.runtime.io.network.partition.consumer.CheckpointableInput
- resumeConsumption(InputChannelInfo) - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
- resumeConsumption(InputChannelInfo) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- resumeConsumption(InputChannelInfo) - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
- resumeConsumption(InputChannelInfo) - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
- resumeConsumption(InputChannelInfo) - Method in class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
- resumeConsumption(RemoteInputChannel) - Method in class org.apache.flink.runtime.io.network.netty.NettyPartitionRequestClient
- resumeConsumption(RemoteInputChannel) - Method in interface org.apache.flink.runtime.io.network.PartitionRequestClient
-
Requests to resume data consumption from one remote input channel.
- resumeMeasurement() - Method in class org.apache.flink.runtime.throughput.ThroughputCalculator
-
Mark when the time should be included to the throughput calculation.
- retain() - Method in class org.apache.flink.runtime.asyncprocessing.ReferenceCounted
- retain() - Method in class org.apache.flink.runtime.rest.handler.router.RoutedRequest
- retain(int) - Method in class org.apache.flink.runtime.rest.handler.router.RoutedRequest
- RETAIN_ON_CANCELLATION - org.apache.flink.runtime.checkpoint.CheckpointRetentionPolicy
-
Checkpoints should be retained on cancellation and failure.
- RETAIN_ON_FAILURE - org.apache.flink.runtime.checkpoint.CheckpointRetentionPolicy
-
Checkpoints should be retained on failure, but not on cancellation.
- retainAll(Collection<?>) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- retainBuffer() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Retains this buffer for further use, increasing the reference counter by 1.
- retainBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- retainBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- retainBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- retainBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- retainJobs(Collection<JobID>, Executor) - Method in class org.apache.flink.runtime.blob.BlobServer
- retainLocalStateForAllocations(Set<AllocationID>) - Method in class org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager
-
Retains the given set of allocations.
- retireWindow(W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
-
Removes the given window from the set of in-flight windows.
- RETRIED_COMMITTABLES - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- RetrievableStateHandle<T extends Serializable> - Interface in org.apache.flink.runtime.state
-
Handle to state that can be read back again via
RetrievableStateHandle.retrieveState(). - RetrievableStateStorageHelper<T extends Serializable> - Interface in org.apache.flink.runtime.persistence
-
State storage helper which is used by
StateHandleStoreto persist state before the state handle is written to the underlying system. - RetrievableStreamStateHandle<T extends Serializable> - Class in org.apache.flink.runtime.state
-
Wrapper around a
StreamStateHandleto make the referenced state object retrievable trough a simple get call. - RetrievableStreamStateHandle(Path, long) - Constructor for class org.apache.flink.runtime.state.RetrievableStreamStateHandle
- RetrievableStreamStateHandle(StreamStateHandle) - Constructor for class org.apache.flink.runtime.state.RetrievableStreamStateHandle
- RETRIEVE_HOST_NAME - org.apache.flink.runtime.taskmanager.TaskManagerLocation.ResolutionMode
- retrieveCompletedCheckpoints(StateHandleStore<CompletedCheckpoint, R>, CheckpointStoreUtil) - Static method in class org.apache.flink.runtime.checkpoint.DefaultCompletedCheckpointStoreUtils
-
Fetch all
completed checkpointsfrom anexternal store. - retrieveJobGraph(Configuration) - Method in class org.apache.flink.runtime.entrypoint.component.FileJobGraphRetriever
- retrieveJobGraph(Configuration) - Method in interface org.apache.flink.runtime.entrypoint.component.JobGraphRetriever
-
Retrieve the
JobGraph. - retrieveLeaderInformation(LeaderRetrievalService, Duration) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
-
Retrieves the leader pekko url and the current leader session ID.
- retrieveLocalState(long) - Method in class org.apache.flink.runtime.state.NoOpTaskLocalStateStoreImpl
- retrieveLocalState(long) - Method in interface org.apache.flink.runtime.state.TaskLocalStateStore
-
Returns the local state that is stored under the given checkpoint id or null if nothing was stored under the id.
- retrieveLocalState(long) - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
- retrievePayload(ResourceID) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatListener
-
Retrieves the payload value for the next heartbeat message.
- retrieveService(String) - Method in class org.apache.flink.runtime.webmonitor.retriever.impl.RpcMetricQueryServiceRetriever
- retrieveService(String) - Method in interface org.apache.flink.runtime.webmonitor.retriever.MetricQueryServiceRetriever
-
Retrieves for the given query service address a
MetricQueryServiceGateway. - retrieveState() - Method in interface org.apache.flink.runtime.state.RetrievableStateHandle
-
Retrieves the object that was previously written to state.
- retrieveState() - Method in class org.apache.flink.runtime.state.RetrievableStreamStateHandle
- retriggerPartitionRequest(IntermediateResultPartitionID, InputChannelInfo) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
Retriggers a partition request.
- RETRY - org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestState
- RetryingRegistration<F extends Serializable,G extends org.apache.flink.runtime.rpc.RpcGateway,S extends RegistrationResponse.Success,R extends RegistrationResponse.Rejection> - Class in org.apache.flink.runtime.registration
-
This utility class implements the basis of registering one component at another component, for example registering the TaskExecutor at the ResourceManager.
- RetryingRegistration(Logger, RpcService, String, Class<G>, String, F, RetryingRegistrationConfiguration) - Constructor for class org.apache.flink.runtime.registration.RetryingRegistration
- RetryingRegistrationConfiguration - Class in org.apache.flink.runtime.registration
-
Configuration for the cluster components.
- RetryingRegistrationConfiguration(long, long, long, long) - Constructor for class org.apache.flink.runtime.registration.RetryingRegistrationConfiguration
- retryLater() - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
- returnLogicalSlot(LogicalSlot) - Method in interface org.apache.flink.runtime.jobmaster.SlotOwner
-
Return the given slot to the slot owner.
- returnPhysicalFileForNextReuse(FileMergingSnapshotManager.SubtaskKey, long, PhysicalFile) - Method in class org.apache.flink.runtime.checkpoint.filemerging.AcrossCheckpointFileMergingSnapshotManager
- returnPhysicalFileForNextReuse(FileMergingSnapshotManager.SubtaskKey, long, PhysicalFile) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
-
Try to return an existing physical file to the manager for next reuse.
- returnPhysicalFileForNextReuse(FileMergingSnapshotManager.SubtaskKey, long, PhysicalFile) - Method in class org.apache.flink.runtime.checkpoint.filemerging.WithinCheckpointFileMergingSnapshotManager
- returns(Class<T>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Adds a type information hint about the return type of this operator.
- returns(TypeHint<T>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Adds a type information hint about the return type of this operator.
- returns(TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Adds a type information hint about the return type of this operator.
- reuseBytesInputCounter(Counter) - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- reuseBytesInputMetricsForTask() - Method in class org.apache.flink.runtime.metrics.groups.InternalOperatorIOMetricGroup
-
Causes the containing task to use this operators input bytes counter.
- reuseBytesOutputCounter(Counter) - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- reuseBytesOutputMetricsForTask() - Method in class org.apache.flink.runtime.metrics.groups.InternalOperatorIOMetricGroup
-
Causes the containing task to use this operators output bytes counter.
- reuseInputMetricsForTask() - Method in class org.apache.flink.runtime.metrics.groups.InternalOperatorIOMetricGroup
-
Causes the containing task to use this operators input record counter.
- reuseOutputMetricsForTask() - Method in class org.apache.flink.runtime.metrics.groups.InternalOperatorIOMetricGroup
-
Causes the containing task to use this operators output record counter.
- reusePreviousStateHandle(long, Collection<? extends StreamStateHandle>) - Method in interface org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager
-
A callback method which is called when previous state handles are reused by following checkpoint(s).
- reusePreviousStateHandle(long, Collection<? extends StreamStateHandle>) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
- reusePreviousStateHandle(Collection<? extends StreamStateHandle>) - Method in interface org.apache.flink.runtime.state.CheckpointStreamFactory
-
A callback method when some previous handle is reused.
- reusePreviousStateHandle(Collection<? extends StreamStateHandle>) - Method in class org.apache.flink.runtime.state.filesystem.FsMergingCheckpointStorageLocation
- reuseRecordsInputCounter(Counter) - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- reuseRecordsOutputCounter(Counter) - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- ReusingBlockResettableIterator<T> - Class in org.apache.flink.runtime.operators.resettable
-
Implementation of an iterator that fetches a block of data into main memory and offers resettable access to the data in that block.
- ReusingBlockResettableIterator(MemoryManager, Iterator<T>, TypeSerializer<T>, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.resettable.ReusingBlockResettableIterator
- ReusingBlockResettableIterator(MemoryManager, TypeSerializer<T>, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.resettable.ReusingBlockResettableIterator
- ReusingBuildFirstHashJoinIterator<V1,V2,O> - Class in org.apache.flink.runtime.operators.hash
-
An implementation of the
JoinTaskIteratorthat uses a hybrid-hash-join internally to match the records with equal key. - ReusingBuildFirstHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V2, V1>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
- ReusingBuildFirstReOpenableHashJoinIterator<V1,V2,O> - Class in org.apache.flink.runtime.operators.hash
- ReusingBuildFirstReOpenableHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V2, V1>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.ReusingBuildFirstReOpenableHashJoinIterator
- ReusingBuildSecondHashJoinIterator<V1,V2,O> - Class in org.apache.flink.runtime.operators.hash
-
An implementation of the
JoinTaskIteratorthat uses a hybrid-hash-join internally to match the records with equal key. - ReusingBuildSecondHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V1, V2>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
- ReusingBuildSecondReOpenableHashJoinIterator<V1,V2,O> - Class in org.apache.flink.runtime.operators.hash
- ReusingBuildSecondReOpenableHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V1, V2>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.ReusingBuildSecondReOpenableHashJoinIterator
- ReusingDeserializationDelegate<T> - Class in org.apache.flink.runtime.plugable
-
A
DeserializationDelegatethat reuses an existing instance upon deserialization. - ReusingDeserializationDelegate(TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.plugable.ReusingDeserializationDelegate
- ReusingKeyGroupedIterator<E> - Class in org.apache.flink.runtime.util
-
The KeyValueIterator returns a key and all values that belong to the key (share the same key).
- ReusingKeyGroupedIterator(MutableObjectIterator<E>, TypeSerializer<E>, TypeComparator<E>) - Constructor for class org.apache.flink.runtime.util.ReusingKeyGroupedIterator
-
Initializes the KeyGroupedIterator.
- ReusingKeyGroupedIterator.ValuesIterator - Class in org.apache.flink.runtime.util
- ReusingMergeInnerJoinIterator<T1,T2,O> - Class in org.apache.flink.runtime.operators.sort
- ReusingMergeInnerJoinIterator(MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.ReusingMergeInnerJoinIterator
- ReusingMergeOuterJoinIterator<T1,T2,O> - Class in org.apache.flink.runtime.operators.sort
- ReusingMergeOuterJoinIterator(OuterJoinOperatorBase.OuterJoinType, MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.ReusingMergeOuterJoinIterator
- ReusingMutableToRegularIteratorWrapper<T> - Class in org.apache.flink.runtime.util
-
This class wraps a
MutableObjectIteratorinto a regularIterator. - ReusingMutableToRegularIteratorWrapper(MutableObjectIterator<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.util.ReusingMutableToRegularIteratorWrapper
- ReusingSortMergeCoGroupIterator<T1,T2> - Class in org.apache.flink.runtime.operators.sort
- ReusingSortMergeCoGroupIterator(MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>) - Constructor for class org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
- revert(long) - Method in class org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
-
Revert the buffer back to the result whose offset is `checkpointedOffset`.
- RevisionInformation(String, String) - Constructor for class org.apache.flink.runtime.util.EnvironmentInformation.RevisionInformation
- revokeDispatcherLeadership() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServicesWithLeadershipControl
- revokeDispatcherLeadership() - Method in interface org.apache.flink.runtime.highavailability.nonha.embedded.HaLeadershipControl
- revokeJobMasterLeadership(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServicesWithLeadershipControl
- revokeJobMasterLeadership(JobID) - Method in interface org.apache.flink.runtime.highavailability.nonha.embedded.HaLeadershipControl
- revokeLeadership() - Method in class org.apache.flink.runtime.dispatcher.runner.DefaultDispatcherRunner
- revokeLeadership() - Method in class org.apache.flink.runtime.jobmaster.JobMasterServiceLeadershipRunner
- revokeLeadership() - Method in interface org.apache.flink.runtime.leaderelection.LeaderContender
-
Callback method which is called by the
LeaderElectionServiceupon revoking the leadership of a former leader. - revokeLeadership() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerServiceImpl
- revokeLeadership() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
- revokeResourceManagerLeadership() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServicesWithLeadershipControl
- revokeResourceManagerLeadership() - Method in interface org.apache.flink.runtime.highavailability.nonha.embedded.HaLeadershipControl
- RichParallelSourceFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source.legacy
-
Deprecated.This class is based on the
SourceFunctionAPI, which is due to be removed. Use the newSourceAPI instead. - RichParallelSourceFunction() - Constructor for class org.apache.flink.streaming.api.functions.source.legacy.RichParallelSourceFunction
-
Deprecated.
- RichSinkFunction<IN> - Class in org.apache.flink.streaming.api.functions.sink.legacy
-
Deprecated.This interface will be removed in future versions. Use the new
Sinkinterface instead. - RichSinkFunction() - Constructor for class org.apache.flink.streaming.api.functions.sink.legacy.RichSinkFunction
-
Deprecated.
- RichSourceFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source.legacy
-
Deprecated.This class is based on the
SourceFunctionAPI, which is due to be removed. Use the newSourceAPI instead. - RichSourceFunction() - Constructor for class org.apache.flink.streaming.api.functions.source.legacy.RichSourceFunction
-
Deprecated.
- RIGHT_HYBRIDHASH_BUILD_FIRST - org.apache.flink.runtime.operators.DriverStrategy
- RIGHT_HYBRIDHASH_BUILD_SECOND - org.apache.flink.runtime.operators.DriverStrategy
- RIGHT_OUTER_MERGE - org.apache.flink.runtime.operators.DriverStrategy
- RightOuterJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
-
The right outer join driver implements the logic of an outer join operator at runtime.
- RightOuterJoinDriver() - Constructor for class org.apache.flink.runtime.operators.RightOuterJoinDriver
- rng - Variable in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
- ROCKSDB_STATE_BACKEND_NAME - Static variable in class org.apache.flink.runtime.state.StateBackendLoader
-
The shortcut configuration name for the RocksDB State Backend.
- RootExceptionHistoryEntry - Class in org.apache.flink.runtime.scheduler.exceptionhistory
-
RootExceptionHistoryEntryextendingExceptionHistoryEntryby providing a list ofExceptionHistoryEntryinstances to store concurrently caught failures. - RootExceptionHistoryEntry(Throwable, long, CompletableFuture<Map<String, String>>, String, TaskManagerLocation, Collection<ExceptionHistoryEntry>) - Constructor for class org.apache.flink.runtime.scheduler.exceptionhistory.RootExceptionHistoryEntry
-
Instantiates a
RootExceptionHistoryEntry. - RootExceptionInfo(String, String, long, Map<String, String>, String, String, String, Collection<JobExceptionsInfoWithHistory.ExceptionInfo>) - Constructor for class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.RootExceptionInfo
- RootExceptionInfo(String, String, long, Map<String, String>, Collection<JobExceptionsInfoWithHistory.ExceptionInfo>) - Constructor for class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.RootExceptionInfo
- ROUND_ROBIN - org.apache.flink.runtime.io.network.api.writer.SubtaskStateMapper
-
Redistributes subtask state in a round robin fashion.
- RoundRobinChannelSelector<T extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.writer
-
This is the default implementation of the
ChannelSelectorinterface. - RoundRobinChannelSelector() - Constructor for class org.apache.flink.runtime.io.network.api.writer.RoundRobinChannelSelector
- RoundRobinOperatorStateRepartitioner - Class in org.apache.flink.runtime.checkpoint
-
Current default implementation of
OperatorStateRepartitionerthat redistributes state in round robin fashion. - RoundRobinOperatorStateRepartitioner() - Constructor for class org.apache.flink.runtime.checkpoint.RoundRobinOperatorStateRepartitioner
- RoundRobinSubpartitionSelector<T> - Class in org.apache.flink.runtime.io.network.partition
-
A
SubpartitionSelectorthat selects all subpartitions in round-robin order. - RoundRobinSubpartitionSelector() - Constructor for class org.apache.flink.runtime.io.network.partition.RoundRobinSubpartitionSelector
- route(HttpMethod, String) - Method in class org.apache.flink.runtime.rest.handler.router.Router
-
If there's no match, returns the result with
notFoundas the target if it is set, otherwise returnsnull. - route(HttpMethod, String, Map<String, List<String>>) - Method in class org.apache.flink.runtime.rest.handler.router.Router
- RoutedRequest<T> - Class in org.apache.flink.runtime.rest.handler.router
-
Class for handling
HttpRequestwith associatedRouteResult. - RoutedRequest(RouteResult<T>, HttpRequest) - Constructor for class org.apache.flink.runtime.rest.handler.router.RoutedRequest
- Router<T> - Class in org.apache.flink.runtime.rest.handler.router
-
This is adopted and simplified code from tv.cntt:netty-router library.
- Router() - Constructor for class org.apache.flink.runtime.rest.handler.router.Router
- RouteResult<T> - Class in org.apache.flink.runtime.rest.handler.router
-
This is adopted and simplified code from tv.cntt:netty-router library.
- RouteResult(String, String, Map<String, String>, Map<String, List<String>>, T) - Constructor for class org.apache.flink.runtime.rest.handler.router.RouteResult
-
The maps will be wrapped in Collections.unmodifiableMap.
- RouterHandler - Class in org.apache.flink.runtime.rest.handler.router
-
Inbound handler that converts HttpRequest to Routed and passes Routed to the matched handler.
- RouterHandler(Router, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.router.RouterHandler
- RpcCheckpointResponder - Class in org.apache.flink.runtime.taskexecutor.rpc
- RpcCheckpointResponder(CheckpointCoordinatorGateway) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcCheckpointResponder
- RpcGatewayRetriever<F extends Serializable,T extends org.apache.flink.runtime.rpc.FencedRpcGateway<F>> - Class in org.apache.flink.runtime.webmonitor.retriever.impl
-
LeaderGatewayRetrieverimplementation using theRpcService. - RpcGatewayRetriever(RpcService, Class<T>, Function<UUID, F>, RetryStrategy) - Constructor for class org.apache.flink.runtime.webmonitor.retriever.impl.RpcGatewayRetriever
- RpcGlobalAggregateManager - Class in org.apache.flink.runtime.taskexecutor.rpc
- RpcGlobalAggregateManager(JobMasterGateway) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcGlobalAggregateManager
- RpcInputSplitProvider - Class in org.apache.flink.runtime.taskexecutor.rpc
- RpcInputSplitProvider(JobMasterGateway, JobVertexID, ExecutionAttemptID, Duration) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcInputSplitProvider
- RpcKvStateRegistryListener - Class in org.apache.flink.runtime.taskexecutor.rpc
-
KvStateRegistryListenerimplementation for the new RPC service. - RpcKvStateRegistryListener(KvStateRegistryGateway, InetSocketAddress) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcKvStateRegistryListener
- RpcMetricQueryServiceRetriever - Class in org.apache.flink.runtime.webmonitor.retriever.impl
-
MetricQueryServiceRetrieverimplementation for rpc basedMetricQueryService. - RpcMetricQueryServiceRetriever(RpcService) - Constructor for class org.apache.flink.runtime.webmonitor.retriever.impl.RpcMetricQueryServiceRetriever
- RpcPartitionStateChecker - Class in org.apache.flink.runtime.taskexecutor.rpc
- RpcPartitionStateChecker(JobMasterGateway) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcPartitionStateChecker
- RpcServiceSharing - Enum in org.apache.flink.runtime.minicluster
-
Enum which defines whether the mini cluster components use a shared RpcService or whether every component gets its own dedicated RpcService started.
- RpcTaskManagerGateway - Class in org.apache.flink.runtime.jobmaster
-
Implementation of the
TaskManagerGatewayfor Flink's RPC system. - RpcTaskManagerGateway(TaskExecutorGateway, JobMasterId) - Constructor for class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
- RpcTaskOperatorEventGateway - Class in org.apache.flink.runtime.taskexecutor.rpc
-
An OperatorEventSender that calls the RPC gateway
JobMasterOperatorEventGatewayto send the messages to the coordinator. - RpcTaskOperatorEventGateway(JobMasterOperatorEventGateway, ExecutionAttemptID, Consumer<Throwable>) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcTaskOperatorEventGateway
- rpcTimeout - Variable in class org.apache.flink.runtime.jobmaster.slotpool.AbstractSlotPoolServiceFactory
- run() - Method in class org.apache.flink.runtime.blob.BlobServer
- run() - Method in class org.apache.flink.runtime.heartbeat.DefaultHeartbeatMonitor
- run() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskIOScheduler
- run() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteStorageScanner
-
Iterate the watched segment ids and check related file status.
- run() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
- run() - Method in class org.apache.flink.runtime.iterative.task.IterationHeadTask
- run() - Method in class org.apache.flink.runtime.iterative.task.IterationIntermediateTask
- run() - Method in class org.apache.flink.runtime.iterative.task.IterationTailTask
- run() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
- run() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
- run() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
- run() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
- run() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
- run() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
- run() - Method in class org.apache.flink.runtime.operators.BatchTask
- run() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
- run() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
- run() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
- run() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
- run() - Method in class org.apache.flink.runtime.operators.CrossDriver
- run() - Method in interface org.apache.flink.runtime.operators.Driver
-
The main operation method of the task.
- run() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
- run() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
- run() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
- run() - Method in class org.apache.flink.runtime.operators.JoinDriver
- run() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
- run() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
- run() - Method in class org.apache.flink.runtime.operators.MapDriver
- run() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
- run() - Method in class org.apache.flink.runtime.operators.NoOpDriver
- run() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
- run() - Method in class org.apache.flink.runtime.operators.ReduceDriver
- run() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
- run() - Method in class org.apache.flink.runtime.state.DoneFuture
- run() - Method in class org.apache.flink.runtime.taskmanager.MemoryLogger
- run() - Method in class org.apache.flink.runtime.taskmanager.Task
-
The core work method that bootstraps the task and executes its code.
- run() - Method in class org.apache.flink.runtime.util.JvmShutdownSafeguard
- run() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.Mail
- run(Object, Output<StreamRecord<OUT>>, OperatorChain<?, ?>) - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
Deprecated.
- run(Object, OperatorChain<?, ?>) - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
Deprecated.
- run(SourceFunction.SourceContext<Long>) - Method in class org.apache.flink.streaming.api.functions.source.legacy.StatefulSequenceSource
-
Deprecated.
- run(SourceFunction.SourceContext<String>) - Method in class org.apache.flink.streaming.api.functions.source.legacy.SocketTextStreamFunction
-
Deprecated.
- run(SourceFunction.SourceContext<Tuple3<String, Long, Long>>) - Method in class org.apache.flink.streaming.api.functions.source.legacy.FileMonitoringFunction
-
Deprecated.
- run(SourceFunction.SourceContext<TimestampedFileInputSplit>) - Method in class org.apache.flink.streaming.api.functions.source.legacy.ContinuousFileMonitoringFunction
-
Deprecated.
- run(SourceFunction.SourceContext<OUT>) - Method in class org.apache.flink.streaming.api.functions.source.legacy.InputFormatSourceFunction
-
Deprecated.
- run(SourceFunction.SourceContext<T>) - Method in class org.apache.flink.streaming.api.functions.source.legacy.FromElementsFunction
-
Deprecated.
- run(SourceFunction.SourceContext<T>) - Method in class org.apache.flink.streaming.api.functions.source.legacy.FromIteratorFunction
-
Deprecated.
- run(SourceFunction.SourceContext<T>) - Method in class org.apache.flink.streaming.api.functions.source.legacy.FromSplittableIteratorFunction
-
Deprecated.
- run(SourceFunction.SourceContext<T>) - Method in interface org.apache.flink.streaming.api.functions.source.legacy.SourceFunction
-
Deprecated.Starts the source.
- run(RunnableWithException) - Method in interface org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
- run(RunnableWithException) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor
-
Deprecated.
- runBatch() - Method in class org.apache.flink.runtime.asyncprocessing.BatchCallbackRunner
-
Run at most a full batch of callbacks.
- runClusterEntrypoint(ClusterEntrypoint) - Static method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
- runDefaultAction(MailboxDefaultAction.Controller) - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.MailboxDefaultAction
-
This method implements the default action of the mailbox loop (e.g. processing one event from the input).
- runDetached(JobGraph) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
This method executes a job in detached mode.
- runDisposer(Runnable) - Method in interface org.apache.flink.runtime.asyncprocessing.RecordContext.DisposerRunner
- runExclusively(Runnable) - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
Runs the given code exclusively on this mailbox.
- runExclusively(Runnable) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
- runFlinkZkQuorumPeer(String, int) - Static method in class org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
-
Runs a ZooKeeper
QuorumPeerif further peers are configured or a singleZooKeeperServerif no further peers are configured. - runIfState(State, Runnable) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- runIfState(State, Runnable, Duration) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- runInCoordinatorThread(Runnable) - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinatorContext
-
If the runnable throws an Exception, the corresponding job is failed.
- runMailboxLoop() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
Runs the mailbox processing loop.
- runMailboxLoop() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- runMailboxStep() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
Execute a single (as small as possible) step of the mailbox.
- runMailboxStep() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- Runnables - Class in org.apache.flink.runtime.util
-
Utils related to
Runnable. - Runnables() - Constructor for class org.apache.flink.runtime.util.Runnables
- running - Variable in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
- running - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The flag that tags the task as still running.
- running - Variable in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
- running - Variable in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
- running - Variable in class org.apache.flink.runtime.operators.JoinDriver
- running - Variable in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
- running - Variable in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
- RUNNING - org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess.State
- RUNNING - org.apache.flink.runtime.execution.ExecutionState
- RUNNING - org.apache.flink.runtime.rest.messages.ProfilingInfo.ProfilingStatus
- runPostJobGloballyTerminated(JobID, JobStatus) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- runPostJobGloballyTerminated(JobID, JobStatus) - Method in class org.apache.flink.runtime.dispatcher.MiniDispatcher
- runSecured(Callable<T>) - Method in class org.apache.flink.runtime.security.contexts.HadoopSecurityContext
- runSecured(Callable<T>) - Method in class org.apache.flink.runtime.security.contexts.NoOpSecurityContext
- runSecured(Callable<T>) - Method in interface org.apache.flink.runtime.security.contexts.SecurityContext
- runSingleMailboxLoop() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
Execute a single (as small as possible) step of the mailbox.
- runSingleMailboxLoop() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- runTaskManager(Configuration, PluginManager) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
- runTaskManagerProcessSecurely(String[]) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
- runTaskManagerProcessSecurely(Configuration) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
- runThrowing(ThrowingRunnable<E>) - Method in interface org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
- runThrowing(ThrowingRunnable<E>) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor
-
Deprecated.
- RUNTIME_FAILURE_RETURN_CODE - Static variable in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
- RuntimeAggregatorRegistry - Class in org.apache.flink.runtime.iterative.task
- RuntimeAggregatorRegistry(Collection<AggregatorWithName<?>>) - Constructor for class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
- RuntimeEnvironment - Class in org.apache.flink.runtime.taskmanager
-
In implementation of the
Environment. - RuntimeEnvironment(JobID, JobType, JobVertexID, ExecutionAttemptID, ExecutionConfig, JobInfo, TaskInfo, Configuration, Configuration, UserCodeClassLoader, MemoryManager, SharedResources, IOManager, BroadcastVariableManager, TaskStateManager, GlobalAggregateManager, AccumulatorRegistry, TaskKvStateRegistry, InputSplitProvider, Map<String, Future<Path>>, ResultPartitionWriter[], IndexedInputGate[], TaskEventDispatcher, CheckpointResponder, TaskOperatorEventGateway, TaskManagerRuntimeInfo, TaskMetricGroup, Task, ExternalResourceInfoProvider, ChannelStateWriteRequestExecutorFactory, TaskManagerActions) - Constructor for class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- RuntimeEvent - Class in org.apache.flink.runtime.event
-
Subclasses of this event are recognized as events exchanged by the core runtime.
- RuntimeEvent() - Constructor for class org.apache.flink.runtime.event.RuntimeEvent
- RuntimeMessageHeaders<R extends RequestBody,P extends ResponseBody,M extends MessageParameters> - Interface in org.apache.flink.runtime.rest.messages
-
This class links
RequestBodys toResponseBodys types and contains meta-data required for their http headers in runtime module. - RuntimeRestAPIVersion - Enum in org.apache.flink.runtime.rest.versioning
-
An enum for all versions of the REST API.
- runtimeUdfContext - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The udf's runtime context.
- RuntimeUntypedResponseMessageHeaders<R extends RequestBody,M extends MessageParameters> - Interface in org.apache.flink.runtime.rest.messages
-
Message headers for a web handler request that belongs to runtime module.
S
- savepoint() - Method in interface org.apache.flink.runtime.state.CheckpointableKeyedStateBackend
-
Returns a
SavepointResourcesthat can be used bySavepointSnapshotStrategyto write out a savepoint in the common/unified format. - savepoint() - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
- savepoint() - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
- savepoint(SavepointFormatType) - Static method in class org.apache.flink.runtime.checkpoint.SavepointType
- SAVEPOINT - org.apache.flink.runtime.dispatcher.TriggerSavepointMode
- SavepointDisposalHandlers - Class in org.apache.flink.runtime.rest.handler.job.savepoints
-
Handlers to trigger the disposal of a savepoint.
- SavepointDisposalHandlers(Duration) - Constructor for class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers
- SavepointDisposalHandlers.SavepointDisposalStatusHandler - Class in org.apache.flink.runtime.rest.handler.job.savepoints
-
AbstractAsynchronousOperationHandlers.StatusHandlerimplementation for the savepoint disposal operation. - SavepointDisposalHandlers.SavepointDisposalTriggerHandler - Class in org.apache.flink.runtime.rest.handler.job.savepoints
-
AbstractAsynchronousOperationHandlers.TriggerHandlerimplementation for the savepoint disposal operation. - SavepointDisposalRequest - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
Request body for a savepoint disposal call.
- SavepointDisposalRequest(String) - Constructor for class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalRequest
- SavepointDisposalStatusHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalStatusHandler
- SavepointDisposalStatusHeaders - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
AsynchronousOperationTriggerMessageHeadersimplementation for theSavepointDisposalHandlers.SavepointDisposalStatusHandler. - SavepointDisposalStatusMessageParameters - Class in org.apache.flink.runtime.rest.messages.job.savepoints
- SavepointDisposalStatusMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusMessageParameters
- SavepointDisposalTriggerHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalTriggerHandler
- SavepointDisposalTriggerHeaders - Class in org.apache.flink.runtime.rest.messages.job.savepoints
- SavepointHandlers - Class in org.apache.flink.runtime.rest.handler.job.savepoints
-
HTTP handlers for asynchronous triggering of savepoints.
- SavepointHandlers(String) - Constructor for class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers
- SavepointHandlers.SavepointStatusHandler - Class in org.apache.flink.runtime.rest.handler.job.savepoints
-
HTTP handler to query for the status of the savepoint.
- SavepointHandlers.SavepointTriggerHandler - Class in org.apache.flink.runtime.rest.handler.job.savepoints
-
HTTP handler to trigger savepoints.
- SavepointHandlers.StopWithSavepointHandler - Class in org.apache.flink.runtime.rest.handler.job.savepoints
-
HTTP handler to stop a job with a savepoint.
- SavepointInfo - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
Represents information about a finished savepoint.
- SavepointInfo(String, SerializedThrowable) - Constructor for class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointInfo
- SavepointKeyedStateHandle - Interface in org.apache.flink.runtime.state
-
A
KeyedStateHandlethat points to a savepoint taken in the unified format. - SavepointResources<K> - Class in org.apache.flink.runtime.state
-
Savepoint resources for a
KeyedStateBackend. - SavepointResources(FullSnapshotResources<K>, SnapshotExecutionType) - Constructor for class org.apache.flink.runtime.state.SavepointResources
- SavepointRestoreResult - Class in org.apache.flink.runtime.state.restore
-
A result from restoring a single
KeyedStateHandle. - SavepointRestoreResult(List<StateMetaInfoSnapshot>, ThrowingIterator<KeyGroup>) - Constructor for class org.apache.flink.runtime.state.restore.SavepointRestoreResult
- SavepointRestoreSettings - Class in org.apache.flink.runtime.jobgraph
-
Savepoint restore settings.
- SavepointSnapshotStrategy<K> - Class in org.apache.flink.runtime.state
-
A
SnapshotStrategythat produces unified savepoints. - SavepointSnapshotStrategy(FullSnapshotResources<K>) - Constructor for class org.apache.flink.runtime.state.SavepointSnapshotStrategy
-
Creates a
SavepointSnapshotStrategythat writes a savepoint from the givenFullSnapshotResources. - SavepointStatusHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointStatusHandler
- SavepointStatusHeaders - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
These headers define the protocol for triggering a savepoint.
- SavepointStatusMessageParameters - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
The parameters for triggering a savepoint.
- SavepointStatusMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusMessageParameters
- SavepointTriggerHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointTriggerHandler
- SavepointTriggerHeaders - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
These headers define the protocol for triggering a savepoint.
- SavepointTriggerMessageParameters - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
The parameters for triggering a savepoint.
- SavepointTriggerMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerMessageParameters
- SavepointTriggerRequestBody - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
RequestBodyto trigger savepoints. - SavepointTriggerRequestBody(String, Boolean, SavepointFormatType, TriggerId) - Constructor for class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerRequestBody
- SavepointType - Class in org.apache.flink.runtime.checkpoint
-
The type of checkpoint to perform.
- SavepointType.PostCheckpointAction - Enum in org.apache.flink.runtime.checkpoint
-
What's the intended action after the checkpoint (relevant for stopping with savepoint).
- ScalaProductFieldAccessorFactory - Interface in org.apache.flink.streaming.util.typeutils
-
Interface to interact with optional Scala field accessors.
- scheduleAllVerticesIfPossible() - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingStrategy
-
Schedules all vertices and excludes any vertices that are already finished or whose inputs are not yet ready.
- scheduleAllVerticesIfPossible() - Method in class org.apache.flink.runtime.scheduler.strategy.VertexwiseSchedulingStrategy
- scheduleAtFixedRate(ProcessingTimeService.ProcessingTimeCallback, long, long) - Method in interface org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
-
Registers a task to be executed repeatedly at a fixed rate.
- scheduleAtFixedRate(ProcessingTimeService.ProcessingTimeCallback, long, long) - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
- SCHEDULED - org.apache.flink.runtime.execution.ExecutionState
- scheduleOperation(Runnable, Duration) - Method in interface org.apache.flink.runtime.scheduler.adaptive.StateTransitionManager.Context
-
Runs operation with a given delay in the underlying main thread.
- schedulePendingRequestBulkTimeoutCheck(PhysicalSlotRequestBulk, Duration) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlotRequestBulkChecker
-
Starts tracking the fulfillability of a
PhysicalSlotRequestBulkwith timeout. - schedulePendingRequestBulkTimeoutCheck(PhysicalSlotRequestBulk, Duration) - Method in class org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlotRequestBulkCheckerImpl
- SchedulerBase - Class in org.apache.flink.runtime.scheduler
-
Base class which can be used to implement
SchedulerNG. - SchedulerBase(Logger, JobGraph, Executor, Configuration, CheckpointsCleaner, CheckpointRecoveryFactory, JobManagerJobMetricGroup, ExecutionVertexVersioner, long, ComponentMainThreadExecutor, JobStatusListener, ExecutionGraphFactory, VertexParallelismStore) - Constructor for class org.apache.flink.runtime.scheduler.SchedulerBase
- SchedulerNG - Interface in org.apache.flink.runtime.scheduler
-
Interface for scheduling Flink jobs.
- SchedulerNGFactory - Interface in org.apache.flink.runtime.scheduler
-
Factory for
SchedulerNG. - SchedulerOperations - Interface in org.apache.flink.runtime.scheduler
-
Component which is used by
SchedulingStrategyto commit scheduling decisions. - SchedulerUtils - Class in org.apache.flink.runtime.scheduler
-
Utils class for Flink's scheduler implementations.
- scheduleWithFixedDelay(ProcessingTimeService.ProcessingTimeCallback, long, long) - Method in interface org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
-
Registers a task to be executed repeatedly with a fixed delay.
- scheduleWithFixedDelay(ProcessingTimeService.ProcessingTimeCallback, long, long) - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
- SchedulingExecutionVertex - Interface in org.apache.flink.runtime.scheduler.strategy
-
Scheduling representation of
ExecutionVertex. - SchedulingPipelinedRegion - Interface in org.apache.flink.runtime.scheduler.strategy
-
Pipelined region on execution level, i.e.,
ExecutionGraphlevel. - SchedulingPipelinedRegionComputeUtil - Class in org.apache.flink.runtime.executiongraph.failover
-
Utils for computing
SchedulingPipelinedRegions. - SchedulingResultPartition - Interface in org.apache.flink.runtime.scheduler.strategy
-
Representation of
IntermediateResultPartition. - schedulingStrategy - Variable in class org.apache.flink.runtime.scheduler.DefaultScheduler
- SchedulingStrategy - Interface in org.apache.flink.runtime.scheduler.strategy
-
Component which encapsulates the scheduling logic.
- SchedulingStrategyFactory - Interface in org.apache.flink.runtime.scheduler.strategy
-
Factory interface for
SchedulingStrategy. - SchedulingTopology - Interface in org.apache.flink.runtime.scheduler.strategy
-
Topology of
SchedulingExecutionVertex. - SchedulingTopologyListener - Interface in org.apache.flink.runtime.scheduler
-
This listener will be notified whenever the scheduling topology is updated.
- scope - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
-
The remaining scope not covered by specific fields.
- SCOPE_HOST - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
- SCOPE_INHERIT_PARENT - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
If the scope format starts with this character, then the parent components scope format will be used as a prefix.
- SCOPE_JOB_ID - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
- SCOPE_JOB_NAME - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
- SCOPE_OPERATOR_ID - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
- SCOPE_OPERATOR_NAME - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
- SCOPE_SEPARATOR - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
- SCOPE_TASK_ATTEMPT_ID - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
- SCOPE_TASK_ATTEMPT_NUM - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
- SCOPE_TASK_NAME - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
- SCOPE_TASK_SUBTASK_INDEX - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
- SCOPE_TASK_VERTEX_ID - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
- SCOPE_TASKMANAGER_ID - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
- ScopeFormat - Class in org.apache.flink.runtime.metrics.scope
-
This class represents the format after which the "scope" (or namespace) of the various component metric groups is built.
- ScopeFormat(String, ScopeFormat, String[]) - Constructor for class org.apache.flink.runtime.metrics.scope.ScopeFormat
- ScopeFormats - Class in org.apache.flink.runtime.metrics.scope
-
A container for component scope formats.
- scopeInfo - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump
-
The scope information for the stored metric.
- SECOND - Static variable in class org.apache.flink.streaming.api.operators.InputSelection
-
The
InputSelectioninstance which indicates to select the second input. - secondDam() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
- SecureAclProvider() - Constructor for class org.apache.flink.runtime.util.ZooKeeperUtils.SecureAclProvider
- SecurityConfiguration - Class in org.apache.flink.runtime.security
-
The global security configuration.
- SecurityConfiguration(Configuration) - Constructor for class org.apache.flink.runtime.security.SecurityConfiguration
-
Create a security configuration from the global configuration.
- SecurityConfiguration(Configuration, List<String>, List<String>) - Constructor for class org.apache.flink.runtime.security.SecurityConfiguration
-
Create a security configuration from the global configuration.
- SecurityContext - Interface in org.apache.flink.runtime.security.contexts
-
A security context with may be required to run a Callable.
- SecurityContextFactory - Interface in org.apache.flink.runtime.security.contexts
-
A factory for a
SecurityContext. - SecurityContextInitializeException - Exception in org.apache.flink.runtime.security
-
Indicates a problem with installing or uninstalling a security module or context.
- SecurityContextInitializeException(String) - Constructor for exception org.apache.flink.runtime.security.SecurityContextInitializeException
- SecurityContextInitializeException(String, Throwable) - Constructor for exception org.apache.flink.runtime.security.SecurityContextInitializeException
- SecurityFactoryServiceLoader - Class in org.apache.flink.runtime.security
-
The Service provider discovery for searching suitable security factory.
- SecurityFactoryServiceLoader() - Constructor for class org.apache.flink.runtime.security.SecurityFactoryServiceLoader
- SecurityInstallException(String) - Constructor for exception org.apache.flink.runtime.security.modules.SecurityModule.SecurityInstallException
- SecurityInstallException(String, Throwable) - Constructor for exception org.apache.flink.runtime.security.modules.SecurityModule.SecurityInstallException
- SecurityModule - Interface in org.apache.flink.runtime.security.modules
-
An installable security module.
- SecurityModule.SecurityInstallException - Exception in org.apache.flink.runtime.security.modules
-
Indicates a problem with installing or uninstalling a security module.
- SecurityModuleFactory - Interface in org.apache.flink.runtime.security.modules
-
A factory for a
SecurityModule. - SecurityUtils - Class in org.apache.flink.runtime.security
-
Security Environment that holds the security context and modules installed.
- SecurityUtils() - Constructor for class org.apache.flink.runtime.security.SecurityUtils
- seek(long) - Method in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
- seek(long) - Method in class org.apache.flink.runtime.state.CompressibleFSDataInputStream
- seek(long) - Method in class org.apache.flink.runtime.state.filesystem.FsSegmentDataInputStream
- SeekableFileChannelInputView - Class in org.apache.flink.runtime.io.disk
-
A
DataInputViewthat is backed by aBlockChannelReader, making it effectively a data input stream. - SeekableFileChannelInputView(IOManager, FileIOChannel.ID, MemoryManager, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
- seekInput(MemorySegment, int, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Sets the internal state of the view such that the next bytes will be read from the given memory segment, starting at the given position.
- seekOutput(MemorySegment, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
Sets the internal state to the given memory segment and the given position within the segment.
- seekTo(long) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileSegmentReader
- seekTo(long) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileSegmentReader
- seekToPosition(long) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockReader
- seekToPosition(long) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileReader
- seekToPosition(long) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelReader
- seekToPosition(long) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileReader
- seekToPosition(long) - Method in class org.apache.flink.runtime.io.disk.iomanager.SynchronousBufferFileReader
- SegmentBufferContext(int, List<Tuple2<Buffer, Integer>>, boolean) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.PartitionFileWriter.SegmentBufferContext
- SegmentFileStateHandle - Class in org.apache.flink.runtime.state.filemerging
-
FileStateHandlefor state that was written to a file segment. - SegmentFileStateHandle(Path, long, long, CheckpointedStateScope, LogicalFile.LogicalFileId) - Constructor for class org.apache.flink.runtime.state.filemerging.SegmentFileStateHandle
-
Creates a new segment file state for the given file path.
- SegmentPartitionFile - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.file
-
The partition file with segment file mode.
- SegmentPartitionFile() - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.SegmentPartitionFile
- SegmentPartitionFileReader - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.file
-
The implementation of
PartitionFileReaderwith segment file mode. - SegmentPartitionFileReader(String) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.SegmentPartitionFileReader
- SegmentPartitionFileWriter - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.file
-
The implementation of
PartitionFileWriterwith segment file mode. - segments - Variable in class org.apache.flink.runtime.io.network.partition.SortBuffer
-
A segment list as a joint buffer which stores all records and index entries.
- segmentSize - Variable in class org.apache.flink.runtime.memory.AbstractPagedOutputView
- segmentSize - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The size of the segments used by the hash join buckets.
- select(int) - Method in class org.apache.flink.streaming.api.operators.InputSelection.Builder
-
Selects an input identified by the given
inputId. - SelectableSortingInputs(StreamTaskInput<?>[], StreamTaskInput<?>[], InputSelectable) - Constructor for class org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput.SelectableSortingInputs
- selectAllocationBaseDirectory(int) - Method in interface org.apache.flink.runtime.state.LocalSnapshotDirectoryProvider
-
Returns a specific allocation base directory.
- selectAllocationBaseDirectory(int) - Method in class org.apache.flink.runtime.state.LocalSnapshotDirectoryProviderImpl
- selectBestSlotForProfile(FreeSlotTracker, SlotProfile) - Method in class org.apache.flink.runtime.jobmaster.slotpool.LocationPreferenceSlotSelectionStrategy
- selectBestSlotForProfile(FreeSlotTracker, SlotProfile) - Method in class org.apache.flink.runtime.jobmaster.slotpool.PreviousAllocationSlotSelectionStrategy
- selectBestSlotForProfile(FreeSlotTracker, SlotProfile) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotSelectionStrategy
-
Selects the best
SlotInfow.r.t. a certain selection criterion from the provided list of available slots and considering the givenSlotProfilethat describes the requirements. - selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
-
Note: Broadcast mode could be handled directly for all the output channels in record writer, so it is no need to select channels via this method.
- selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
- selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardForConsecutiveHashPartitioner
- selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardForUnspecifiedPartitioner
- selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
- selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
- selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
- selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
- selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
- selectChannel(SerializationDelegate<StreamRecord<T>>) - Method in class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
- selectChannel(SerializationDelegate<T>) - Method in class org.apache.flink.runtime.operators.shipping.OutputEmitter
- selectChannel(T) - Method in interface org.apache.flink.runtime.io.network.api.writer.ChannelSelector
-
Returns the logical channel index, to which the given record should be written.
- selectChannel(T) - Method in class org.apache.flink.runtime.io.network.api.writer.RoundRobinChannelSelector
- selectSlotSelectionStrategy(JobType, Configuration) - Static method in class org.apache.flink.runtime.util.SlotSelectionStrategyUtils
- selectSubtaskBaseDirectory(int) - Method in interface org.apache.flink.runtime.state.LocalSnapshotDirectoryProvider
-
Returns a specific subtask base directory.
- selectSubtaskBaseDirectory(int) - Method in class org.apache.flink.runtime.state.LocalSnapshotDirectoryProviderImpl
- selectWithoutLocationPreference(FreeSlotTracker, ResourceProfile) - Method in class org.apache.flink.runtime.jobmaster.slotpool.LocationPreferenceSlotSelectionStrategy
- send(StageRunner.SortStage, CircularElement<E>) - Method in interface org.apache.flink.runtime.operators.sort.StageRunner.StageMessageDispatcher
-
Sends a message to the given stage.
- sendAcknowledgeCheckpointEvent(long) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- sendCoordinationRequest(String, CoordinationRequest) - Method in class org.apache.flink.runtime.minicluster.MiniClusterJobClient
- sendCoordinationRequest(String, CoordinationRequest) - Method in interface org.apache.flink.runtime.operators.coordination.CoordinationRequestGateway
-
Send out a request to a specified coordinator and return the response.
- sendErrorResponse(ChannelHandlerContext, boolean, ErrorResponseBody, HttpResponseStatus, Map<String, String>) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerUtils
-
Sends the given error response and status code to the given channel.
- sendErrorResponse(ChannelHandlerContext, HttpRequest, ErrorResponseBody, HttpResponseStatus, Map<String, String>) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerUtils
-
Sends the given error response and status code to the given channel.
- sendEvent(OperatorEvent) - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator.SubtaskGateway
-
Sends an event to the parallel subtask with the given subtask index.
- sendEventToCoordinator(OperatorEvent) - Method in interface org.apache.flink.runtime.operators.coordination.OperatorEventGateway
-
Sends the given event to the coordinator, where it will be handled by the
OperatorCoordinator.handleEventFromOperator(int, int, OperatorEvent)method. - sendEventToSourceReader(int, int, SourceEvent) - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinatorContext
- sendEventToSourceReader(int, SourceEvent) - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinatorContext
- sendNotModified(ChannelHandlerContext) - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
-
Send the "304 Not Modified" response.
- sendOperatorEvent(OperatorID, SerializedValue<OperatorEvent>) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Sends the operator event to the Task on the Task Executor.
- sendOperatorEventToCoordinator(ExecutionAttemptID, OperatorID, SerializedValue<OperatorEvent>) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- sendOperatorEventToCoordinator(ExecutionAttemptID, OperatorID, SerializedValue<OperatorEvent>) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterOperatorEventGateway
- sendOperatorEventToCoordinator(OperatorID, SerializedValue<OperatorEvent>) - Method in interface org.apache.flink.runtime.jobgraph.tasks.TaskOperatorEventGateway
-
Sends an event from the operator (identified by the given operator ID) to the operator coordinator (identified by the same ID).
- sendOperatorEventToCoordinator(OperatorID, SerializedValue<OperatorEvent>) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcTaskOperatorEventGateway
- sendOperatorEventToTask(ExecutionAttemptID, OperatorID, SerializedValue<OperatorEvent>) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
- sendOperatorEventToTask(ExecutionAttemptID, OperatorID, SerializedValue<OperatorEvent>) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
- sendOperatorEventToTask(ExecutionAttemptID, OperatorID, SerializedValue<OperatorEvent>) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- sendOperatorEventToTask(ExecutionAttemptID, OperatorID, SerializedValue<OperatorEvent>) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
- sendOperatorEventToTask(ExecutionAttemptID, OperatorID, SerializedValue<OperatorEvent>) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- sendOperatorEventToTask(ExecutionAttemptID, OperatorID, SerializedValue<OperatorEvent>) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorOperatorEventGateway
-
Sends an operator event to an operator in a task executed by the Task Manager (Task Executor).
- sendReadRequest(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
Sends a new read requests, if further requests remain.
- sendRequest(String, int, M) - Method in class org.apache.flink.runtime.rest.RestClient
- sendRequest(String, int, M, U, R) - Method in class org.apache.flink.runtime.rest.RestClient
- sendRequest(String, int, M, U, R, Collection<FileUpload>) - Method in class org.apache.flink.runtime.rest.RestClient
- sendRequest(String, int, M, U, R, Collection<FileUpload>, RestAPIVersion<? extends RestAPIVersion<?>>) - Method in class org.apache.flink.runtime.rest.RestClient
- sendRequestToCoordinator(OperatorID, SerializedValue<CoordinationRequest>) - Method in interface org.apache.flink.runtime.jobgraph.tasks.TaskOperatorEventGateway
-
Sends a request from current operator to a specified operator coordinator which is identified by the given operator ID and return the response.
- sendRequestToCoordinator(OperatorID, SerializedValue<CoordinationRequest>) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- sendRequestToCoordinator(OperatorID, SerializedValue<CoordinationRequest>) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterOperatorEventGateway
- sendRequestToCoordinator(OperatorID, SerializedValue<CoordinationRequest>) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcTaskOperatorEventGateway
- sendResponse(ChannelHandlerContext, boolean, String, HttpResponseStatus, Map<String, String>) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerUtils
-
Sends the given response and status code to the given channel.
- sendResponse(ChannelHandlerContext, HttpRequest, String, HttpResponseStatus, Map<String, String>) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerUtils
-
Sends the given response and status code to the given channel.
- sendResponse(ChannelHandlerContext, HttpRequest, P, HttpResponseStatus, Map<String, String>) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerUtils
-
Sends the given response and status code to the given channel.
- sendResult(MutableObjectIterator<E>) - Method in interface org.apache.flink.runtime.operators.sort.StageRunner.StageMessageDispatcher
-
Sends a result to the corresponding
Sorter. - sendSlotReport(ResourceID, InstanceID, SlotReport, Duration) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
- sendSlotReport(ResourceID, InstanceID, SlotReport, Duration) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Sends the given
SlotReportto the ResourceManager. - sendTaskEvent(TaskEvent) - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
- sendTaskEvent(TaskEvent) - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
- sendTaskEvent(TaskEvent) - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
- sendTaskEvent(TaskEvent) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- sendTaskEvent(TaskEvent) - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
- sendTaskEvent(TaskEvent) - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
- sendTaskEvent(ResultPartitionID, TaskEvent, RemoteInputChannel) - Method in class org.apache.flink.runtime.io.network.netty.NettyPartitionRequestClient
-
Sends a task event backwards to an intermediate result partition producer.
- sendTaskEvent(ResultPartitionID, TaskEvent, RemoteInputChannel) - Method in interface org.apache.flink.runtime.io.network.PartitionRequestClient
-
Sends a task event backwards to an intermediate result partition.
- SEQUENCE_NUMBER_RESTORED - Static variable in interface org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter
-
Sequence number for the buffers that were saved during the previous execution attempt; then restored; and now are to be saved again (as opposed to the buffers received from the upstream or from the operator).
- SEQUENCE_NUMBER_UNKNOWN - Static variable in interface org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter
-
Signifies that buffer sequence number is unknown (e.g. if passing sequence numbers is not implemented).
- SequenceNumber - Interface in org.apache.flink.runtime.state.changelog
-
A logical timestamp to draw a boundary between the materialized and non-materialized changes.
- SequenceNumber.GenericSequenceNumber - Class in org.apache.flink.runtime.state.changelog
-
Generic
SequenceNumber. - SequenceNumberRange - Interface in org.apache.flink.runtime.state.changelog
- SequenceNumberRange.GenericSequenceNumberRange - Class in org.apache.flink.runtime.state.changelog
- SequentialChannelStateReader - Interface in org.apache.flink.runtime.checkpoint.channel
-
Reads channel state saved during checkpoint/savepoint.
- SequentialChannelStateReaderImpl - Class in org.apache.flink.runtime.checkpoint.channel
-
SequentialChannelStateReaderimplementation. - SequentialChannelStateReaderImpl(TaskStateSnapshot) - Constructor for class org.apache.flink.runtime.checkpoint.channel.SequentialChannelStateReaderImpl
- SERIAL_BETWEEN_EPOCH - org.apache.flink.runtime.asyncprocessing.EpochManager.ParallelMode
-
Subsequent epochs must wait until the previous epoch is completed before they can start.
- SerializationDelegate<T> - Class in org.apache.flink.runtime.plugable
-
The serialization delegate exposes an arbitrary element as a
IOReadableWritablefor serialization, with the help of a type serializer. - SerializationDelegate(TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.plugable.SerializationDelegate
- serialize(ArrayList<T>, DataOutputView) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
- serialize(Map<Counter, Tuple2<QueryScopeInfo, String>>, Map<Gauge<?>, Tuple2<QueryScopeInfo, String>>, Map<Histogram, Tuple2<QueryScopeInfo, String>>, Map<Meter, Tuple2<QueryScopeInfo, String>>) - Method in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricDumpSerializer
-
Serializes the given metrics and returns the resulting byte array.
- serialize(JobID, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.JobIDSerializer
- serialize(DataOutputView) - Method in class org.apache.flink.streaming.api.operators.collect.CollectCoordinationRequest
- serialize(DataOutputView) - Method in class org.apache.flink.streaming.api.operators.collect.CollectCoordinationResponse
- serialize(CheckpointMetadata, DataOutputStream) - Method in interface org.apache.flink.runtime.checkpoint.metadata.MetadataSerializer
-
Serializes a savepoint or checkpoint metadata to an output stream.
- serialize(CheckpointMetadata, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV1Serializer
- serialize(CheckpointMetadata, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV2Serializer
- serialize(CheckpointMetadata, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV3Serializer
- serialize(CheckpointMetadata, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV4Serializer
- serialize(ResourceID, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.ResourceIDSerializer
- serialize(SlotSharingGroupId, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.SlotSharingGroupIDSerializer
- serialize(JobVertexID, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.JobVertexIDKeySerializer
- serialize(JobVertexID, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.JobVertexIDSerializer
- serialize(JobEvent) - Method in class org.apache.flink.runtime.jobmaster.event.GenericJobEventSerializer
- serialize(JobResult, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.JobResultSerializer
- serialize(CheckpointConfigInfo.ProcessingMode, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingModeSerializer
- serialize(AggregatedMetricsResponseBody, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetricsResponseBody.Serializer
- serialize(MetricCollectionResponseBody, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricCollectionResponseBody.Serializer
- serialize(JobConfigInfo, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.JobConfigInfo.Serializer
- serialize(JobPlanInfo.RawJson, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson.Serializer
- serialize(TriggerId, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.TriggerId.TriggerIdSerializer
- serialize(VoidNamespace, DataOutputView) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
- serialize(CommittableMessage<CommT>) - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageSerializer
- serialize(CoGroupedStreams.TaggedUnion<T1, T2>, DataOutputView) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
- serialize(IntervalJoinOperator.BufferEntry<T>, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
- serialize(TimerHeapInternalTimer<K, N>, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
- serialize(TimerHeapInternalTimer<K, N>, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
- serialize(GlobalWindow, DataOutputView) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
- serialize(TimeWindow, DataOutputView) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
- serialize(CommittableCollector<CommT>) - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollectorSerializer
- serialize(StreamElement, DataOutputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
- serialize(SerializedThrowable, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.SerializedThrowableSerializer
- serialize(SerializedValue<?>, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.SerializedValueSerializer
- serialize(Credentials) - Static method in class org.apache.flink.runtime.security.token.hadoop.HadoopDelegationTokenConverter
-
Serializes delegation tokens.
- serialize(T, DataOutputView) - Method in class org.apache.flink.runtime.state.JavaSerializer
- serializeAccumulatorResult(long, String, long, List<byte[]>) - Static method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
- serializeAllConfigs() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
Serialize all object configs synchronously.
- serializeAndTryOffload(T, JobID, BlobWriter) - Static method in interface org.apache.flink.runtime.blob.BlobWriter
-
Serializes the given value and offloads it to the BlobServer if its size exceeds the minimum offloading size of the BlobServer.
- SERIALIZED_UDF - Static variable in class org.apache.flink.streaming.api.graph.StreamConfig
- SERIALIZED_UDF_CLASS - Static variable in class org.apache.flink.streaming.api.graph.StreamConfig
-
Introduce serializedUdfClassName to avoid unnecessarily heavy
StreamConfig.getStreamOperatorFactory(java.lang.ClassLoader). - SerializedCheckpointException - Class in org.apache.flink.runtime.messages.checkpoint
-
Serialized checkpoint exception which wraps the checkpoint failure reason and its serialized throwable.
- SerializedCheckpointException(CheckpointException) - Constructor for class org.apache.flink.runtime.messages.checkpoint.SerializedCheckpointException
- SerializedCompositeKeyBuilder<K> - Class in org.apache.flink.runtime.state
-
Responsible for serialization of currentKey, currentGroup and namespace.
- SerializedCompositeKeyBuilder(TypeSerializer<K>, int, int) - Constructor for class org.apache.flink.runtime.state.SerializedCompositeKeyBuilder
- serializedCounters - Variable in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
- serializedGauges - Variable in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
- serializedHistograms - Variable in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
- SerializedInputSplit - Class in org.apache.flink.runtime.jobmaster
- SerializedInputSplit(byte[]) - Constructor for class org.apache.flink.runtime.jobmaster.SerializedInputSplit
- SerializedJobExecutionResult - Class in org.apache.flink.runtime.client
-
A variant of the
JobExecutionResultthat holds its accumulator data in serialized form. - SerializedJobExecutionResult(JobID, long, Map<String, SerializedValue<OptionalFailure<Object>>>) - Constructor for class org.apache.flink.runtime.client.SerializedJobExecutionResult
-
Creates a new SerializedJobExecutionResult.
- serializedMeters - Variable in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
- serializedThrowable(SerializedThrowable) - Method in class org.apache.flink.runtime.jobmaster.JobResult.Builder
- SerializedThrowableDeserializer - Class in org.apache.flink.runtime.rest.messages.json
-
JSON deserializer for
SerializedThrowable. - SerializedThrowableDeserializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.SerializedThrowableDeserializer
- SerializedThrowableSerializer - Class in org.apache.flink.runtime.rest.messages.json
-
JSON serializer for
SerializedThrowable. - SerializedThrowableSerializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.SerializedThrowableSerializer
- SerializedUpdateBuffer - Class in org.apache.flink.runtime.iterative.io
-
AbstractPagedOutputViewused by theBlockingBackChannelfor transmitting superstep results. - SerializedUpdateBuffer() - Constructor for class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
- SerializedUpdateBuffer(List<MemorySegment>, int, IOManager) - Constructor for class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
- serializedValue - Variable in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.NonOffloaded
-
The serialized value.
- SerializedValueDeserializer - Class in org.apache.flink.runtime.rest.messages.json
-
JSON deserializer for
SerializedValue. - SerializedValueDeserializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.SerializedValueDeserializer
- SerializedValueDeserializer(JavaType) - Constructor for class org.apache.flink.runtime.rest.messages.json.SerializedValueDeserializer
- serializedValueKey - Variable in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.Offloaded
-
The key of the offloaded value BLOB.
- SerializedValueSerializer - Class in org.apache.flink.runtime.rest.messages.json
-
JSON serializer for
SerializedValue. - SerializedValueSerializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.SerializedValueSerializer
- SerializedValueSerializer(JavaType) - Constructor for class org.apache.flink.runtime.rest.messages.json.SerializedValueSerializer
- serializeInputChannelStateHandle(InputChannelStateHandle, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV2V3SerializerBase
- serializeInputChannelStateHandle(InputChannelStateHandle, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV3Serializer
- serializeKeyedStateHandleUtil(KeyedStateHandle, DataOutputStream) - Static method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV3Serializer
- serializeKeyGroup(int, byte[]) - Static method in class org.apache.flink.runtime.state.CompositeKeySerializationUtils
- serializeList(List<T>, TypeSerializer<T>) - Method in class org.apache.flink.runtime.state.ListDelimitedSerializer
- serializeMasterState(MasterState, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV2V3SerializerBase
- serializeMetadata(CheckpointMetadata, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV2V3SerializerBase
- serializeOperatorState(OperatorState, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV2Serializer
- serializeOperatorState(OperatorState, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV2V3SerializerBase
- serializeOperatorState(OperatorState, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV3Serializer
- serializeOperatorState(OperatorState, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV5Serializer
- serializeOperatorStateHandleUtil(OperatorStateHandle, DataOutputStream) - Static method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV3Serializer
- serializeOrDiscard(StateObject) - Static method in class org.apache.flink.runtime.util.StateHandleStoreUtils
-
Serializes the passed
StateObjectand discards the state in case of failure. - serializer - Variable in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
- serializer - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
- serializer - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
- Serializer() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetricsResponseBody.Serializer
- Serializer() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.MetricCollectionResponseBody.Serializer
- Serializer() - Constructor for class org.apache.flink.runtime.rest.messages.JobConfigInfo.Serializer
- Serializer() - Constructor for class org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson.Serializer
- Serializer() - Constructor for class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
- Serializer() - Constructor for class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
- serializer1 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
- serializer2 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
- serializeRecord(DataOutputSerializer, IOReadableWritable) - Static method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
- serializeResultSubpartitionStateHandle(ResultSubpartitionStateHandle, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV2V3SerializerBase
- serializeResultSubpartitionStateHandle(ResultSubpartitionStateHandle, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV3Serializer
- serializerFactory - Variable in class org.apache.flink.runtime.state.DefaultKeyedStateStore
- serializeShuffleDescriptors(TaskDeploymentDescriptorFactory.ShuffleDescriptorSerializer) - Method in class org.apache.flink.runtime.deployment.CachedShuffleDescriptors
- serializeStreamStateHandle(StreamStateHandle, DataOutputStream) - Static method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV3Serializer
- serializeSubtaskState(OperatorSubtaskState, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV2Serializer
- serializeSubtaskState(OperatorSubtaskState, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV2V3SerializerBase
- serializeSubtaskState(OperatorSubtaskState, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.metadata.MetadataV3Serializer
- serializeTaskStateSnapshot(TaskStateSnapshot) - Static method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
- serverAddress - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
- service - Variable in class org.apache.flink.runtime.jobmaster.slotpool.AbstractServiceConnectionManager
- ServiceConnectionManager<S> - Interface in org.apache.flink.runtime.jobmaster
-
Base interface for managers of services that are explicitly connected to / disconnected from.
- serviceName() - Method in class org.apache.flink.runtime.security.token.hadoop.HadoopDelegationTokenReceiver
- serviceName() - Method in class org.apache.flink.runtime.security.token.hadoop.HadoopFSDelegationTokenProvider
- serviceName() - Method in class org.apache.flink.runtime.security.token.hadoop.HadoopFSDelegationTokenReceiver
- serviceName() - Method in class org.apache.flink.runtime.security.token.hadoop.HBaseDelegationTokenProvider
- serviceName() - Method in class org.apache.flink.runtime.security.token.hadoop.HBaseDelegationTokenReceiver
- SessionClusterEntrypoint - Class in org.apache.flink.runtime.entrypoint
-
Base class for session cluster entry points.
- SessionClusterEntrypoint(Configuration) - Constructor for class org.apache.flink.runtime.entrypoint.SessionClusterEntrypoint
- SessionDispatcherFactory - Enum in org.apache.flink.runtime.dispatcher
-
DispatcherFactorywhich creates aStandaloneDispatcher. - SessionDispatcherLeaderProcess - Class in org.apache.flink.runtime.dispatcher.runner
-
Process which encapsulates the job recovery logic and life cycle management of a
Dispatcher. - SessionDispatcherLeaderProcessFactory - Class in org.apache.flink.runtime.dispatcher.runner
-
Factory for the
SessionDispatcherLeaderProcess. - SessionDispatcherLeaderProcessFactory(AbstractDispatcherLeaderProcess.DispatcherGatewayServiceFactory, JobPersistenceComponentFactory, Executor, FatalErrorHandler) - Constructor for class org.apache.flink.runtime.dispatcher.runner.SessionDispatcherLeaderProcessFactory
- SessionDispatcherLeaderProcessFactoryFactory - Class in org.apache.flink.runtime.dispatcher.runner
-
Factory for the
SessionDispatcherLeaderProcessFactory. - SessionRestEndpointFactory - Enum in org.apache.flink.runtime.rest
-
RestEndpointFactorywhich creates aDispatcherRestEndpoint. - set(int) - Method in class org.apache.flink.runtime.operators.util.BitSet
-
Sets the bit at specified index.
- set(E) - Method in class org.apache.flink.runtime.util.SingleElementIterator
-
Resets the element.
- set(T, F) - Method in class org.apache.flink.streaming.util.typeutils.FieldAccessor
-
Sets the field (specified in the constructor) of the given record to the given value.
- setAbsoluteTimestamp(long) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
- setAccumulators(Map<String, Accumulator<?, ?>>) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Update accumulators (discarded when the Execution has already been terminated).
- setAlignedCheckpointTimeout(long) - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration.CheckpointCoordinatorConfigurationBuilder
- setAlignedCheckpointTimeout(Duration) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Only relevant if
CheckpointingOptions.ENABLE_UNALIGNEDis enabled. - setAlignedCheckpointTimeout(Duration) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setAlignmentDurationNanos(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetricsBuilder
- setAlignmentDurationNanos(CompletableFuture<Long>) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetricsBuilder
- setAllocator(ByteBufAllocator) - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Sets the buffer allocator for use in netty.
- setAllocator(ByteBufAllocator) - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- setAllocator(ByteBufAllocator) - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- setAllocator(ByteBufAllocator) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- setAllocator(ByteBufAllocator) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- setAllVerticesInSameSlotSharingGroupByDefault(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
-
Set whether to put all vertices into the same slot sharing group by default.
- setAndSerializeTransitiveChainedTaskConfigs(Map<Integer, StreamConfig>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setAsyncDurationMillis(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetricsBuilder
- setAsyncKeyedContextElement(StreamRecord<T>, KeySelector<T, ?>) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperator
- setAsyncKeyedContextElement(StreamRecord<T>, KeySelector<T, ?>) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperatorV2
- setAsyncKeyedContextElement(StreamRecord<T>, KeySelector<T, ?>) - Method in interface org.apache.flink.streaming.runtime.operators.asyncprocessing.AsyncStateProcessingOperator
-
Set key context for async state processing.
- setAsyncOperationsThreadPool(ExecutorService) - Method in interface org.apache.flink.runtime.execution.Environment
- setAsyncOperationsThreadPool(ExecutorService) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- setAttemptCount(JobVertexID, int, int) - Method in class org.apache.flink.runtime.executiongraph.DefaultVertexAttemptNumberStore
- setAttemptCount(JobVertexID, int, int) - Method in interface org.apache.flink.runtime.executiongraph.MutableVertexAttemptNumberStore
-
Sets the attempt count for the given subtask of the given vertex.
- setAttribute(Integer, Attribute) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setAttribute(Attribute) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setAttribute(Attribute) - Method in class org.apache.flink.streaming.api.graph.StreamNode
- setAutoParallelismEnabled(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setBacklog(boolean) - Method in class org.apache.flink.streaming.runtime.streamrecord.RecordAttributesBuilder
- setBitsLocation(MemorySegment, int) - Method in class org.apache.flink.runtime.operators.util.BloomFilter
- setBlobServerAddress(InetSocketAddress) - Method in class org.apache.flink.runtime.blob.AbstractBlobCache
-
Sets the address of the
BlobServer. - setBlobServerAddress(InetSocketAddress) - Method in class org.apache.flink.runtime.blob.BlobCacheService
-
Sets the address of the
BlobServer. - setBlobServerAddress(InetSocketAddress) - Method in interface org.apache.flink.runtime.blob.TaskExecutorBlobService
-
Sets the blob server address.
- setBoundedness(Boundedness) - Method in class org.apache.flink.streaming.api.transformations.LegacySourceTransformation
-
Mutable for legacy sources in the Table API.
- setBroadcastGateIterativeWithNumberOfEventsUntilInterrupt(int, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setBroadcastInputName(String, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setBroadcastInputSerializer(TypeSerializerFactory<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setBroadcastVariable(String, BroadcastVariableMaterialization<?, ?>) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
- setBufferPool(BufferPool) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the buffering timeout for data produced by this operation.
- setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the maximum time frequency (milliseconds) for the flushing of the output buffers.
- setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.graph.StreamEdge
- setBufferTimeout(Integer, long) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setBufferTimeout(Long) - Method in class org.apache.flink.streaming.api.graph.StreamNode
- setByteChannelBufferHeader(Buffer, ByteBuffer) - Static method in class org.apache.flink.runtime.io.network.partition.BufferReaderWriterUtil
- setBytes(int, byte[], int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- setBytes(int, InputStream, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- setBytes(int, ByteBuffer) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- setBytes(int, FileChannel, long, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- setBytes(int, ScatteringByteChannel, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- setBytes(int, ByteBuf, int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- setBytesPersistedDuringAlignment(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetricsBuilder
- setBytesPersistedOfThisCheckpoint(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetricsBuilder
- setBytesProcessedDuringAlignment(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetricsBuilder
- setBytesProcessedDuringAlignment(CompletableFuture<Long>) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetricsBuilder
- setCached(boolean) - Method in class org.apache.flink.streaming.api.transformations.CacheTransformation
- setCancellerHandle(ScheduledFuture<?>) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
Sets the handle for the canceller to this pending checkpoint.
- setChainedOutputs(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setChainEnd() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setChainIndex(int) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
- setChainingStrategy(ChainingStrategy) - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
-
Set the chaining strategy for operator factory.
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.LegacySinkTransformation
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.LegacySourceTransformation
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.PhysicalTransformation
-
Sets the chaining strategy of this
Transformation. - setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.ReduceTransformation
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.TimestampsAndWatermarksTransformation
- setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
- setChainStart() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setChangelogStateBackendEnabled(TernaryBoolean) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setChannelInfo(InputChannelInfo) - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
- setChannelSelector(ChannelSelector<T>) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriterBuilder
- setChannelStateWriter(ChannelStateWriter) - Method in interface org.apache.flink.runtime.io.network.partition.ChannelStateHolder
-
Injects the
ChannelStateWriter. - setChannelStateWriter(ChannelStateWriter) - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
- setChannelStateWriter(ChannelStateWriter) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RecoveredInputChannel
- setChannelStateWriter(ChannelStateWriter) - Method in class org.apache.flink.runtime.io.network.partition.PipelinedResultPartition
- setChannelStateWriter(ChannelStateWriter) - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartition
- setChannelStateWriter(ChannelStateWriter) - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
- setCheckpointIdOfIgnoredInFlightData(long) - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration.CheckpointCoordinatorConfigurationBuilder
- setCheckpointIdOfIgnoredInFlightData(long) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Setup the checkpoint id for which the in-flight data will be ignored for all operators in case of the recovery from this checkpoint.
- setCheckpointingConsistencyMode(CheckpointingMode) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the checkpointing consistency mode (exactly-once vs. at-least-once).
- setCheckpointingEnabled(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setCheckpointingMode(CheckpointingMode) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Deprecated.
- setCheckpointInterval(long) - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration.CheckpointCoordinatorConfigurationBuilder
- setCheckpointInterval(long) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the interval in which checkpoints are periodically scheduled.
- setCheckpointIntervalDuringBacklog(long) - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration.CheckpointCoordinatorConfigurationBuilder
- setCheckpointIntervalDuringBacklog(long) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the interval in which checkpoints are periodically scheduled during backlog.
- setCheckpointMode(CheckpointingMode) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setCheckpointRetentionPolicy(CheckpointRetentionPolicy) - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration.CheckpointCoordinatorConfigurationBuilder
- setCheckpointStartDelayNanos(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetricsBuilder
- setCheckpointStorage(CheckpointStorage) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setCheckpointStorage(CheckpointStorage) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setCheckpointStorageAccess(CheckpointStorageAccess) - Method in interface org.apache.flink.runtime.execution.Environment
- setCheckpointStorageAccess(CheckpointStorageAccess) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- setCheckpointTargetLocation(CheckpointStorageLocation) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
- setCheckpointTimeout(long) - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration.CheckpointCoordinatorConfigurationBuilder
- setCheckpointTimeout(long) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the maximum time that a checkpoint may take before being discarded.
- setCheckpointTrigger(ExternallyInducedSource.CheckpointTrigger) - Method in interface org.apache.flink.streaming.api.checkpoint.ExternallyInducedSource
-
Deprecated.Sets the checkpoint trigger through which the source can trigger the checkpoint.
- setClasspaths(List<URL>) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Sets the classpaths required to run the job on a task manager.
- setCleanUpInterval(Duration) - Method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexThreadInfoTrackerBuilder
-
Sets
cleanUpInterval. - setCoLocationGroup(String) - Method in class org.apache.flink.streaming.api.graph.StreamNode
- setCommitterUidHash(String) - Method in class org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes.SinkOperatorUidHashesBuilder
-
Sets the uid hash of the committer operator used to recover state.
- setCommonBindAddress(String) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
- setCompressed(boolean) - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Tags the buffer as compressed or uncompressed.
- setCompressed(boolean) - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- setCompressed(boolean) - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- setCompressed(boolean) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- setCompressed(boolean) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- setConfiguration(Configuration) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
- setConnectionId(ConnectionID) - Method in interface org.apache.flink.runtime.io.network.NetworkClientHandler
- setConnectionType(StreamPartitioner<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Internal function for setting the partitioner for the DataStream.
- setConnectionType(StreamPartitioner<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
- setConsumeClusterDatasetId(IntermediateDataSetID) - Method in class org.apache.flink.streaming.api.graph.StreamNode
- setConsumedPartitionGroup(ConsumedPartitionGroup) - Method in class org.apache.flink.runtime.scheduler.strategy.ConsumerVertexGroup
- setConsumerVertexGroup(ConsumerVertexGroup) - Method in class org.apache.flink.runtime.scheduler.strategy.ConsumedPartitionGroup
- setContentTypeHeader(HttpResponse, File) - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
-
Sets the content type header for the HTTP Response.
- setConvergenceCriterion(String, ConvergenceCriterion<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setCoordinator(ThreadInfoRequestCoordinator) - Method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexThreadInfoTrackerBuilder
-
Sets
cleanUpInterval. - setCoordinatorListeningID(String) - Method in class org.apache.flink.streaming.api.operators.SourceOperatorFactory
- setCoordinatorListeningID(String) - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
- setCoordinatorState(ByteStreamStateHandle) - Method in class org.apache.flink.runtime.checkpoint.FullyFinishedOperatorState
- setCoordinatorState(ByteStreamStateHandle) - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- setCount(long) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
-
Sets the current checkpoint ID.
- setCount(long) - Method in enum org.apache.flink.runtime.checkpoint.DeactivatedCheckpointIDCounter
- setCount(long) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
- setCount(long) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
- setCpuCores(double) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
- setCpuCores(double) - Method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec.Builder
- setCpuCores(CPUResource) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
- setCurrentContext(RecordContext<K>) - Method in class org.apache.flink.runtime.asyncprocessing.AsyncExecutionController
-
Each time before a code segment (callback) is about to run in mailbox (task thread), this method should be called to switch a context in AEC.
- setCurrentKey(Object) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- setCurrentKey(Object) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- setCurrentKey(Object) - Method in interface org.apache.flink.streaming.api.operators.KeyContext
- setCurrentKey(Object) - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
- setCurrentKey(K) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- setCurrentKey(K) - Method in interface org.apache.flink.runtime.state.InternalKeyContext
-
Set current key of the context.
- setCurrentKey(K) - Method in class org.apache.flink.runtime.state.InternalKeyContextImpl
- setCurrentKey(K) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
-
Sets the current key that is used for partitioned state.
- setCurrentKey(K) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeService
- setCurrentKey(K) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
- setCurrentKeyAndKeyGroup(K, int) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- setCurrentKeyAndKeyGroup(K, int) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
-
Act as a fast path for
KeyedStateBackend.setCurrentKey(K)when the key group is known. - setCurrentKeyAndKeyGroup(K, int) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
- setCurrentKeyGroupIndex(int) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- setCurrentKeyGroupIndex(int) - Method in interface org.apache.flink.runtime.state.InternalKeyContext
-
Set current key group index of the context.
- setCurrentKeyGroupIndex(int) - Method in class org.apache.flink.runtime.state.InternalKeyContextImpl
- setCurrentNamespace(N) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
- setCurrentNamespace(N) - Method in interface org.apache.flink.runtime.state.internal.InternalKvState
-
Sets the current namespace, which will be used when using the state access methods.
- setCurrentNamespace(N) - Method in class org.apache.flink.runtime.state.v2.AbstractKeyedState
- setCurrentNamespace(N) - Method in class org.apache.flink.runtime.state.v2.adaptor.StateAdaptor
- setCurrentNamespace(N) - Method in interface org.apache.flink.runtime.state.v2.internal.InternalPartitionedState
-
Set current namespace and access state under specified namespace afterward.
- setCurrentNamespaceForState(InternalPartitionedState<N>, N) - Method in class org.apache.flink.runtime.asyncprocessing.AsyncExecutionController
- setCurrentNamespaceForState(InternalPartitionedState<N>, N) - Method in interface org.apache.flink.runtime.asyncprocessing.StateRequestHandler
-
Set current namespace for a state.
- setCurrentPendingCommittablesGauge(Gauge<Integer>) - Method in class org.apache.flink.runtime.metrics.groups.InternalSinkCommitterMetricGroup
- setCurrentSendTimeGauge(Gauge<Long>) - Method in class org.apache.flink.runtime.metrics.groups.InternalSinkWriterMetricGroup
- setCurrentWatermark(long) - Method in class org.apache.flink.streaming.runtime.metrics.WatermarkGauge
- setCustomHeaders(Collection<HttpHeader>) - Method in class org.apache.flink.runtime.rest.messages.CustomHeadersDecorator
-
Sets the custom headers for the message.
- setDataType(Buffer.DataType) - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Sets the type of data this buffer represents.
- setDataType(Buffer.DataType) - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
Sets the data type of the internal buffer.
- setDataType(Buffer.DataType) - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- setDataType(Buffer.DataType) - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- setDataType(Buffer.DataType) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- setDataType(Buffer.DataType) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- setDateAndCacheHeaders(HttpResponse, File) - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
-
Sets the "date" and "cache" headers for the HTTP Response.
- setDateHeader(FullHttpResponse) - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
-
Sets the "date" header for the HTTP response.
- setDefaultLocalParallelism(int) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the default parallelism that will be used for the local execution environment created by
StreamExecutionEnvironment.createLocalEnvironment(). - setDefaultSavepointDirectory(String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the default savepoint directory, where savepoints will be written to if no is explicitly provided when triggered.
- setDefaultSavepointDirectory(URI) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the default savepoint directory, where savepoints will be written to if no is explicitly provided when triggered.
- setDefaultSavepointDirectory(Path) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the default savepoint directory, where savepoints will be written to if no is explicitly provided when triggered.
- setDefaultValue(SV) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
- setDelayBetweenSamples(Duration) - Method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexThreadInfoTrackerBuilder
-
Sets
delayBetweenSamples. - setDescription(String) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Sets the description for this sink.
- setDescription(String) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the description for this operation.
- setDownstreamSubtaskStateMapper(SubtaskStateMapper) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Sets the channel state rescaler used for rescaling persisted data on downstream side of this JobEdge.
- setDriver(Class<? extends Driver>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setDriverComparator(TypeComparatorFactory<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setDriverPairComparator(TypePairComparatorFactory<?, ?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setDriverStrategy(DriverStrategy) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setDynamic(boolean) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
- setDynamic(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setDynamicParallelism(int) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- setEnableBusyTime(boolean) - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- setEnableCheckpointsAfterTasksFinish(boolean) - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration.CheckpointCoordinatorConfigurationBuilder
- setEnableCheckpointsAfterTasksFinish(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setEnabled(boolean) - Method in class org.apache.flink.runtime.state.metrics.LatencyTrackingStateConfig.Builder
- setEndOffsetExclusive(long) - Method in class org.apache.flink.runtime.state.BoundedInputStream
- setError(Throwable) - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Atomically sets an error for this channel and notifies the input gate about available data to trigger querying this channel by the task thread.
- setEventTimeTimers(Set<TimerHeapInternalTimer<K, N>>) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
- setExactlyOnce(boolean) - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration.CheckpointCoordinatorConfigurationBuilder
- setExecutionConfig(ExecutionConfig) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Sets the execution config.
- setExecutionConfig(ExecutionConfig) - Method in class org.apache.flink.runtime.jobgraph.JobGraphBuilder
- setExtendedResource(ExternalResource) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
-
Add the given extended resource.
- setExtendedResource(ExternalResource) - Method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec.Builder
-
Add the given extended resource.
- setExtendedResources(Collection<ExternalResource>) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
-
Add the given extended resources.
- setExtendedResources(Collection<ExternalResource>) - Method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec.Builder
-
Add the given extended resources.
- setExternalizedCheckpointRetention(ExternalizedCheckpointRetention) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the mode for externalized checkpoint clean-up.
- setExtra(Object) - Method in class org.apache.flink.runtime.asyncprocessing.RecordContext
- setFailUnfulfillableRequest(boolean) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
Set
SlotManagerwhether to fail unfulfillable slot requests. - setFailUnfulfillableRequest(boolean) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedSlotManager
- setFailUnfulfillableRequest(boolean) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
- setField(TtlValue<T>, int, Object) - Method in class org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
- setFilehandlesDriver(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setFilehandlesInput(int, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setFilePoolType(PhysicalFilePool.Type) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBuilder
-
Set the type of physical file pool.
- setForceUnalignedCheckpoints(boolean) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Checks whether unaligned checkpoints are forced, despite currently non-checkpointable iteration feedback or custom partitioners.
- setFormatDescription(OperatorID, String) - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatVertex
- setForward(boolean) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Sets whether the edge is forward edge.
- setFurtherPatitioning(boolean) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
- setGateIterativeWithNumberOfEventsUntilInterrupt(int, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setGlobalCommitterUidHash(String) - Method in class org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes.SinkOperatorUidHashesBuilder
-
Sets the uid hash of the global committer operator used to recover state.
- setGlobalFailureCause(Throwable, long) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- setGlobalStreamExchangeMode(GlobalStreamExchangeMode) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setGraphContainingLoops(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setHaServices(MiniCluster.HaServices) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
- setHistorySize(int) - Method in class org.apache.flink.runtime.state.metrics.LatencyTrackingStateConfig.Builder
- setImplicitConvergenceCriterion(String, ConvergenceCriterion<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
Sets the default convergence criterion of a
DeltaIteration - setInitialClientHeartbeatTimeout(long) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
- setInitialState(JobManagerTaskRestore) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Sets the initial state for the execution.
- setInPhysicalEdges(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setInputAsynchronouslyMaterialized(int, boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setInputBytes(long) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- setInputCached(int, boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setInputChannels(InputChannel...) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- setInputChannelState(StateObjectCollection<InputChannelStateHandle>) - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState.Builder
- setInputChannelStateFuture(Future<SnapshotResult<StateObjectCollection<InputChannelStateHandle>>>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
- setInputComparator(TypeComparatorFactory<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setInputFormat(Integer, InputFormat<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setInputFormat(InputFormat<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
- setInputLocalStrategy(int, LocalStrategy) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setInputRescalingDescriptor(InflightDataRescalingDescriptor) - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState.Builder
- setInputs(StreamConfig.InputConfig...) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setInputSerializer(TypeSerializerFactory<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setInputSplitSource(InputSplitSource<?>) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.OutputFormatSinkFunction
-
Deprecated.
- setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
- setInputType(TypeInformation<?>, ExecutionConfig) - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
-
Is called by the
StreamGraph.addOperator(java.lang.Integer, java.lang.String, java.lang.String, org.apache.flink.streaming.api.operators.StreamOperatorFactory<OUT>, org.apache.flink.api.common.typeinfo.TypeInformation<IN>, org.apache.flink.api.common.typeinfo.TypeInformation<OUT>, java.lang.String)method when theStreamGraphis generated. - setInstance(T) - Method in interface org.apache.flink.runtime.plugable.DeserializationDelegate
- setInstance(T) - Method in class org.apache.flink.runtime.plugable.NonReusingDeserializationDelegate
- setInstance(T) - Method in class org.apache.flink.runtime.plugable.ReusingDeserializationDelegate
- setInstance(T) - Method in class org.apache.flink.runtime.plugable.SerializationDelegate
- setInternalIndex(int) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueueElement
- setInternalIndex(int) - Method in interface org.apache.flink.runtime.state.heap.HeapPriorityQueueElement
-
Sets the current index of this object in the
HeapPriorityQueueand should only be called by the owningHeapPriorityQueue. - setInternalIndex(int) - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
- setInternalIndex(int) - Method in class org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve.SubpartitionStatus
- setInternalSorterSupported(boolean) - Method in class org.apache.flink.streaming.api.operators.OperatorAttributesBuilder
- setInternalTaskFailuresListener(InternalFailuresListener) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- setInternalTaskFailuresListener(InternalFailuresListener) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- setInvokableClass(Class<? extends TaskInvokable>) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- setIOExecutor(Executor) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBuilder
-
Set the executor for io operation in manager.
- setIsCompacted(boolean) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
sets compaction status (should only be set
truedirectly after compaction andfalsewhen garbage was created) - setIsJobRestarting(boolean) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolBridge
-
To set whether the underlying is currently restarting or not.
- setIsJobRestarting(boolean) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Sets whether the underlying job is currently restarting or not.
- setIsProcessingBacklog(boolean) - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinatorContext
- setIsProcessingBacklog(OperatorID, boolean) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Reports whether a source operator is currently processing backlog.
- setIsSolutionSetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setIsSolutionSetUpdateWithoutReprobe() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setIsWorksetIteration() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setIsWorksetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setIterationHeadFinalOutputConfig(TaskConfig) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setIterationHeadIndexOfSyncOutput(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setIterationHeadPartialSolutionOrWorksetInputIndex(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setIterationHeadSolutionSetInputIndex(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setIterationId(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setIterationId(String) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setIterationWaitTime(long) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setIterativeReader() - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
- setIterativeReader() - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
- setJarURLsToConfig(String[], Configuration) - Static method in class org.apache.flink.streaming.util.RemoteEnvironmentConfigUtils
- setJobCheckpointingSettings(JobCheckpointingSettings) - Method in class org.apache.flink.runtime.jobgraph.JobGraphBuilder
- setJobClient(JobClient) - Method in class org.apache.flink.streaming.api.operators.collect.CollectResultFetcher
- setJobClient(JobClient) - Method in class org.apache.flink.streaming.api.operators.collect.CollectResultIterator
- setJobConfiguration(Configuration) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
- setJobConfiguration(Configuration) - Method in class org.apache.flink.runtime.jobgraph.JobGraphBuilder
- setJobId(JobID) - Method in class org.apache.flink.runtime.jobgraph.JobGraphBuilder
- setJobID(JobID) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Sets the ID of the job.
- setJobManagerAddressToConfig(String, int, Configuration) - Static method in class org.apache.flink.streaming.util.RemoteEnvironmentConfigUtils
- setJobName(String) - Method in class org.apache.flink.runtime.jobgraph.JobGraphBuilder
- setJobName(String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setJobStatusHooks(List<JobStatusHook>) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
- setJobType(JobType) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
- setJobType(JobType) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setJsonPlan(String) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- setJsonPlan(String) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- setKeyAndKeyGroup(K, int) - Method in class org.apache.flink.runtime.state.SerializedCompositeKeyBuilder
-
Sets the key and key-group as prefix.
- setKeyContextElement(StreamRecord<IN>) - Method in interface org.apache.flink.streaming.api.operators.Input
-
Set the correct key context before processing the
record. - setKeyContextElement(StreamRecord<IN>) - Method in interface org.apache.flink.streaming.api.operators.OneInputStreamOperator
- setKeyContextElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOnRestoreInput
- setKeyContextElement1(StreamRecord) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperator
- setKeyContextElement1(StreamRecord) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- setKeyContextElement1(StreamRecord<?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- setKeyContextElement1(StreamRecord<?>) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
- setKeyContextElement2(StreamRecord) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperator
- setKeyContextElement2(StreamRecord) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- setKeyContextElement2(StreamRecord<?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- setKeyContextElement2(StreamRecord<?>) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
- setKeyedStateManagedFuture(RunnableFuture<SnapshotResult<KeyedStateHandle>>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
- setKeyedStateRawFuture(RunnableFuture<SnapshotResult<KeyedStateHandle>>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
- setKeyedStateStore(KeyedStateStore) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
- setKeyedStateStoreV2(KeyedStateStoreV2) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
- setKeyGroupOffset(int, long) - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
-
Sets the offset for the given key-group.
- setKeySerializerSnapshot(TypeSerializerSnapshot<K>) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
- setLastOutputCollector(Collector<OT>) - Method in class org.apache.flink.runtime.operators.BatchTask
-
Sets the last output
Collectorof the collector chain of thisBatchTask. - setLatencyMeasurementInterval(int) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
- setLineageGraph(LineageGraph) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setLineageVertex(LineageVertex) - Method in class org.apache.flink.streaming.api.transformations.TransformationWithLineage
-
Change the lineage vertex of this
Transformation. - setMailboxExecutor(MailboxExecutor) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- setMailboxExecutor(MailboxExecutor) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
- setMailboxExecutor(MailboxExecutor) - Method in interface org.apache.flink.streaming.api.operators.legacy.YieldingOperatorFactory
-
Deprecated.
- setMailboxExecutor(MailboxExecutor) - Method in interface org.apache.flink.streaming.api.operators.YieldingOperator
- setMainMailboxExecutor(MailboxExecutor) - Method in interface org.apache.flink.runtime.execution.Environment
- setMainMailboxExecutor(MailboxExecutor) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
- setManagedKeyedState(StateObjectCollection<KeyedStateHandle>) - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState.Builder
- setManagedKeyedState(KeyedStateHandle) - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState.Builder
- setManagedMemory(MemorySize) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
- setManagedMemoryFractionOperatorOfUseCase(ManagedMemoryUseCase, double) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
Fraction of managed memory reserved for the given use case that this operator should use.
- setManagedMemoryMB(int) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
- setManagedMemoryMB(int) - Method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec.Builder
- setManagedMemoryUseCaseWeights(int, Map<ManagedMemoryUseCase, Integer>, Set<ManagedMemoryUseCase>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setManagedMemoryUseCaseWeights(Map<ManagedMemoryUseCase, Integer>, Set<ManagedMemoryUseCase>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
- setManagedOperatorState(StateObjectCollection<OperatorStateHandle>) - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState.Builder
- setManagedOperatorState(OperatorStateHandle) - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState.Builder
- setMaxConcurrentCheckpoints(int) - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration.CheckpointCoordinatorConfigurationBuilder
- setMaxConcurrentCheckpoints(int) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the maximum number of checkpoint attempts that may be in progress at the same time.
- setMaxConcurrentCheckpoints(int) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setMaxFileSize(long) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBuilder
-
Set the max file size.
- setMaxOverdraftBuffersPerGate(int) - Method in class org.apache.flink.runtime.io.network.api.writer.MultipleRecordWriters
- setMaxOverdraftBuffersPerGate(int) - Method in class org.apache.flink.runtime.io.network.api.writer.NonRecordWriter
- setMaxOverdraftBuffersPerGate(int) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
Sets the max overdraft buffer size of per gate.
- setMaxOverdraftBuffersPerGate(int) - Method in interface org.apache.flink.runtime.io.network.api.writer.RecordWriterDelegate
-
Sets the max overdraft buffer size of per gate.
- setMaxOverdraftBuffersPerGate(int) - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
Sets the max overdraft buffer size of per gate.
- setMaxOverdraftBuffersPerGate(int) - Method in class org.apache.flink.runtime.io.network.api.writer.SingleRecordWriter
- setMaxOverdraftBuffersPerGate(int) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
Sets the max overdraft buffer size of per gate.
- setMaxOverdraftBuffersPerGate(int) - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
- setMaxOverdraftBuffersPerGate(int) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- setMaxParallelism(int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- setMaxParallelism(int) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Sets the maximum parallelism for the task.
- setMaxParallelism(int) - Method in class org.apache.flink.runtime.scheduler.DefaultVertexParallelismInfo
- setMaxParallelism(int) - Method in interface org.apache.flink.runtime.scheduler.VertexParallelismInformation
-
Changes a given vertex's max parallelism property.
- setMaxParallelism(int) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Sets the max parallelism for this sink.
- setMaxParallelism(int) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the maximum parallelism of this operator.
- setMaxParallelism(int) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the maximum degree of parallelism defined for the program.
- setMaxParallelism(int, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setMaxSpaceAmplification(float) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBuilder
- setMaxSubtasksPerChannelStateFile(int) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
The number of subtasks to share the same channel state file.
- setMaxSubtasksPerChannelStateFile(int) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setMaxThreadInfoDepth(int) - Method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexThreadInfoTrackerBuilder
-
Sets
delayBetweenSamples. - setMemorySegment(MemorySegment, int) - Method in class org.apache.flink.runtime.operators.util.BitSet
- setMetaDataFollowsFlagInKey(byte[]) - Static method in class org.apache.flink.runtime.state.FullSnapshotUtil
- setMetaInfo(RegisteredKeyValueStateBackendMetaInfo<N, S>) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
- setMetaInfo(RegisteredKeyValueStateBackendMetaInfo<N, S>) - Method in class org.apache.flink.runtime.state.heap.StateTable
- setMetricGroup(MetricGroup) - Method in class org.apache.flink.runtime.state.metrics.LatencyTrackingStateConfig.Builder
- setMetricGroup(TaskIOMetricGroup) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
Sets the metric group for this RecordWriter.
- setMetricGroup(TaskIOMetricGroup) - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
Sets the metric group for the
ResultPartitionWriter. - setMetricGroup(TaskIOMetricGroup) - Method in class org.apache.flink.runtime.io.network.partition.BufferWritingResultPartition
- setMetricGroup(TaskIOMetricGroup) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartition
- setMetricGroup(TaskIOMetricGroup) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemoryManager
-
Set the
TaskIOMetricGroupfor this memory manager. - setMetricGroup(TaskIOMetricGroup) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemoryManagerImpl
- setMetricGroup(TaskIOMetricGroup) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- setMetricGroup(TaskManagerJobMetricGroup) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBuilder
- setMetricStatisticsUpdater(Consumer<TieredStorageProducerMetricUpdate>) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageProducerClient
- setMinPauseBetweenCheckpoints(long) - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration.CheckpointCoordinatorConfigurationBuilder
- setMinPauseBetweenCheckpoints(long) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
Sets the minimal pause between checkpointing attempts.
- setMoreAvailable(boolean) - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
- setMultipleInputStateKey(Integer, List<KeySelector<?, ?>>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setName(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Sets the name of the vertex.
- setNamespace(N, TypeSerializer<N>) - Method in class org.apache.flink.runtime.state.SerializedCompositeKeyBuilder
- setNamespace(InternalPartitionedState<N>, N) - Method in class org.apache.flink.runtime.asyncprocessing.RecordContext
- setNamespaceSerializer(TypeSerializer<N>) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
- setNamespaceSerializerSnapshot(TypeSerializerSnapshot<N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
- setNetworkMemory(MemorySize) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
- setNetworkMemoryMB(int) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
- setNetworkMemoryMB(int) - Method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec.Builder
- setNextBuffer(Buffer) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
- setNextBuffer(Buffer) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
- setNumberOfIterations(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setNumberOfNetworkInputs(int) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setNumberOfOutputs(int) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setNumBuffers(int) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
Sets the current size of this buffer pool.
- setNumBuffers(int) - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
- setNumRecordsOut(Counter) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
- setNumSamples(int) - Method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexThreadInfoTrackerBuilder
-
Sets
numSamples. - setNumSlots(int) - Method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec.Builder
- setNumSlotsPerTaskManager(int) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
- setNumTaskManagers(int) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
- setOneInputStateKey(Integer, KeySelector<?, ?>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setOperatorDescription(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- setOperatorDescription(String) - Method in class org.apache.flink.streaming.api.graph.StreamNode
- setOperatorEventGateway(OperatorEventGateway) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
- setOperatorID(OperatorID) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setOperatorLevelCachingDescription(String) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Sets the operator-level caching description for this input.
- setOperatorName(String) - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- setOperatorName(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- setOperatorName(String) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setOperatorNonChainedOutputs(List<NonChainedOutput>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
Sets the operator level non-chained outputs.
- setOperatorPrettyName(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- setOperatorStateManagedFuture(RunnableFuture<SnapshotResult<OperatorStateHandle>>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
- setOperatorStateRawFuture(RunnableFuture<SnapshotResult<OperatorStateHandle>>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
- setOperatorUid(String) - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- setOutputCollector(Collector<?>) - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
- setOutputComparator(TypeComparatorFactory<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setOutputDataDistribution(DataDistribution, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setOutputFormat(Integer, OutputFormat<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setOutputFormat(OutputFormat<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
- setOutputOnlyAfterEndOfStream(boolean) - Method in class org.apache.flink.streaming.api.operators.OperatorAttributesBuilder
-
Set to true if and only if the operator only emits records after all its inputs have ended.
- setOutputPartitioner(Partitioner<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setOutputRescalingDescriptor(InflightDataRescalingDescriptor) - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState.Builder
- setOutputSerializer(TypeSerializerFactory<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setOutputType(Function, TypeInformation<T>, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.functions.StreamingFunctionUtils
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateUdfStreamOperator
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperatorFactory
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.operators.SourceOperatorFactory
- setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorFactory
-
Is called by the
StreamGraph.addOperator(java.lang.Integer, java.lang.String, java.lang.String, org.apache.flink.streaming.api.operators.StreamOperatorFactory<OUT>, org.apache.flink.api.common.typeinfo.TypeInformation<IN>, org.apache.flink.api.common.typeinfo.TypeInformation<OUT>, java.lang.String)method when theStreamGraphis generated. - setOutputType(TypeInformation<T>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.source.legacy.FromElementsFunction
-
Deprecated.Set element type and re-serialize element if required.
- setParallelism(int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- setParallelism(int) - Method in class org.apache.flink.runtime.jobgraph.forwardgroup.ForwardGroup
- setParallelism(int) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Sets the parallelism for the task.
- setParallelism(int) - Method in class org.apache.flink.runtime.scheduler.DefaultVertexParallelismInfo
- setParallelism(int) - Method in interface org.apache.flink.runtime.scheduler.VertexParallelismInformation
-
Set a given vertex's parallelism property.
- setParallelism(int) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Sets the parallelism for this sink.
- setParallelism(int) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSource
- setParallelism(int) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the parallelism for this operator.
- setParallelism(int) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the parallelism for operations executed through this environment.
- setParallelism(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamNode
- setParallelism(Integer, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setParallelism(Integer, int, boolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setParallelismConfigured(boolean) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- setParallelismForJobVertex(JobVertexID, int, int) - Method in class org.apache.flink.runtime.jobgraph.JobResourceRequirements.Builder
- setParallelismInfo(JobVertexID, VertexParallelismInformation) - Method in class org.apache.flink.runtime.scheduler.DefaultVertexParallelismStore
- setParallelismInfo(JobVertexID, VertexParallelismInformation) - Method in interface org.apache.flink.runtime.scheduler.MutableVertexParallelismStore
-
Sets the parallelism properties for the given vertex.
- setPartition(int, IntermediateResultPartition) - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
- setPartitioner(StreamPartitioner<?>) - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
- setPartitioner(StreamPartitioner<?>) - Method in class org.apache.flink.streaming.api.graph.StreamEdge
- setPartitionNumber(int) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
overwrites partition number and should only be used on compaction partition
- setPartitionType(ResultPartitionType) - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
- setPendingBytesGauge(Gauge<Long>) - Method in class org.apache.flink.runtime.metrics.groups.InternalSourceReaderMetricGroup
- setPendingRecordsGauge(Gauge<Long>) - Method in class org.apache.flink.runtime.metrics.groups.InternalSourceReaderMetricGroup
- setPluginManager(PluginManager) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
- setPreProcessingOperationName(String) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Sets the name of the pre-processing operation for this input.
- setPreviousSerializerSnapshotForRestoredState(TypeSerializerSnapshot<T>) - Method in class org.apache.flink.runtime.state.StateSerializerProvider
-
For restored state, set the state's previous serializer's snapshot.
- setProcessingTimeService(AbstractStreamOperator<?>, ProcessingTimeService) - Static method in class org.apache.flink.streaming.api.operators.StreamOperatorUtils
- setProcessingTimeService(ProcessingTimeService) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- setProcessingTimeService(ProcessingTimeService) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorFactory
- setProcessingTimeService(ProcessingTimeService) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
- setProcessingTimeService(ProcessingTimeService) - Method in interface org.apache.flink.streaming.runtime.tasks.ProcessingTimeServiceAware
- setProcessingTimeTimers(Set<TimerHeapInternalTimer<K, N>>) - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshot
- setRawKeyedState(StateObjectCollection<KeyedStateHandle>) - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState.Builder
- setRawKeyedState(KeyedStateHandle) - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState.Builder
- setRawOperatorState(StateObjectCollection<OperatorStateHandle>) - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState.Builder
- setRawOperatorState(OperatorStateHandle) - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState.Builder
- setReaderIndex(int) - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Sets the reader index of this buffer.
- setReaderIndex(int) - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- setReaderIndex(int) - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- setReaderIndex(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- setReaderIndex(int) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- setReadPosition(long) - Method in class org.apache.flink.runtime.io.disk.RandomAccessInputView
- setReadPosition(long) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
- setRecycler(BufferRecycler) - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Sets the buffer's recycler.
- setRecycler(BufferRecycler) - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- setRecycler(BufferRecycler) - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- setRecycler(BufferRecycler) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- setRecycler(BufferRecycler) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- setReference(Tuple2<byte[], INPUT>) - Method in class org.apache.flink.streaming.api.operators.sortpartition.FixedLengthByteKeyAndValueComparator
- setReference(Tuple2<byte[], INPUT>) - Method in class org.apache.flink.streaming.api.operators.sortpartition.VariableLengthByteKeyAndValueComparator
- setRegisteredAsAvailable(boolean) - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
Updates the value to indicate whether the reader is enqueued in the pipeline or not.
- setRelativeBackChannelMemory(double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setRelativeInputMaterializationMemory(int, double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setRelativeMemoryDriver(double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setRelativeMemoryInput(int, double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setRelativeSolutionSetMemory(double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setResourceProfile(ResourceProfile) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
- setResourceRequirements(ResourceCounter) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPool
-
Sets the resource requirements to the given resourceRequirements.
- setResourceRequirements(ResourceCounter) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultDeclarativeSlotPool
- setResources(int, ResourceSpec, ResourceSpec) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setResources(ResourceSpec, ResourceSpec) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Sets the minimum and preferred resources for the task.
- setResources(ResourceSpec, ResourceSpec) - Method in class org.apache.flink.streaming.api.graph.StreamNode
- setResultOptimizerProperties(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- setResultSubpartitionState(StateObjectCollection<ResultSubpartitionStateHandle>) - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState.Builder
- setResultSubpartitionStateFuture(Future<SnapshotResult<StateObjectCollection<ResultSubpartitionStateHandle>>>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotFutures
- setRpcServiceSharing(RpcServiceSharing) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.sink.legacy.OutputFormatSinkFunction
-
Deprecated.
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
- setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
- setRuntimeMode(RuntimeExecutionMode) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Sets the runtime execution mode for the application (see
RuntimeExecutionMode). - setSampleInterval(int) - Method in class org.apache.flink.runtime.state.metrics.LatencyTrackingStateConfig.Builder
- setSavepointRestoreSettings(SavepointRestoreSettings) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Sets the savepoint restore settings.
- setSavepointRestoreSettings(SavepointRestoreSettings) - Method in class org.apache.flink.runtime.jobgraph.JobGraphBuilder
- setSavepointRestoreSettings(SavepointRestoreSettings) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setSavepointRestoreSettings(SavepointRestoreSettings) - Method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
- setSerializerOut(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
- setSerializers(Integer, TypeSerializer<?>, TypeSerializer<?>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setSerializersIn(TypeSerializer<?>...) - Method in class org.apache.flink.streaming.api.graph.StreamNode
- setShipStrategyName(String) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Sets the name of the ship strategy for the represented input.
- setSize(int) - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Sets the size of the written data, i.e. the writer index, of this buffer.
- setSize(int) - Method in class org.apache.flink.runtime.io.network.buffer.CompositeBuffer
- setSize(int) - Method in class org.apache.flink.runtime.io.network.buffer.FileRegionBuffer
- setSize(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- setSize(int) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- setSlotSharingGroup(String) - Method in class org.apache.flink.streaming.api.graph.StreamNode
- setSlotSharingGroup(SlotSharingGroup) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Associates this vertex with a slot sharing group for scheduling.
- setSlotSharingGroupResource(Map<String, ResourceProfile>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setSlotSharingGroupResource(Map<String, ResourceProfile>) - Method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
-
Specify fine-grained resource requirements for slot sharing groups.
- setSnapshotSettings(JobCheckpointingSettings) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Sets the settings for asynchronous snapshots.
- setSolutionSetComparator(TypeComparatorFactory<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setSolutionSetSerializer(TypeSerializerFactory<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setSolutionSetUnmanaged(boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setSpillingThresholdDriver(float) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setSpillingThresholdInput(int, float) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setSplitState(Serializable) - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
-
Sets the state of the split.
- setSplitState(Serializable) - Method in interface org.apache.flink.streaming.api.functions.source.TimestampedInputSplit
-
Sets the state of the split.
- setState(S, int) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap.StateMapEntry
- setStateBackend(StateBackend) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setStateBackend(StateBackend) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setStateBackendUsesManagedMemory(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setStateHandle(String, byte[], int) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
- setStateHandles(Collection<KeyedStateHandle>) - Method in class org.apache.flink.runtime.state.KeyedStateBackendParametersImpl
- setStateKeySelector(KeySelector<IN, ?>) - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
-
Sets the
KeySelectorthat must be used for partitioning keyed state of this operation. - setStateKeySelector(KeySelector<T, ?>) - Method in class org.apache.flink.streaming.api.transformations.LegacySinkTransformation
-
Sets the
KeySelectorthat must be used for partitioning keyed state of this Sink. - setStateKeySelectors(KeySelector<IN1, ?>, KeySelector<IN2, ?>) - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Sets the
KeySelectorsthat must be used for partitioning keyed state of this transformation. - setStateKeySerializer(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setStateKeySerializer(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
- setStateKeyType(TypeInformation<?>) - Method in class org.apache.flink.streaming.api.transformations.LegacySinkTransformation
- setStateKeyType(TypeInformation<?>) - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
- setStateKeyType(TypeInformation<?>) - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
- setStateMetaInfo(RegisteredBroadcastStateBackendMetaInfo<K, V>) - Method in interface org.apache.flink.runtime.state.BackendWritableBroadcastState
- setStateMetaInfo(RegisteredBroadcastStateBackendMetaInfo<K, V>) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
- setStateMetaInfo(RegisteredOperatorStateBackendMetaInfo<S>) - Method in class org.apache.flink.runtime.state.PartitionableListState
- setStateNameAsVariable(boolean) - Method in class org.apache.flink.runtime.state.metrics.LatencyTrackingStateConfig.Builder
- setStatePartitioner(int, KeySelector<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setStatePartitioners(KeySelector<?, ?>...) - Method in class org.apache.flink.streaming.api.graph.StreamNode
- setStateSerializer(TypeSerializer<S>) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
- setStatsRefreshInterval(Duration) - Method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexThreadInfoTrackerBuilder
-
Sets
statsRefreshInterval. - setStatus(InitializationStatus) - Method in class org.apache.flink.runtime.checkpoint.SubTaskInitializationMetricsBuilder
- setStreamOperator(StreamOperator<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setStreamOperatorFactory(StreamOperatorFactory<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setStrictlyCoLocatedWith(JobVertex) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Tells this vertex to strictly co locate its subtasks with the subtasks of the given vertex.
- setStubParameter(String, String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setStubParameters(Configuration) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setStubWrapper(UserCodeWrapper<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setSupportsConcurrentExecutionAttempts(boolean) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- setSupportsConcurrentExecutionAttempts(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamNode
- setSupportsConcurrentExecutionAttempts(boolean) - Method in class org.apache.flink.streaming.api.transformations.PhysicalTransformation
- setSupportsConcurrentExecutionAttempts(Integer, boolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setSupportsUnalignedCheckpoints(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamEdge
- setSyncDurationMillis(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetricsBuilder
- setSynchronousSavepoint(long) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- setTaskHeapMemory(MemorySize) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
- setTaskHeapMemoryMB(int) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
- setTaskHeapMemoryMB(int) - Method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec.Builder
- setTaskName(String) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriterBuilder
- setTaskName(String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setTaskOffHeapMemory(MemorySize) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
- setTaskOffHeapMemoryMB(int) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile.Builder
- setTaskOffHeapMemoryMB(int) - Method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec.Builder
- setTieredStorageService(List<TieredStorageConsumerSpec>, TieredStorageConsumerClient, TieredStorageNettyServiceImpl) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- setTimeout(long) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriterBuilder
- setTimerServiceProvider(InternalTimeServiceManager.Provider) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setTimerServiceProvider(InternalTimeServiceManager.Provider) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setTimestamp(long) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
- setTimestamp(StreamRecord<?>) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
- setTolerableCheckpointFailureNumber(int) - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration.CheckpointCoordinatorConfigurationBuilder
- setTolerableCheckpointFailureNumber(int) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
-
This defines how many consecutive checkpoint failures will be tolerated, before the whole job is failed over.
- setTotalBytesPersisted(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetricsBuilder
- setTransformationUID(Integer, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setTransitiveChainedTaskConfigs(Map<Integer, StreamConfig>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setTtlTimeProvider(TtlTimeProvider) - Method in class org.apache.flink.runtime.state.KeyedStateBackendParametersImpl
- setTwoInputStateKey(Integer, KeySelector<?, ?>, KeySelector<?, ?>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setTypeSerializerOut(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setTypeSerializerSideOut(OutputTag<?>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setUidHash(String) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Sets an user provided hash for this operator.
- setUidHash(String) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets an user provided hash for this operator.
- setUnalignedCheckpointsEnabled(boolean) - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration.CheckpointCoordinatorConfigurationBuilder
- setUnalignedCheckpointsEnabled(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setUnalignedCheckpointsSplittableTimersEnabled(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setUnassignedSplitsGauge(G) - Method in class org.apache.flink.runtime.metrics.groups.InternalSplitEnumeratorMetricGroup
- setup() - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
Setup partition, potentially heavy-weight, blocking operation comparing to just creation.
- setup() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
Setup gate, potentially heavy-weight, blocking operation comparing to just creation.
- setup() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- setup() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
- setup() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Registers a buffer pool with this result partition.
- setup() - Method in class org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrier
- setup() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
-
Setup the barrier, has to be called at the beginning of each superstep.
- setup() - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
- setup(int) - Method in interface org.apache.flink.runtime.io.network.api.writer.ChannelSelector
-
Initializes the channel selector with the number of output channels.
- setup(int) - Method in class org.apache.flink.runtime.io.network.api.writer.RoundRobinChannelSelector
- setup(int) - Method in class org.apache.flink.runtime.operators.shipping.OutputEmitter
- setup(int) - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
- setup(int) - Method in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
- setup(Configuration) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskTierFactory
- setup(Configuration) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory.MemoryTierFactory
- setup(Configuration) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierFactory
- setup(Configuration) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierFactory
-
Sets up the tier factory based on the
Configuration. - setup(StateRequestHandler) - Method in interface org.apache.flink.runtime.state.AsyncKeyedStateBackend
-
Initializes with some contexts.
- setup(StateRequestHandler) - Method in class org.apache.flink.runtime.state.v2.adaptor.AsyncKeyedStateBackendAdaptor
- setup(BufferPool) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageConsumerClient
- setup(BufferPool, List<TieredStorageMemorySpec>) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemoryManager
-
Setup the
TieredStorageMemoryManager. - setup(BufferPool, List<TieredStorageMemorySpec>) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemoryManagerImpl
- setup(TieredStorageMemoryManager) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskTierConsumerAgent
- setup(TieredStorageMemoryManager) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory.MemoryTierConsumerAgent
- setup(TieredStorageMemoryManager) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierConsumerAgent
- setup(TieredStorageMemoryManager) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierConsumerAgent
-
The consumer agent may request buffers from the memory manager.
- setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
- setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
- setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
- setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
- setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
- setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
- setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
- setup(TaskContext<AbstractRichFunction, T>) - Method in class org.apache.flink.runtime.operators.NoOpDriver
- setup(TaskContext<CoGroupFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.CoGroupDriver
- setup(TaskContext<CoGroupFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
- setup(TaskContext<CoGroupFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
- setup(TaskContext<CoGroupFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
- setup(TaskContext<CrossFunction<T1, T2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.CrossDriver
- setup(TaskContext<FlatJoinFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
- setup(TaskContext<FlatJoinFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.JoinDriver
- setup(TaskContext<FlatJoinFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
- setup(TaskContext<FlatJoinFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
- setup(TaskContext<FlatMapFunction<IT, OT>, OT>) - Method in class org.apache.flink.runtime.operators.FlatMapDriver
- setup(TaskContext<Function, T>) - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
- setup(TaskContext<GroupCombineFunction<IN, OUT>, OUT>) - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
- setup(TaskContext<GroupCombineFunction<IN, OUT>, OUT>) - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
- setup(TaskContext<GroupReduceFunction<IT, OT>, OT>) - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
- setup(TaskContext<GroupReduceFunction<IT, OT>, OT>) - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
- setup(TaskContext<MapFunction<IT, OT>, OT>) - Method in class org.apache.flink.runtime.operators.MapDriver
- setup(TaskContext<MapPartitionFunction<IT, OT>, OT>) - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
- setup(TaskContext<ReduceFunction<T>, T>) - Method in class org.apache.flink.runtime.operators.AllReduceDriver
- setup(TaskContext<ReduceFunction<T>, T>) - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
- setup(TaskContext<ReduceFunction<T>, T>) - Method in class org.apache.flink.runtime.operators.ReduceDriver
- setup(TaskContext<S, OT>) - Method in interface org.apache.flink.runtime.operators.Driver
- setup(TaskConfig, String, Collector<OT>, AbstractInvokable, UserCodeClassLoader, ExecutionConfig, Map<String, Accumulator<?, ?>>) - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
- setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<INPUT>>) - Method in class org.apache.flink.streaming.api.operators.sortpartition.KeyedSortPartitionOperator
- setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<INPUT>>) - Method in class org.apache.flink.streaming.api.operators.sortpartition.SortPartitionOperator
- setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateUdfStreamOperator
- setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
- setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.streaming.api.operators.SourceOperator
- setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
- setup(TriConsumer<TieredStorageSubpartitionId, Buffer, Integer>) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.BufferAccumulator
-
Setup the accumulator.
- setup(TriConsumer<TieredStorageSubpartitionId, Buffer, Integer>) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.HashBufferAccumulator
- setup(TriConsumer<TieredStorageSubpartitionId, Buffer, Integer>) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.SortBufferAccumulator
- setupChannels() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
Assign the exclusive buffers to all remote input channels directly for credit-based mode.
- setupInputChannels(List<TieredStorageConsumerSpec>, List<Supplier<InputChannel>>) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.TieredStorageNettyServiceImpl
-
Set up input channels in
SingleInputGate. - setupInternal() - Method in class org.apache.flink.runtime.io.network.partition.BufferWritingResultPartition
- setupInternal() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartition
- setupInternal() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Do the subclass's own setup operation.
- setupInternal() - Method in class org.apache.flink.runtime.io.network.partition.SortMergeResultPartition
- setupLatencyMeasurement(TimerService, MailboxExecutor) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
-
Sets up latency measurement with required
TimerServiceandMailboxExecutor. - setupNetworkInputs(TypeSerializer<?>...) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setupNumRecordsInCounter(StreamOperator) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- setupPartitionsAndGates(ResultPartitionWriter[], InputGate[]) - Static method in class org.apache.flink.runtime.taskmanager.Task
- setupStreamOperator(AbstractStreamOperator<OUT>, StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Static method in class org.apache.flink.streaming.api.operators.StreamOperatorUtils
- setUpstreamSubtaskStateMapper(SubtaskStateMapper) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Sets the channel state rescaler used for rescaling persisted data on upstream side of this JobEdge.
- setupSubtaskGatewayForAttempts(int, Set<Integer>) - Method in class org.apache.flink.runtime.operators.coordination.OperatorCoordinatorHolder
- setUseLargeRecordHandler(boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setUserArtifactBlobKey(String, PermanentBlobKey) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
- setUserArtifactRemotePath(String, String) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
- setUserHash(String) - Method in class org.apache.flink.streaming.api.graph.StreamNode
- setValue(byte[]) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
- setValueSerializer(TypeSerializer<SV>) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
- setVertexDescriptionMode(PipelineOptions.VertexDescriptionMode) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setVertexID(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- setVertexNameIncludeIndexPrefix(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
- setVertexNonChainedOutputs(List<NonChainedOutput>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
Sets the job vertex level non-chained outputs.
- setWaitForSolutionSetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- setWritePosition(long) - Method in class org.apache.flink.runtime.io.disk.RandomAccessOutputView
- setWriterUidHash(String) - Method in class org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes.SinkOperatorUidHashesBuilder
-
Sets the uid hash of the writer operator used to recover state.
- SHARED - org.apache.flink.runtime.minicluster.RpcServiceSharing
- SHARED - org.apache.flink.runtime.state.CheckpointedStateScope
-
Shared state may belong to more than one checkpoint.
- sharedPhysicalFilePoolBySubtask - Variable in class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFilePool
-
Map maintaining queues of different subtasks for reusing shared physical files.
- SharedResources - Class in org.apache.flink.runtime.memory
-
A map that keeps track of acquired shared resources and handles their allocation disposal.
- SharedResources() - Constructor for class org.apache.flink.runtime.memory.SharedResources
- SharedResources.ResourceAndSize<T extends AutoCloseable> - Interface in org.apache.flink.runtime.memory
-
A resource handle with size.
- sharedState - Variable in class org.apache.flink.runtime.state.AbstractIncrementalStateHandle
-
Shared state in the incremental checkpoint.
- sharedStateDir - Variable in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
- sharedStateDirectory - Variable in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageAccess
- SharedStateRegistry - Interface in org.apache.flink.runtime.state
-
This registry manages state that is shared across (incremental) checkpoints, and is responsible for deleting shared state that is no longer used in any valid checkpoint.
- SharedStateRegistryFactory - Interface in org.apache.flink.runtime.state
-
Simple factory to produce
SharedStateRegistryobjects. - SharedStateRegistryImpl - Class in org.apache.flink.runtime.state
-
SharedStateRegistryimplementation. - SharedStateRegistryImpl() - Constructor for class org.apache.flink.runtime.state.SharedStateRegistryImpl
-
Default uses direct executor to delete unreferenced state
- SharedStateRegistryImpl(Executor) - Constructor for class org.apache.flink.runtime.state.SharedStateRegistryImpl
- SharedStateRegistryImpl.EmptyDiscardStateObjectForRegister - Class in org.apache.flink.runtime.state
-
An object with empty discardState for registering.
- SharedStateRegistryKey - Class in org.apache.flink.runtime.state
-
This class represents a key that uniquely identifies (on a logical level) state handles for registration in the
SharedStateRegistry. - SharedStateRegistryKey(String) - Constructor for class org.apache.flink.runtime.state.SharedStateRegistryKey
- SharedStateRegistryKey(String, StateHandleID) - Constructor for class org.apache.flink.runtime.state.SharedStateRegistryKey
- SHIP_STRATEGY - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
- ShipStrategyType - Enum in org.apache.flink.runtime.operators.shipping
-
Enumeration defining the different shipping types of the output, such as local forward, re-partitioning by hash, or re-partitioning by range.
- shouldAdvanceToEndOfTime() - Method in class org.apache.flink.runtime.checkpoint.SavepointType
- shouldBeDiscardedOnShutdown(JobStatus) - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
- shouldBeDiscardedOnSubsume() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
- shouldDrain() - Method in class org.apache.flink.runtime.checkpoint.SavepointType
- shouldDrain() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointRequestBody
- shouldExitJvmOnOutOfMemoryError() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
- shouldExitJvmOnOutOfMemoryError() - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
-
Checks whether the TaskManager should exit the JVM when the task thread throws an OutOfMemoryError.
- shouldIgnoreEndOfInput() - Method in class org.apache.flink.runtime.checkpoint.SavepointType
- shouldIncludeFinished() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
- shouldIncludeRunning() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
- shouldInterrupt() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
- shouldSyncAfterClosingLogicalFile - Variable in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
-
File-system dependent value.
- shuffle() - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Sets the partitioning of the
DataStreamso that the output elements are shuffled uniformly randomly to the next operation. - SHUFFLE_SERVICE_FACTORY_CLASS - Static variable in class org.apache.flink.runtime.shuffle.ShuffleServiceOptions
-
The full class name of the shuffle service factory implementation to be used by the cluster.
- ShuffleDescriptor - Interface in org.apache.flink.runtime.shuffle
-
Interface for shuffle deployment descriptor of result partition resource.
- ShuffleDescriptorAndIndex(ShuffleDescriptor, int) - Constructor for class org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory.ShuffleDescriptorAndIndex
- ShuffleDescriptorGroup(TaskDeploymentDescriptorFactory.ShuffleDescriptorAndIndex[]) - Constructor for class org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup
- ShuffleEnvironment<P extends ResultPartitionWriter,G extends IndexedInputGate> - Interface in org.apache.flink.runtime.shuffle
-
Interface for the implementation of shuffle service local environment.
- ShuffleEnvironmentContext - Class in org.apache.flink.runtime.shuffle
-
Local context used to create
ShuffleEnvironment. - ShuffleEnvironmentContext(Configuration, ResourceID, MemorySize, boolean, InetAddress, int, String[], TaskEventPublisher, MetricGroup, Executor, ScheduledExecutor) - Constructor for class org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
- ShuffleIOOwnerContext - Class in org.apache.flink.runtime.shuffle
-
Context of shuffle input/output owner used to create partitions or gates belonging to the owner.
- ShuffleIOOwnerContext(String, ExecutionAttemptID, MetricGroup, MetricGroup, MetricGroup) - Constructor for class org.apache.flink.runtime.shuffle.ShuffleIOOwnerContext
- shuffleMaster - Variable in class org.apache.flink.runtime.scheduler.DefaultScheduler
- ShuffleMaster<T extends ShuffleDescriptor> - Interface in org.apache.flink.runtime.shuffle
-
Intermediate result partition registry to use in
JobMaster. - ShuffleMasterContext - Interface in org.apache.flink.runtime.shuffle
-
Shuffle context used to create
ShuffleMaster. - ShuffleMasterContextImpl - Class in org.apache.flink.runtime.shuffle
-
The default implementation of
ShuffleMasterContext. - ShuffleMasterContextImpl(Configuration, FatalErrorHandler) - Constructor for class org.apache.flink.runtime.shuffle.ShuffleMasterContextImpl
- ShuffleMasterSnapshot - Interface in org.apache.flink.runtime.shuffle
-
This class represents a snapshot of shuffle master, which can be used to restore the internal state of the shuffle master.
- ShuffleMasterSnapshotContext - Interface in org.apache.flink.runtime.shuffle
-
Snapshot context used to create
ShuffleMasterSnapshot. - ShuffleMetrics - Interface in org.apache.flink.runtime.shuffle
-
Interface provides access to the shuffle metrics which includes the meta information of partition(partition bytes, etc).
- ShufflePartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
Partitioner that distributes the data equally by selecting one output channel randomly.
- ShufflePartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
- ShuffleServiceFactory<SD extends ShuffleDescriptor,P extends ResultPartitionWriter,G extends IndexedInputGate> - Interface in org.apache.flink.runtime.shuffle
-
Interface for shuffle service factory implementations.
- ShuffleServiceLoader - Enum in org.apache.flink.runtime.shuffle
-
Utility to load the pluggable
ShuffleServiceFactoryimplementations. - ShuffleServiceOptions - Class in org.apache.flink.runtime.shuffle
-
Options to configure shuffle service.
- ShuffleUtils - Class in org.apache.flink.runtime.shuffle
-
Common utility methods for shuffle service.
- shutdown() - Method in interface org.apache.flink.runtime.asyncprocessing.StateExecutor
-
Shutdown the StateExecutor, and new committed state execution requests will be rejected.
- shutdown() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Shuts down the checkpoint coordinator.
- shutdown() - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
- shutdown() - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
-
Shuts the library cache manager down.
- shutdown() - Method in class org.apache.flink.runtime.filecache.FileCache
-
Shuts down the file cache by cancelling all.
- shutdown() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
-
Shuts down this leader election service.
- shutdown() - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
- shutdown() - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
- shutdown() - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
- shutdown() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
- shutdown() - Method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
-
Shutdown the
JobMasterservices. - shutdown() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Shuts the memory manager down, trying to release all the memory it managed.
- shutdown() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
- shutdown() - Method in interface org.apache.flink.runtime.query.KvStateServer
-
Shuts down the server and all related thread pools.
- shutdown() - Method in class org.apache.flink.runtime.state.TaskExecutorChannelStateExecutorFactoryManager
- shutdown() - Method in class org.apache.flink.runtime.state.TaskExecutorFileMergingManager
- shutdown() - Method in class org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager
- shutdown() - Method in class org.apache.flink.runtime.state.TaskExecutorStateChangelogStoragesManager
- shutdown() - Method in class org.apache.flink.runtime.taskexecutor.KvStateService
- shutdown() - Method in class org.apache.flink.runtime.taskmanager.MemoryLogger
- shutdown(Duration) - Method in class org.apache.flink.runtime.rest.RestClient
- shutdown(JobStatus) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
-
Shuts the
CheckpointIDCounterservice. - shutdown(JobStatus) - Method in enum org.apache.flink.runtime.checkpoint.DeactivatedCheckpointIDCounter
- shutdown(JobStatus) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
- shutdown(JobStatus) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
- shutdown(JobStatus, CheckpointsCleaner) - Method in class org.apache.flink.runtime.checkpoint.AbstractCompleteCheckpointStore
- shutdown(JobStatus, CheckpointsCleaner) - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
Shuts down the store.
- shutdown(JobStatus, CheckpointsCleaner) - Method in enum org.apache.flink.runtime.checkpoint.DeactivatedCheckpointCompletedCheckpointStore
- shutdown(JobStatus, CheckpointsCleaner) - Method in class org.apache.flink.runtime.checkpoint.DefaultCompletedCheckpointStore
- shutdown(JobStatus, CheckpointsCleaner) - Method in class org.apache.flink.runtime.checkpoint.EmbeddedCompletedCheckpointStore
- shutdown(JobStatus, CheckpointsCleaner) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
- shutDown() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
Shuts the
TaskExecutorservices down. - shutDown() - Method in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator
-
Shuts down the coordinator.
- shutDown() - Method in interface org.apache.flink.runtime.webmonitor.stats.VertexStatsTracker
-
Shuts the
VertexStatsTrackerdown. - shutDown() - Method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexThreadInfoTracker
- SHUTDOWN_CLUSTER - org.apache.flink.runtime.minicluster.MiniClusterJobClient.JobFinalizationBehavior
-
Shut down the
MiniClusterwhen the job finishes. - shutDownCluster() - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- shutDownCluster() - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
- shutDownCluster(ApplicationStatus) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- shutDownCluster(ApplicationStatus) - Method in interface org.apache.flink.runtime.dispatcher.DispatcherGateway
- shutdownExecutorForcefully(ExecutorService, Duration) - Static method in class org.apache.flink.runtime.operators.coordination.ComponentClosingUtils
-
Shutdown the given executor forcefully within the given timeout.
- shutdownExecutorForcefully(ExecutorService, Duration, boolean) - Static method in class org.apache.flink.runtime.operators.coordination.ComponentClosingUtils
-
Shutdown the given executor forcefully within the given timeout.
- shutDownFuture - Variable in class org.apache.flink.runtime.dispatcher.Dispatcher
- ShutdownHandler - Class in org.apache.flink.runtime.rest.handler.cluster
-
REST handler which allows to shut down the cluster.
- ShutdownHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, EmptyResponseBody, EmptyMessageParameters>) - Constructor for class org.apache.flink.runtime.rest.handler.cluster.ShutdownHandler
- ShutdownHeaders - Class in org.apache.flink.runtime.rest.messages.cluster
-
Message headers for
ShutdownHandler. - ShutdownHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
- shutdownHook - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
-
Shutdown hook thread to ensure deletion of the local storage directory.
- shutDownInternal() - Method in class org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint
- shutDownInternal() - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
-
Stops this REST server endpoint.
- shutDownInternal() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
- shutdownRequested - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
- shutdownService() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
- shutdownService() - Method in interface org.apache.flink.streaming.runtime.tasks.TimerService
-
Shuts down and clean up the timer service provider hard and immediately.
- shutdownServiceUninterruptible(long) - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
- shutdownServiceUninterruptible(long) - Method in interface org.apache.flink.streaming.runtime.tasks.TimerService
-
Shuts down and clean up the timer service provider hard and immediately.
- SIDE - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
- sideOutput(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Write skipped late arriving element to SideOutput.
- sideOutput(T, long, boolean) - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator
-
Write skipped late arriving element to SideOutput.
- SideOutputDataStream<T> - Class in org.apache.flink.streaming.api.datastream
-
A
SideOutputDataStreamrepresents aDataStreamthat contains elements that are emitted from upstream into a side output with some tag. - SideOutputDataStream(StreamExecutionEnvironment, SideOutputTransformation<T>) - Constructor for class org.apache.flink.streaming.api.datastream.SideOutputDataStream
-
Creates a new
SideOutputDataStreamin the given execution environment. - sideOutputLateData(OutputTag<T>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Send late arriving data to the side output identified by the given
OutputTag. - sideOutputLateData(OutputTag<T>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Send late arriving data to the side output identified by the given
OutputTag. - sideOutputLateData(OutputTag<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
- sideOutputLeftLateData(OutputTag<IN1>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoined
-
Send late arriving left-side data to the side output identified by the given
OutputTag. - sideOutputRightLateData(OutputTag<IN2>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoined
-
Send late arriving right-side data to the side output identified by the given
OutputTag. - SideOutputTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This transformation represents a selection of a side output of an upstream operation with a given
OutputTag. - SideOutputTransformation(Transformation<?>, OutputTag<T>) - Constructor for class org.apache.flink.streaming.api.transformations.SideOutputTransformation
- SideOutputTransformationTranslator<OUT> - Class in org.apache.flink.streaming.runtime.translators
-
A
TransformationTranslatorfor theSideOutputTransformation. - SideOutputTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.SideOutputTransformationTranslator
- signalAlreadyCommitted() - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
- signalFailedWithKnownReason(Throwable) - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
- signalFailedWithUnknownReason(Throwable) - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
- SignalHandler - Class in org.apache.flink.runtime.util
-
This signal handler / signal logger is based on Apache Hadoop's org.apache.hadoop.util.SignalLogger.
- SignalHandler() - Constructor for class org.apache.flink.runtime.util.SignalHandler
- signalIntermediateNoMoreSplits(int) - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinatorContext
- signalNoMoreSplits(int) - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinatorContext
- signalTermination() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
- SimpleCloseableInputProvider<E> - Class in org.apache.flink.runtime.operators.util
-
A simple iterator provider that returns a supplied iterator and does nothing when closed.
- SimpleCloseableInputProvider(MutableObjectIterator<E>) - Constructor for class org.apache.flink.runtime.operators.util.SimpleCloseableInputProvider
-
Creates a new simple input provider that will return the given iterator.
- SimpleCollectingOutputView - Class in org.apache.flink.runtime.io.disk
-
The list with the full segments contains at any point all completely full segments, plus the segment that is currently filled.
- SimpleCollectingOutputView(List<MemorySegment>, MemorySegmentSource, int) - Constructor for class org.apache.flink.runtime.io.disk.SimpleCollectingOutputView
- SimpleExecutionSlotAllocator - Class in org.apache.flink.runtime.scheduler
-
A simple implementation of
ExecutionSlotAllocator. - SimpleExecutionSlotAllocator.Factory - Class in org.apache.flink.runtime.scheduler
-
Factory to instantiate a
SimpleExecutionSlotAllocator. - SimpleInitializeOnMasterContext - Class in org.apache.flink.runtime.executiongraph
-
A simple pojo based implementation of
JobVertex.InitializeOnMasterContext. - SimpleInitializeOnMasterContext(ClassLoader, int) - Constructor for class org.apache.flink.runtime.executiongraph.SimpleInitializeOnMasterContext
- SimpleInputFormatOperatorFactory<OUT> - Class in org.apache.flink.streaming.api.operators
-
Input format source operator factory which just wrap existed
StreamSource. - SimpleInputFormatOperatorFactory(StreamSource<OUT, InputFormatSourceFunction<OUT>>) - Constructor for class org.apache.flink.streaming.api.operators.SimpleInputFormatOperatorFactory
- SimpleIterable(IN, MutableObjectIterator<IN>) - Constructor for class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable
- SimpleIterator(IN, MutableObjectIterator<IN>) - Constructor for class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable.SimpleIterator
- SimpleOperatorFactory<OUT> - Class in org.apache.flink.streaming.api.operators
-
Simple factory which just wrap existed
StreamOperator. - SimpleOperatorFactory(StreamOperator<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.SimpleOperatorFactory
- SimpleOutputFormatOperatorFactory<IN,OUT> - Class in org.apache.flink.streaming.api.operators
-
A simple operator factory which create an operator containing an
OutputFormat. - SimpleOutputFormatOperatorFactory(OutputFormat<IN>, StreamOperator<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.SimpleOutputFormatOperatorFactory
- SimpleRequestSlotMatchingStrategy - Enum in org.apache.flink.runtime.jobmaster.slotpool
-
Simple implementation of the
RequestSlotMatchingStrategythat matches the pending requests in order as long as the resource profile can be fulfilled. - SimpleStateEntry(K, N, S) - Constructor for class org.apache.flink.runtime.state.StateEntry.SimpleStateEntry
- SimpleTimerService - Class in org.apache.flink.streaming.api
-
Implementation of
TimerServicethat uses aInternalTimerService. - SimpleTimerService(InternalTimerService<VoidNamespace>) - Constructor for class org.apache.flink.streaming.api.SimpleTimerService
- SimpleTransformationTranslator<OUT,T extends org.apache.flink.api.dag.Transformation<OUT>> - Class in org.apache.flink.streaming.api.graph
-
A base class for all
TransformationTranslatorswho translateTransformationsthat have a single operator in their runtime implementation. - SimpleTransformationTranslator() - Constructor for class org.apache.flink.streaming.api.graph.SimpleTransformationTranslator
- SimpleUdfStreamOperatorFactory<OUT> - Class in org.apache.flink.streaming.api.operators
-
Udf stream operator factory which just wrap existed
AbstractUdfStreamOperator. - SimpleUdfStreamOperatorFactory(AbstractUdfStreamOperator<OUT, ?>) - Constructor for class org.apache.flink.streaming.api.operators.SimpleUdfStreamOperatorFactory
- SimpleVersionedListState<T> - Class in org.apache.flink.streaming.api.operators.util
-
A
ListStatethat uses aSimpleVersionedSerializerinstead of aTypeSerializer. - SimpleVersionedListState(ListState<byte[]>, SimpleVersionedSerializer<T>) - Constructor for class org.apache.flink.streaming.api.operators.util.SimpleVersionedListState
-
Creates a new SimpleVersionedListState that reads and writes bytes from the given raw ListState with the given serializer.
- SINGLE - org.apache.flink.streaming.util.LatencyStats.Granularity
- SingleCheckpointBarrierHandler - Class in org.apache.flink.streaming.runtime.io.checkpointing
-
SingleCheckpointBarrierHandleris used for triggering checkpoint while reading the first barrier and keeping track of the number of received barriers and consumed barriers. - SingleElementIterator<E> - Class in org.apache.flink.runtime.util
-
An
Iteratorthat contains only a single element. - SingleElementIterator() - Constructor for class org.apache.flink.runtime.util.SingleElementIterator
- SingleInputGate - Class in org.apache.flink.runtime.io.network.partition.consumer
-
An input gate consumes one or more partitions of a single produced intermediate result.
- SingleInputGate(String, int, IntermediateDataSetID, ResultPartitionType, int, PartitionProducerStateProvider, SupplierWithException<BufferPool, IOException>, BufferDecompressor, MemorySegmentProvider, int, ThroughputCalculator, BufferDebloater) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- SingleInputGateFactory - Class in org.apache.flink.runtime.io.network.partition.consumer
-
Factory for
SingleInputGateto use inNettyShuffleEnvironment. - SingleInputGateFactory(ResourceID, NettyShuffleEnvironmentConfiguration, ConnectionManager, ResultPartitionManager, TaskEventPublisher, NetworkBufferPool, TieredStorageConfiguration, TieredStorageNettyServiceImpl) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGateFactory
- SingleInputGateFactory.ChannelStatistics - Class in org.apache.flink.runtime.io.network.partition.consumer
-
Statistics of input channels.
- SingleLogicalSlot - Class in org.apache.flink.runtime.jobmaster.slotpool
-
Implementation of the
LogicalSlot. - SingleLogicalSlot(SlotRequestId, SlotContext, Locality, SlotOwner) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
- SingleLogicalSlot(SlotRequestId, SlotContext, Locality, SlotOwner, boolean) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
- SingleOutputStreamOperator<T> - Class in org.apache.flink.streaming.api.datastream
-
SingleOutputStreamOperatorrepresents a user defined transformation applied on aDataStreamwith one predefined output type. - SingleOutputStreamOperator(StreamExecutionEnvironment, Transformation<T>) - Constructor for class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
- SingleRecordWriter<T extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.writer
-
The specific delegate implementation for the single output case.
- SingleRecordWriter(RecordWriter<T>) - Constructor for class org.apache.flink.runtime.io.network.api.writer.SingleRecordWriter
- singleton(T) - Static method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- singletonOrEmpty(T) - Static method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- sink() - Method in class org.apache.flink.streaming.api.lineage.DefaultLineageEdge
- sink() - Method in interface org.apache.flink.streaming.api.lineage.LineageEdge
- SINK - org.apache.flink.runtime.operators.DriverStrategy
- SinkFunction<IN> - Interface in org.apache.flink.streaming.api.functions.sink.legacy
-
Deprecated.This interface will be removed in future versions. Use the new
Sinkinterface instead. - SinkFunction.Context - Interface in org.apache.flink.streaming.api.functions.sink.legacy
-
Deprecated.Context that
SinkFunctionscan use for getting additional data about an input record. - SinkOperatorUidHashesBuilder() - Constructor for class org.apache.flink.streaming.api.datastream.CustomSinkOperatorUidHashes.SinkOperatorUidHashesBuilder
- sinkRestarted(long) - Method in class org.apache.flink.streaming.api.operators.collect.AbstractCollectResultBuffer
- sinkRestarted(long) - Method in class org.apache.flink.streaming.api.operators.collect.CheckpointedCollectResultBuffer
- sinkRestarted(long) - Method in class org.apache.flink.streaming.api.operators.collect.UncheckpointedCollectResultBuffer
- sinks() - Method in class org.apache.flink.streaming.api.lineage.DefaultLineageGraph
- sinks() - Method in interface org.apache.flink.streaming.api.lineage.LineageGraph
- sinkTo(Sink<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Adds the given
Sinkto this DataStream. - sinkTo(Sink<T>, CustomSinkOperatorUidHashes) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Adds the given
Sinkto this DataStream. - SinkTransformation<InputT,OutputT> - Class in org.apache.flink.streaming.api.transformations
-
A
TransformationforSink. - SinkTransformation(DataStream<InputT>, Sink<InputT>, TypeInformation<OutputT>, String, int, boolean, CustomSinkOperatorUidHashes) - Constructor for class org.apache.flink.streaming.api.transformations.SinkTransformation
- SinkTransformationTranslator<Input,Output> - Class in org.apache.flink.streaming.runtime.translators
-
A
TransformationTranslatorfor theSinkTransformation. - SinkTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.SinkTransformationTranslator
- SinkV1CommittableDeserializer - Class in org.apache.flink.streaming.runtime.operators.sink.committables
-
This class offers the possibility to deserialize committables that have been written with older Flink releases (i.e. 1.13, 1.14).
- SinkV1CommittableDeserializer() - Constructor for class org.apache.flink.streaming.runtime.operators.sink.committables.SinkV1CommittableDeserializer
- SinkWriterOperatorFactory<InputT,CommT> - Class in org.apache.flink.streaming.runtime.operators.sink
-
A
StreamOperatorFactoryforSinkWriterOperator. - SinkWriterOperatorFactory(Sink<InputT>) - Constructor for class org.apache.flink.streaming.runtime.operators.sink.SinkWriterOperatorFactory
- size - Variable in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
-
The current size of the priority queue.
- size() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- size() - Method in class org.apache.flink.runtime.dispatcher.DefaultJobManagerRunnerRegistry
- size() - Method in interface org.apache.flink.runtime.dispatcher.ExecutionGraphInfoStore
-
Returns the current number of stored
ExecutionGraphInfoinstances. - size() - Method in class org.apache.flink.runtime.dispatcher.FileExecutionGraphInfoStore
- size() - Method in interface org.apache.flink.runtime.dispatcher.JobManagerRunnerRegistry
-
Returns the number of
JobManagerRunnerinstances currently being registered. - size() - Method in class org.apache.flink.runtime.dispatcher.MemoryExecutionGraphInfoStore
- size() - Method in class org.apache.flink.runtime.dispatcher.OnMainThreadJobManagerRunnerRegistry
- size() - Method in class org.apache.flink.runtime.executiongraph.IndexRange
- size() - Method in class org.apache.flink.runtime.io.network.partition.PrioritizedDeque
-
Returns the number of priority and non-priority elements.
- size() - Method in class org.apache.flink.runtime.jobgraph.forwardgroup.ForwardGroup
- size() - Method in interface org.apache.flink.runtime.memory.SharedResources.ResourceAndSize
- size() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
- size() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
- size() - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
-
Gets the number of elements in the sortable.
- size() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
- size() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
-
Returns the number of elements currently stored in the PriorityQueue.
- size() - Method in class org.apache.flink.runtime.rest.handler.legacy.DefaultExecutionGraphCache
- size() - Method in interface org.apache.flink.runtime.rest.handler.legacy.ExecutionGraphCache
-
Gets the number of cache entries.
- size() - Method in class org.apache.flink.runtime.rest.handler.router.Router
-
Returns the number of routes in this router.
- size() - Method in class org.apache.flink.runtime.scheduler.strategy.ConsumedPartitionGroup
- size() - Method in class org.apache.flink.runtime.scheduler.strategy.ConsumerVertexGroup
- size() - Method in class org.apache.flink.runtime.state.changelog.SequenceNumberRange.GenericSequenceNumberRange
- size() - Method in interface org.apache.flink.runtime.state.changelog.SequenceNumberRange
- size() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
- size() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
Returns the total number of entries in this
CopyOnWriteStateMap. - size() - Method in class org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
- size() - Method in class org.apache.flink.runtime.state.heap.StateMap
-
Returns the total number of entries in this
StateMap. - size() - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Returns the total number of entries in this
StateTable. - size() - Method in interface org.apache.flink.runtime.state.InternalPriorityQueue
-
Returns the number of elements in this set.
- size() - Method in class org.apache.flink.runtime.util.BooleanArrayList
- size() - Method in class org.apache.flink.runtime.util.BoundedFIFOQueue
-
Returns the number of currently stored elements.
- size() - Method in class org.apache.flink.runtime.util.DualKeyLinkedMap
- size() - Method in class org.apache.flink.runtime.util.IntArrayList
- size() - Method in class org.apache.flink.runtime.util.LongArrayList
- size() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
Returns the current number of mails in this mailbox.
- size() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
- size() - Method in class org.apache.flink.streaming.runtime.watermarkstatus.HeapPriorityQueue
- SIZE - Static variable in class org.apache.flink.runtime.blob.BlobKey
-
Size of the internal BLOB key in bytes.
- SIZE - Static variable in class org.apache.flink.runtime.rest.messages.LogInfo
- SIZE - Static variable in class org.apache.flink.runtime.scheduler.strategy.ExecutionVertexID
-
The size of the ID in byte.
- sizeLimit - Variable in class org.apache.flink.runtime.blob.BlobCacheSizeTracker
- sizeOfNamespace(Object) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
- sizeOfNamespace(Object) - Method in class org.apache.flink.runtime.state.heap.StateMap
- sizeOfNamespace(Object) - Method in class org.apache.flink.runtime.state.heap.StateTable
- SKEW - org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter.AggregationMode
- skip(long) - Method in class org.apache.flink.runtime.state.BoundedInputStream
- skip(long) - Method in class org.apache.flink.runtime.state.filesystem.FsSegmentDataInputStream
- skip(long) - Method in class org.apache.flink.runtime.util.ForwardingInputStream
- skipBytes(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
- skipBytesToRead(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
- skipBytesToWrite(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
- SlidingEventTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssignerthat windows elements into sliding windows based on the timestamp of the elements. - SlidingEventTimeWindows(long, long, long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
- SlidingProcessingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssignerthat windows elements into sliding windows based on the current system time of the machine the operation is running on. - SlotActions - Interface in org.apache.flink.runtime.taskexecutor.slot
-
Interface to trigger slot actions from within the
TaskSlotTable. - SlotAllocationException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
-
Exception indicating that the slot allocation on the task manager failed.
- SlotAllocationException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.SlotAllocationException
- SlotAllocationException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.SlotAllocationException
- SlotAllocationException(Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.SlotAllocationException
- SlotAllocationSnapshot - Class in org.apache.flink.runtime.taskexecutor.slot
-
Model to save local slot allocation info.
- SlotAllocationSnapshot(SlotID, JobID, String, AllocationID, ResourceProfile) - Constructor for class org.apache.flink.runtime.taskexecutor.slot.SlotAllocationSnapshot
- SlotAllocationSnapshotPersistenceService - Interface in org.apache.flink.runtime.taskexecutor.slot
-
Service for persisting
SlotAllocationSnapshot. - SlotAllocator - Interface in org.apache.flink.runtime.scheduler.adaptive.allocator
-
Component for calculating the slot requirements and mapping of vertices to slots.
- SlotAssigner - Interface in org.apache.flink.runtime.scheduler.adaptive.allocator
-
Interface for assigning slots to slot sharing groups.
- SlotAssignment(SlotInfo, Object) - Constructor for class org.apache.flink.runtime.scheduler.adaptive.JobSchedulingPlan.SlotAssignment
- slotBatchAllocatable - Variable in class org.apache.flink.runtime.jobmaster.slotpool.AbstractSlotPoolServiceFactory
- SlotContext - Interface in org.apache.flink.runtime.jobmaster
-
Interface for the context of a
LogicalSlot. - SlotID - Class in org.apache.flink.runtime.clusterframework.types
-
Unique identifier for a slot on a TaskManager.
- SlotID(ResourceID, int) - Constructor for class org.apache.flink.runtime.clusterframework.types.SlotID
- slotIdleTimeout - Variable in class org.apache.flink.runtime.jobmaster.slotpool.AbstractSlotPoolServiceFactory
- SlotInfo - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
Class containing information for a slot of
TaskManagerSlotInformation. - SlotInfo - Interface in org.apache.flink.runtime.jobmaster
-
Interface that provides basic information in the context of a slot.
- SlotInfo(JobID, ResourceProfile) - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.SlotInfo
- SlotInfo(JobID, ResourceProfileInfo) - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.SlotInfo
- SlotManager - Interface in org.apache.flink.runtime.resourcemanager.slotmanager
-
The slot manager is responsible for maintaining a view on all registered task manager slots, their allocation and all pending slot requests.
- SlotManager.RegistrationResult - Enum in org.apache.flink.runtime.resourcemanager.slotmanager
-
The result of task manager registration.
- SlotManagerConfiguration - Class in org.apache.flink.runtime.resourcemanager.slotmanager
-
Configuration for the
SlotManager. - SlotManagerConfiguration(Duration, Duration, Duration, Duration, TaskManagerOptions.TaskManagerLoadBalanceMode, WorkerResourceSpec, int, int, int, CPUResource, CPUResource, MemorySize, MemorySize, int) - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
- SlotManagerException - Exception in org.apache.flink.runtime.resourcemanager.slotmanager
-
Base class for exceptions thrown by the
SlotManager. - SlotManagerException(String) - Constructor for exception org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerException
- SlotManagerException(String, Throwable) - Constructor for exception org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerException
- SlotManagerException(Throwable) - Constructor for exception org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerException
- SlotManagerMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
Metric group which is used by the
SlotManagerto register metrics. - SlotManagerUtils - Class in org.apache.flink.runtime.resourcemanager.slotmanager
-
Utilities for
SlotManagerimplementations. - SlotManagerUtils() - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerUtils
- SlotNotActiveException - Exception in org.apache.flink.runtime.taskexecutor.slot
-
Exception indicating that the given
TaskSlotwas not in state active. - SlotNotActiveException(JobID, AllocationID) - Constructor for exception org.apache.flink.runtime.taskexecutor.slot.SlotNotActiveException
- SlotNotFoundException - Exception in org.apache.flink.runtime.taskexecutor.slot
-
Exception indicating that a
TaskSlotcould not be found. - SlotNotFoundException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.slot.SlotNotFoundException
- SlotNotFoundException(AllocationID) - Constructor for exception org.apache.flink.runtime.taskexecutor.slot.SlotNotFoundException
- SlotOccupiedException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
-
Exception which signals that a slot is already occupied by the given
AllocationID. - SlotOccupiedException(String, AllocationID, JobID) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.SlotOccupiedException
- SlotOffer - Class in org.apache.flink.runtime.taskexecutor.slot
-
Describe the slot offering to job manager provided by task manager.
- SlotOffer(AllocationID, int, ResourceProfile) - Constructor for class org.apache.flink.runtime.taskexecutor.slot.SlotOffer
- SlotOwner - Interface in org.apache.flink.runtime.jobmaster
-
Interface for components that hold slots and to which slots get released / recycled.
- slotPool - Variable in class org.apache.flink.runtime.jobmaster.slotpool.DefaultDeclarativeSlotPool
- SlotPool - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
The Interface of a slot pool that manages slots.
- SlotPoolService - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
Service used by the
JobMasterto manage a slot pool. - SlotPoolServiceFactory - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
Factory interface for
SlotPoolService. - SlotPoolServiceSchedulerFactory - Interface in org.apache.flink.runtime.jobmaster
-
Factory for
SlotPoolServiceandSchedulerNG. - SlotProfile - Class in org.apache.flink.runtime.clusterframework.types
-
A slot profile describes the profile of a slot into which a task wants to be scheduled.
- SlotReport - Class in org.apache.flink.runtime.taskexecutor
-
A report about the current status of all slots of the TaskExecutor, describing which slots are available and allocated, and what jobs (JobManagers) the allocated slots have been allocated to.
- SlotReport() - Constructor for class org.apache.flink.runtime.taskexecutor.SlotReport
- SlotReport(Collection<SlotStatus>) - Constructor for class org.apache.flink.runtime.taskexecutor.SlotReport
- SlotReport(SlotStatus) - Constructor for class org.apache.flink.runtime.taskexecutor.SlotReport
- SlotRequestId - Class in org.apache.flink.runtime.jobmaster
-
This ID identifies the request for a slot from the Execution to the
SlotPoolorPhysicalSlotProvider. - SlotRequestId() - Constructor for class org.apache.flink.runtime.jobmaster.SlotRequestId
- SlotRequestId(long, long) - Constructor for class org.apache.flink.runtime.jobmaster.SlotRequestId
- slotRequestMaxInterval - Variable in class org.apache.flink.runtime.jobmaster.slotpool.AbstractSlotPoolServiceFactory
- SlotSelectionStrategy - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
Interface for slot selection strategies.
- SlotSelectionStrategy.SlotInfoAndLocality - Class in org.apache.flink.runtime.jobmaster.slotpool
- SlotSelectionStrategyUtils - Class in org.apache.flink.runtime.util
-
Utility class for selecting
SlotSelectionStrategy. - SlotSharingExecutionSlotAllocatorFactory - Class in org.apache.flink.runtime.scheduler
-
Factory for
SlotSharingExecutionSlotAllocator. - SlotSharingExecutionSlotAllocatorFactory(PhysicalSlotProvider, boolean, PhysicalSlotRequestBulkChecker, Duration) - Constructor for class org.apache.flink.runtime.scheduler.SlotSharingExecutionSlotAllocatorFactory
- slotSharingGroup(String) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Sets the slot sharing group of this operation.
- slotSharingGroup(String) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the slot sharing group of this operation.
- slotSharingGroup(SlotSharingGroup) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Sets the slot sharing group of this operation.
- slotSharingGroup(SlotSharingGroup) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets the slot sharing group of this operation.
- SlotSharingGroup - Class in org.apache.flink.runtime.jobmanager.scheduler
-
A slot sharing units defines which different task (from different job vertices) can be deployed together within a slot.
- SlotSharingGroup() - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
- SlotSharingGroupId - Class in org.apache.flink.runtime.instance
- SlotSharingGroupId() - Constructor for class org.apache.flink.runtime.instance.SlotSharingGroupId
- SlotSharingGroupId(byte[]) - Constructor for class org.apache.flink.runtime.instance.SlotSharingGroupId
- SlotSharingGroupId(long, long) - Constructor for class org.apache.flink.runtime.instance.SlotSharingGroupId
- SlotSharingGroupIDDeserializer - Class in org.apache.flink.runtime.rest.messages.json
-
Jackson deserializer for
SlotSharingGroupId. - SlotSharingGroupIDDeserializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.SlotSharingGroupIDDeserializer
- SlotSharingGroupIDSerializer - Class in org.apache.flink.runtime.rest.messages.json
-
Jackson serializer for
SlotSharingGroupId. - SlotSharingGroupIDSerializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.SlotSharingGroupIDSerializer
- SlotSharingSlotAllocator - Class in org.apache.flink.runtime.scheduler.adaptive.allocator
-
SlotAllocatorimplementation that supports slot sharing. - SlotStatus - Class in org.apache.flink.runtime.taskexecutor
-
This describes the slot current status which located in TaskManager.
- SlotStatus(SlotID, ResourceProfile) - Constructor for class org.apache.flink.runtime.taskexecutor.SlotStatus
- SlotStatus(SlotID, ResourceProfile, JobID, AllocationID) - Constructor for class org.apache.flink.runtime.taskexecutor.SlotStatus
- SlotStatusSyncer - Interface in org.apache.flink.runtime.resourcemanager.slotmanager
-
Syncer for slot status.
- SlowTaskDetector - Interface in org.apache.flink.runtime.scheduler.slowtaskdetector
-
Component responsible for detecting slow tasks.
- SlowTaskDetectorListener - Interface in org.apache.flink.runtime.scheduler.slowtaskdetector
-
Component responsible for listening on slow tasks.
- SnappyStreamCompressionDecorator - Class in org.apache.flink.runtime.state
-
This implementation decorates the stream with snappy compression.
- SnappyStreamCompressionDecorator() - Constructor for class org.apache.flink.runtime.state.SnappyStreamCompressionDecorator
- snapshot() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
- snapshot() - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
- snapshot() - Method in class org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
- snapshot() - Method in class org.apache.flink.runtime.state.RegisteredPriorityQueueStateBackendMetaInfo
- snapshot() - Method in class org.apache.flink.runtime.state.RegisteredStateMetaInfoBase
- snapshot() - Method in class org.apache.flink.runtime.state.v2.RegisteredKeyValueStateBackendMetaInfo
- snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
- snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
- snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - Method in interface org.apache.flink.runtime.state.Snapshotable
-
Operation that writes a snapshot into a stream that is provided by the given
CheckpointStreamFactoryand returns a @RunnableFuturethat gives a state handle to the snapshot. - snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - Method in class org.apache.flink.runtime.state.SnapshotStrategyRunner
- snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - Method in class org.apache.flink.runtime.state.v2.adaptor.AsyncKeyedStateBackendAdaptor
- snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionKeyedStateBackend
- Snapshotable<S extends StateObject> - Interface in org.apache.flink.runtime.state
-
Interface for objects that can snapshot its state (state backends currently).
- snapshotChannelStates(StreamOperator<?>, ChannelStateWriter.ChannelStateWriteResult, OperatorSnapshotFutures) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- snapshotCloseableRegistry - Variable in class org.apache.flink.runtime.state.AsyncSnapshotCallable
-
Registers streams that can block in I/O during snapshot.
- snapshotConfiguration() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
- snapshotConfiguration() - Method in class org.apache.flink.runtime.state.JavaSerializer
- snapshotConfiguration() - Method in class org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
- snapshotConfiguration() - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
- snapshotConfiguration() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
- snapshotConfiguration() - Method in class org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntrySerializer
- snapshotConfiguration() - Method in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.LegacyTimerSerializer
- snapshotConfiguration() - Method in class org.apache.flink.streaming.api.operators.TimerSerializer
- snapshotConfiguration() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
- snapshotConfiguration() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
- snapshotConfiguration() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
- SnapshotDirectory - Class in org.apache.flink.runtime.state
-
This class represents a directory that is the target for a state snapshot.
- SnapshotExecutionType - Enum in org.apache.flink.runtime.state
-
Determines how the write-part of a snapshot should be executed.
- snapshotFunctionState(StateSnapshotContext, OperatorStateBackend, Function) - Static method in class org.apache.flink.streaming.util.functions.StreamingFunctionUtils
- SnapshotResources - Interface in org.apache.flink.runtime.state
-
A set of resources produced in the synchronous part of a snapshot required to finish the snapshot.
- SnapshotResult<T extends StateObject> - Class in org.apache.flink.runtime.state
-
This class contains the combined results from the snapshot of a state backend: A state object representing the state that will be reported to the Job Manager to acknowledge the checkpoint.
- snapshotState(long, long) - Method in interface org.apache.flink.streaming.api.checkpoint.ListCheckpointed
-
Deprecated.Gets the current state of the function.
- snapshotState(long, long, CheckpointOptions, CheckpointStreamFactory) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperator
- snapshotState(long, long, CheckpointOptions, CheckpointStreamFactory) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateStreamOperatorV2
- snapshotState(long, long, CheckpointOptions, CheckpointStreamFactory) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- snapshotState(long, long, CheckpointOptions, CheckpointStreamFactory) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- snapshotState(long, long, CheckpointOptions, CheckpointStreamFactory) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
-
Called to draw a state snapshot from the operator.
- snapshotState(CompletableFuture<ShuffleMasterSnapshot>, ShuffleMasterSnapshotContext) - Method in class org.apache.flink.runtime.shuffle.NettyShuffleMaster
- snapshotState(CompletableFuture<ShuffleMasterSnapshot>, ShuffleMasterSnapshotContext) - Method in interface org.apache.flink.runtime.shuffle.ShuffleMaster
-
Triggers a snapshot of the shuffle master's state.
- snapshotState(Map<OperatorID, OperatorSnapshotFutures>, CheckpointMetaData, CheckpointOptions, Supplier<Boolean>, ChannelStateWriter.ChannelStateWriteResult, CheckpointStreamFactory) - Method in class org.apache.flink.streaming.runtime.tasks.FinishedOperatorChain
- snapshotState(Map<OperatorID, OperatorSnapshotFutures>, CheckpointMetaData, CheckpointOptions, Supplier<Boolean>, ChannelStateWriter.ChannelStateWriteResult, CheckpointStreamFactory) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- snapshotState(Map<OperatorID, OperatorSnapshotFutures>, CheckpointMetaData, CheckpointOptions, Supplier<Boolean>, ChannelStateWriter.ChannelStateWriteResult, CheckpointStreamFactory) - Method in class org.apache.flink.streaming.runtime.tasks.RegularOperatorChain
- snapshotState(SimpleVersionedSerializer<SplitT>) - Method in class org.apache.flink.runtime.source.coordinator.SplitAssignmentTracker
-
Take a snapshot of the split assignments.
- snapshotState(FunctionSnapshotContext) - Method in interface org.apache.flink.streaming.api.checkpoint.CheckpointedFunction
-
This method is called when a snapshot for a checkpoint is requested.
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.legacy.ContinuousFileMonitoringFunction
-
Deprecated.
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.legacy.FromElementsFunction
-
Deprecated.
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.legacy.StatefulSequenceSource
-
Deprecated.
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkFunction
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateUdfStreamOperator
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Stream operators with state, which want to participate in a snapshot need to override this hook method.
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
Stream operators with state, which want to participate in a snapshot need to override this hook method.
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.SourceOperator
- snapshotState(StateSnapshotContext) - Method in interface org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator
- snapshotState(StreamOperatorStateHandler.CheckpointedStreamOperator, Optional<InternalTimeServiceManager<?>>, String, long, long, CheckpointOptions, CheckpointStreamFactory, boolean, boolean) - Method in class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
- SnapshotStrategy<S extends StateObject,SR extends SnapshotResources> - Interface in org.apache.flink.runtime.state
-
Interface for different snapshot approaches in state backends.
- SnapshotStrategy.SnapshotResultSupplier<S extends StateObject> - Interface in org.apache.flink.runtime.state
-
A supplier for a
SnapshotResultwith an access to aCloseableRegistryfor io tasks that need to be closed when cancelling the async part of the checkpoint. - SnapshotStrategyRunner<T extends StateObject,SR extends SnapshotResources> - Class in org.apache.flink.runtime.state
-
A class to execute a
SnapshotStrategy. - SnapshotStrategyRunner(String, SnapshotStrategy<T, SR>, CloseableRegistry, SnapshotExecutionType) - Constructor for class org.apache.flink.runtime.state.SnapshotStrategyRunner
- snapshotTimersForKeyGroup(int) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
-
Snapshots the timers (both processing and event time ones) for a given
keyGroupIdx. - snapshotToRawKeyedState(KeyedStateCheckpointOutputStream, String) - Method in interface org.apache.flink.streaming.api.operators.InternalTimeServiceManager
-
Snapshots the timers to raw keyed state.
- snapshotToRawKeyedState(KeyedStateCheckpointOutputStream, String) - Method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManagerImpl
- snapshotToRawKeyedState(KeyedStateCheckpointOutputStream, String) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeServiceManager
- SnapshotType - Interface in org.apache.flink.runtime.checkpoint
-
The type of checkpoint to perform.
- SnapshotType.SharingFilesStrategy - Enum in org.apache.flink.runtime.checkpoint
-
Defines what files can be shared across snapshots.
- SOCKET_TIMEOUT - Static variable in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorFactory
- SocketClientSink<IN> - Class in org.apache.flink.streaming.api.functions.sink.legacy
-
Deprecated.This interface will be removed in future versions. Use the new
Sinkinterface instead. - SocketClientSink(String, int, SerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.api.functions.sink.legacy.SocketClientSink
-
Deprecated.Creates a new SocketClientSink.
- SocketClientSink(String, int, SerializationSchema<IN>, int) - Constructor for class org.apache.flink.streaming.api.functions.sink.legacy.SocketClientSink
-
Deprecated.Creates a new SocketClientSink that retries connections upon failure up to a given number of times.
- SocketClientSink(String, int, SerializationSchema<IN>, int, boolean) - Constructor for class org.apache.flink.streaming.api.functions.sink.legacy.SocketClientSink
-
Deprecated.Creates a new SocketClientSink that retries connections upon failure up to a given number of times.
- socketTextStream(String, int) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains the strings received infinitely from a socket.
- socketTextStream(String, int, char) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Deprecated.
- socketTextStream(String, int, char, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Deprecated.
- socketTextStream(String, int, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains the strings received infinitely from a socket.
- socketTextStream(String, int, String, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new data stream that contains the strings received infinitely from a socket.
- SocketTextStreamFunction - Class in org.apache.flink.streaming.api.functions.source.legacy
-
Deprecated.This class is based on the
SourceFunctionAPI, which is due to be removed. Use the newSourceAPI instead. - SocketTextStreamFunction(String, int, String, long) - Constructor for class org.apache.flink.streaming.api.functions.source.legacy.SocketTextStreamFunction
-
Deprecated.
- SocketTextStreamFunction(String, int, String, long, long) - Constructor for class org.apache.flink.streaming.api.functions.source.legacy.SocketTextStreamFunction
-
Deprecated.
- SolutionSetBroker - Class in org.apache.flink.runtime.iterative.concurrent
-
Used to hand over the hash-join from the iteration head to the solution-set match.
- SolutionSetFastUpdateOutputCollector<T> - Class in org.apache.flink.runtime.iterative.io
-
A
Collectorto update the solution set of a workset iteration. - SolutionSetFastUpdateOutputCollector(CompactingHashTable<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetFastUpdateOutputCollector
- SolutionSetFastUpdateOutputCollector(CompactingHashTable<T>, Collector<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetFastUpdateOutputCollector
- SolutionSetObjectsUpdateOutputCollector<T> - Class in org.apache.flink.runtime.iterative.io
-
A
Collectorto update the solution set of a workset iteration. - SolutionSetObjectsUpdateOutputCollector(JoinHashMap<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetObjectsUpdateOutputCollector
- SolutionSetObjectsUpdateOutputCollector(JoinHashMap<T>, Collector<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetObjectsUpdateOutputCollector
- SolutionSetUpdateBarrier - Class in org.apache.flink.runtime.iterative.concurrent
-
Resettable barrier to synchronize the
IterationHeadTaskand theIterationTailTaskin case of iterations that contain a separate solution set tail. - SolutionSetUpdateBarrier() - Constructor for class org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrier
- SolutionSetUpdateBarrierBroker - Class in org.apache.flink.runtime.iterative.concurrent
- SolutionSetUpdateOutputCollector<T> - Class in org.apache.flink.runtime.iterative.io
-
A
Collectorto update the solution set of a workset iteration. - SolutionSetUpdateOutputCollector(CompactingHashTable<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetUpdateOutputCollector
- SolutionSetUpdateOutputCollector(CompactingHashTable<T>, Collector<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetUpdateOutputCollector
- sort(IndexedSortable) - Method in class org.apache.flink.runtime.operators.sort.HeapSort
- sort(IndexedSortable) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSorter
- sort(IndexedSortable) - Method in class org.apache.flink.runtime.operators.sort.QuickSort
- sort(IndexedSortable, int, int) - Method in class org.apache.flink.runtime.operators.sort.HeapSort
- sort(IndexedSortable, int, int) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSorter
-
Sort the items accessed through the given IndexedSortable over the given range of logical indices.
- sort(IndexedSortable, int, int) - Method in class org.apache.flink.runtime.operators.sort.QuickSort
-
Sort the given range of items using quick sort.
- SORT - org.apache.flink.runtime.operators.sort.StageRunner.SortStage
- SORT - org.apache.flink.runtime.operators.util.LocalStrategy
- SortBasedDataBuffer - Class in org.apache.flink.runtime.io.network.partition
-
When getting buffers, The
SortBasedDataBuffershould recycle the read target buffer with the givenBufferRecycler. - SortBasedDataBuffer(LinkedList<MemorySegment>, BufferRecycler, int, int, int, int[]) - Constructor for class org.apache.flink.runtime.io.network.partition.SortBasedDataBuffer
- SortBuffer - Class in org.apache.flink.runtime.io.network.partition
-
A
DataBufferimplementation which sorts all appended records only by subpartition index. - SortBuffer(LinkedList<MemorySegment>, BufferRecycler, int, int, int, int[]) - Constructor for class org.apache.flink.runtime.io.network.partition.SortBuffer
- SortBufferAccumulator - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage
-
The sort-based implementation of the
BufferAccumulator. - SortBufferAccumulator(int, int, int, TieredStorageMemoryManager, boolean) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.SortBufferAccumulator
- sortBuffers(int) - Method in class org.apache.flink.runtime.operators.sort.ExternalSorterBuilder
- SORTED - org.apache.flink.streaming.api.graph.StreamConfig.InputRequirement
-
Records from all sorted inputs are grouped (sorted) by key and are then fed to the operator one group at a time.
- SORTED_GROUP_COMBINE - org.apache.flink.runtime.operators.DriverStrategy
- SORTED_GROUP_REDUCE - org.apache.flink.runtime.operators.DriverStrategy
- SORTED_PARTIAL_REDUCE - org.apache.flink.runtime.operators.DriverStrategy
- SORTED_REDUCE - org.apache.flink.runtime.operators.DriverStrategy
- Sorter<E> - Interface in org.apache.flink.runtime.operators.sort
-
The SortMerger interface representing the public interface to all specific Sort-Merge implementations.
- sorterFactory(InMemorySorterFactory<T>) - Method in class org.apache.flink.runtime.operators.sort.ExternalSorterBuilder
- sortFieldSelector - Variable in class org.apache.flink.streaming.api.operators.sortpartition.KeyedSortPartitionOperator
-
The selector to create the sort key for records, which will be null if it's not used.
- sortFieldSelector - Variable in class org.apache.flink.streaming.api.operators.sortpartition.SortPartitionOperator
-
The selector to create the sort key for records, which will be null if it's not used.
- SortingDataInput<T,K> - Class in org.apache.flink.streaming.api.operators.sort
-
A
StreamTaskInputwhich sorts in the incoming records from a chained input. - SortingDataInput(StreamTaskInput<T>, TypeSerializer<T>, TypeSerializer<K>, KeySelector<T, K>, MemoryManager, IOManager, boolean, double, Configuration, TaskInvokable, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.operators.sort.SortingDataInput
- SortMergeResultPartition - Class in org.apache.flink.runtime.io.network.partition
-
SortMergeResultPartitionappends records and events toDataBufferand after theDataBufferis full, all data in theDataBufferwill be copied and spilled to aPartitionedFilein subpartition index order sequentially. - SortMergeResultPartition(String, int, ResultPartitionID, ResultPartitionType, int, int, BatchShuffleReadBufferPool, Executor, ResultPartitionManager, String, BufferCompressor, SupplierWithException<BufferPool, IOException>) - Constructor for class org.apache.flink.runtime.io.network.partition.SortMergeResultPartition
- sortPartition(int, Order) - Method in class org.apache.flink.streaming.api.datastream.KeyedPartitionWindowedStream
- sortPartition(int, Order) - Method in class org.apache.flink.streaming.api.datastream.NonKeyedPartitionWindowedStream
- sortPartition(int, Order) - Method in interface org.apache.flink.streaming.api.datastream.PartitionWindowedStream
-
Sorts the records of the window on the specified field in the specified order.
- sortPartition(String, Order) - Method in class org.apache.flink.streaming.api.datastream.KeyedPartitionWindowedStream
- sortPartition(String, Order) - Method in class org.apache.flink.streaming.api.datastream.NonKeyedPartitionWindowedStream
- sortPartition(String, Order) - Method in interface org.apache.flink.streaming.api.datastream.PartitionWindowedStream
-
Sorts the records of the window on the specified field in the specified order.
- sortPartition(KeySelector<T, K>, Order) - Method in class org.apache.flink.streaming.api.datastream.KeyedPartitionWindowedStream
- sortPartition(KeySelector<T, K>, Order) - Method in class org.apache.flink.streaming.api.datastream.NonKeyedPartitionWindowedStream
- sortPartition(KeySelector<T, K>, Order) - Method in interface org.apache.flink.streaming.api.datastream.PartitionWindowedStream
-
Sorts the records according to a
KeySelectorin the specified order. - SortPartitionOperator<INPUT> - Class in org.apache.flink.streaming.api.operators.sortpartition
-
The
SortPartitionOperatorsorts records of a partition on non-keyed data stream. - SortPartitionOperator(TypeInformation<INPUT>, int, Order) - Constructor for class org.apache.flink.streaming.api.operators.sortpartition.SortPartitionOperator
- SortPartitionOperator(TypeInformation<INPUT>, String, Order) - Constructor for class org.apache.flink.streaming.api.operators.sortpartition.SortPartitionOperator
- SortPartitionOperator(TypeInformation<INPUT>, KeySelector<INPUT, K>, Order) - Constructor for class org.apache.flink.streaming.api.operators.sortpartition.SortPartitionOperator
- sortShuffleMinBuffers() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- sortShuffleMinParallelism() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- source() - Method in class org.apache.flink.streaming.api.lineage.DefaultLineageEdge
- source() - Method in interface org.apache.flink.streaming.api.lineage.LineageEdge
- SOURCE - org.apache.flink.runtime.operators.DriverStrategy
- SOURCE_IDLE_TIME - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- SourceCoordinator<SplitT extends org.apache.flink.api.connector.source.SourceSplit,EnumChkT> - Class in org.apache.flink.runtime.source.coordinator
-
The default implementation of the
OperatorCoordinatorfor theSource. - SourceCoordinator(String, Source<?, SplitT, EnumChkT>, SourceCoordinatorContext<SplitT>, CoordinatorStore) - Constructor for class org.apache.flink.runtime.source.coordinator.SourceCoordinator
- SourceCoordinator(String, Source<?, SplitT, EnumChkT>, SourceCoordinatorContext<SplitT>, CoordinatorStore, WatermarkAlignmentParams, String) - Constructor for class org.apache.flink.runtime.source.coordinator.SourceCoordinator
- SourceCoordinator.WatermarkElement - Class in org.apache.flink.runtime.source.coordinator
-
The watermark element for
HeapPriorityQueue. - SourceCoordinatorContext<SplitT extends org.apache.flink.api.connector.source.SourceSplit> - Class in org.apache.flink.runtime.source.coordinator
-
A context class for the
OperatorCoordinator. - SourceCoordinatorContext(SourceCoordinatorProvider.CoordinatorExecutorThreadFactory, int, OperatorCoordinator.Context, SimpleVersionedSerializer<SplitT>, boolean) - Constructor for class org.apache.flink.runtime.source.coordinator.SourceCoordinatorContext
- SourceCoordinatorProvider<SplitT extends org.apache.flink.api.connector.source.SourceSplit> - Class in org.apache.flink.runtime.source.coordinator
-
The provider of
SourceCoordinator. - SourceCoordinatorProvider(String, OperatorID, Source<?, SplitT, ?>, int, WatermarkAlignmentParams, String) - Constructor for class org.apache.flink.runtime.source.coordinator.SourceCoordinatorProvider
-
Construct the
SourceCoordinatorProvider. - SourceCoordinatorProvider.CoordinatorExecutorThreadFactory - Class in org.apache.flink.runtime.source.coordinator
-
A thread factory class that provides some helper methods.
- SourceCoordinatorSerdeUtils - Class in org.apache.flink.runtime.source.coordinator
-
A serialization util class for the
SourceCoordinator. - SourceEventWrapper - Class in org.apache.flink.runtime.source.event
-
A wrapper operator event that contains a custom defined operator event.
- SourceEventWrapper(SourceEvent) - Constructor for class org.apache.flink.runtime.source.event.SourceEventWrapper
- SourceFunction<T> - Interface in org.apache.flink.streaming.api.functions.source.legacy
-
Deprecated.This interface will be removed in future versions. Use the new
Sourceinterface instead. NOTE: All sub-tasks from FLINK-28045 must be closed before this API can be completely removed. - SourceFunction.SourceContext<T> - Interface in org.apache.flink.streaming.api.functions.source.legacy
-
Deprecated.Interface that source functions use to emit elements, and possibly watermarks.
- SourceInputConfig(StreamEdge) - Constructor for class org.apache.flink.streaming.api.graph.StreamConfig.SourceInputConfig
- SourceLineageVertex - Interface in org.apache.flink.streaming.api.lineage
-
Lineage vertex for source which has
Boundednessto indicate whether the data for the source is bounded. - SourceOperator<OUT,SplitT extends org.apache.flink.api.connector.source.SourceSplit> - Class in org.apache.flink.streaming.api.operators
-
Base source operator only used for integrating the source reader which is proposed by FLIP-27.
- SourceOperator(StreamOperatorParameters<OUT>, FunctionWithException<SourceReaderContext, SourceReader<OUT, SplitT>, Exception>, OperatorEventGateway, SimpleVersionedSerializer<SplitT>, WatermarkStrategy<OUT>, ProcessingTimeService, Configuration, String, boolean, StreamTask.CanEmitBatchOfRecordsChecker) - Constructor for class org.apache.flink.streaming.api.operators.SourceOperator
- SourceOperatorFactory<OUT> - Class in org.apache.flink.streaming.api.operators
-
The Factory class for
SourceOperator. - SourceOperatorFactory(Source<OUT, ?, ?>, WatermarkStrategy<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.SourceOperatorFactory
- SourceOperatorFactory(Source<OUT, ?, ?>, WatermarkStrategy<OUT>, boolean) - Constructor for class org.apache.flink.streaming.api.operators.SourceOperatorFactory
- SourceOperatorFactory(Source<OUT, ?, ?>, WatermarkStrategy<OUT>, boolean, int) - Constructor for class org.apache.flink.streaming.api.operators.SourceOperatorFactory
- SourceOperatorStreamTask<T> - Class in org.apache.flink.streaming.runtime.tasks
-
A subclass of
StreamTaskfor executing theSourceOperator. - SourceOperatorStreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask
- SourceOperatorStreamTask.AsyncDataOutputToOutput<T> - Class in org.apache.flink.streaming.runtime.tasks
-
Implementation of
PushingAsyncDataInput.DataOutputthat wraps a specificOutput. - SourceOutputWithWatermarks<T> - Class in org.apache.flink.streaming.api.operators.source
-
Implementation of the SourceOutput.
- SourceOutputWithWatermarks(PushingAsyncDataInput.DataOutput<T>, WatermarkOutput, WatermarkOutput, TimestampAssigner<T>, WatermarkGenerator<T>) - Constructor for class org.apache.flink.streaming.api.operators.source.SourceOutputWithWatermarks
-
Creates a new SourceOutputWithWatermarks that emits records to the given DataOutput and watermarks to the (possibly different) WatermarkOutput.
- sources() - Method in class org.apache.flink.streaming.api.lineage.DefaultLineageGraph
- sources() - Method in interface org.apache.flink.streaming.api.lineage.LineageGraph
- SourceStreamTask<OUT,SRC extends SourceFunction<OUT>,OP extends StreamSource<OUT,SRC>> - Class in org.apache.flink.streaming.runtime.tasks
-
Deprecated.This class is based on the
SourceFunctionAPI, which is due to be removed. Use the newSourceAPI instead. - SourceStreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
Deprecated.
- SourceTransformation<OUT,SplitT extends org.apache.flink.api.connector.source.SourceSplit,EnumChkT> - Class in org.apache.flink.streaming.api.transformations
-
A
PhysicalTransformationforSource. - SourceTransformation(String, Source<OUT, SplitT, EnumChkT>, WatermarkStrategy<OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.SourceTransformation
-
Creates a new
Transformationwith the given name, output type and parallelism. - SourceTransformation(String, Source<OUT, SplitT, EnumChkT>, WatermarkStrategy<OUT>, TypeInformation<OUT>, int, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.SourceTransformation
- SourceTransformationTranslator<OUT,SplitT extends org.apache.flink.api.connector.source.SourceSplit,EnumChkT> - Class in org.apache.flink.streaming.runtime.translators
-
A
TransformationTranslatorfor theSourceTransformation. - SourceTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.SourceTransformationTranslator
- SourceTransformationWrapper<T> - Class in org.apache.flink.streaming.api.transformations
-
This Transformation is a phantom transformation which is used to expose a default parallelism to downstream.
- SourceTransformationWrapper(Transformation<T>) - Constructor for class org.apache.flink.streaming.api.transformations.SourceTransformationWrapper
- spaceStat - Variable in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
-
The current space statistic, updated on file creation/deletion.
- SpaceStat() - Constructor for class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager.SpaceStat
- SpaceStat(long, long, long, long) - Constructor for class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager.SpaceStat
- SpeculativeExecutionHandler - Interface in org.apache.flink.runtime.scheduler.adaptivebatch
-
Interface for managing speculative execution of tasks and handling slow task detection.
- SpeculativeExecutionJobVertex - Class in org.apache.flink.runtime.executiongraph
-
The ExecutionJobVertex which supports speculative execution.
- SpeculativeExecutionJobVertex(InternalExecutionGraphAccessor, JobVertex, VertexParallelismInformation, CoordinatorStore, JobManagerJobMetricGroup) - Constructor for class org.apache.flink.runtime.executiongraph.SpeculativeExecutionJobVertex
- SpeculativeExecutionJobVertex.Factory - Class in org.apache.flink.runtime.executiongraph
-
Factory to create
SpeculativeExecutionJobVertex. - SpeculativeExecutionVertex - Class in org.apache.flink.runtime.executiongraph
-
The ExecutionVertex which supports speculative execution.
- SpeculativeExecutionVertex(ExecutionJobVertex, int, IntermediateResult[], Duration, long, int, int) - Constructor for class org.apache.flink.runtime.executiongraph.SpeculativeExecutionVertex
- SPILL - org.apache.flink.runtime.operators.sort.StageRunner.SortStage
- spillHeadCopy - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
- SpillingAdaptiveSpanningRecordDeserializer<T extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.serialization
- SpillingAdaptiveSpanningRecordDeserializer(String[]) - Constructor for class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
- SpillingAdaptiveSpanningRecordDeserializer(String[], int, int) - Constructor for class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
- SpillingBuffer - Class in org.apache.flink.runtime.io.disk
-
An output view that buffers written data in memory pages and spills them when they are full.
- SpillingBuffer(IOManager, MemorySegmentSource, int) - Constructor for class org.apache.flink.runtime.io.disk.SpillingBuffer
- SpillingResettableIterator<T> - Class in org.apache.flink.runtime.operators.resettable
-
Implementation of a resettable iterator.
- SpillingResettableIterator(Iterator<T>, TypeSerializer<T>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
- SpillingResettableIterator(Iterator<T>, TypeSerializer<T>, MemoryManager, IOManager, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
- SpillingResettableMutableObjectIterator<T> - Class in org.apache.flink.runtime.operators.resettable
-
Implementation of a resettable iterator.
- SpillingResettableMutableObjectIterator(MutableObjectIterator<T>, TypeSerializer<T>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
- SpillingResettableMutableObjectIterator(MutableObjectIterator<T>, TypeSerializer<T>, MemoryManager, IOManager, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
- spillPartition() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Selects a partition and spills it.
- spillPartition(List<MemorySegment>, IOManager, FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
Spills this partition to disk and sets it up such that it continues spilling records that are added to it.
- SPLIT_DISTRIBUTE - org.apache.flink.runtime.state.OperatorStateHandle.Mode
- SplitAssignmentTracker<SplitT extends org.apache.flink.api.connector.source.SourceSplit> - Class in org.apache.flink.runtime.source.coordinator
-
A class that is responsible for tracking the past split assignments made by
SplitEnumerator. - SplitAssignmentTracker() - Constructor for class org.apache.flink.runtime.source.coordinator.SplitAssignmentTracker
- splitFinished(String) - Method in interface org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks.WatermarkUpdateListener
-
Notifies that split has finished.
- splitFinished(String) - Method in class org.apache.flink.streaming.api.operators.SourceOperator
- splits(SimpleVersionedSerializer<SplitT>) - Method in class org.apache.flink.runtime.source.event.AddSplitEvent
- splitZooKeeperPath(String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Splits the given ZooKeeper path into its parts.
- SsgNetworkMemoryCalculationUtils - Class in org.apache.flink.runtime.scheduler
-
Util to analyze inputs & outputs of
ExecutionJobVertexand calculate network memory requirement for slot sharing group (SSG). - SSLHandlerFactory - Class in org.apache.flink.runtime.io.network.netty
-
Creates and configures
SslHandlerinstances. - SSLHandlerFactory(SslContext, int, int) - Constructor for class org.apache.flink.runtime.io.network.netty.SSLHandlerFactory
-
Create a new
SslHandlerfactory. - SSLUtils - Class in org.apache.flink.runtime.net
-
Common utilities to manage SSL transport settings.
- SSLUtils() - Constructor for class org.apache.flink.runtime.net.SSLUtils
- StageRunner - Interface in org.apache.flink.runtime.operators.sort
-
An interface for different stages of the sorting process.
- StageRunner.SortStage - Enum in org.apache.flink.runtime.operators.sort
-
A marker interface for sending messages to different stages.
- StageRunner.StageMessageDispatcher<E> - Interface in org.apache.flink.runtime.operators.sort
-
A dispatcher for inter-stage communication.
- StandaloneCheckpointIDCounter - Class in org.apache.flink.runtime.checkpoint
-
CheckpointIDCounterinstances for JobManagers running inHighAvailabilityMode.NONE. - StandaloneCheckpointIDCounter() - Constructor for class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
- StandaloneCheckpointRecoveryFactory - Class in org.apache.flink.runtime.checkpoint
-
CheckpointCoordinatorcomponents inHighAvailabilityMode.NONE. - StandaloneCheckpointRecoveryFactory() - Constructor for class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
- StandaloneClientHAServices - Class in org.apache.flink.runtime.highavailability.nonha.standalone
-
Non-HA implementation for
ClientHighAvailabilityServices. - StandaloneClientHAServices(String) - Constructor for class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneClientHAServices
- StandaloneCompletedCheckpointStore - Class in org.apache.flink.runtime.checkpoint
-
CompletedCheckpointStorefor JobManagers running inHighAvailabilityMode.NONE. - StandaloneCompletedCheckpointStore(int) - Constructor for class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
- StandaloneCompletedCheckpointStore(int, SharedStateRegistryFactory, Executor, RecoveryClaimMode) - Constructor for class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
-
Creates
StandaloneCompletedCheckpointStore. - StandaloneDispatcher - Class in org.apache.flink.runtime.dispatcher
- StandaloneDispatcher(RpcService, DispatcherId, Collection<JobGraph>, Collection<JobResult>, DispatcherBootstrapFactory, DispatcherServices) - Constructor for class org.apache.flink.runtime.dispatcher.StandaloneDispatcher
- StandaloneHaServices - Class in org.apache.flink.runtime.highavailability.nonha.standalone
-
An implementation of the
HighAvailabilityServicesfor the non-high-availability case. - StandaloneHaServices(String, String, String) - Constructor for class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
Creates a new services class for the fix pre-defined leaders.
- StandaloneJobGraphStore - Class in org.apache.flink.runtime.jobmanager
-
JobGraphinstances for JobManagers running inHighAvailabilityMode.NONE. - StandaloneJobGraphStore() - Constructor for class org.apache.flink.runtime.jobmanager.StandaloneJobGraphStore
- StandaloneLeaderElection - Class in org.apache.flink.runtime.leaderelection
-
StandaloneLeaderElectionimplementsLeaderElectionfor non-HA cases. - StandaloneLeaderElection(UUID) - Constructor for class org.apache.flink.runtime.leaderelection.StandaloneLeaderElection
- StandaloneLeaderRetrievalService - Class in org.apache.flink.runtime.leaderretrieval
-
Standalone implementation of the
LeaderRetrievalService. - StandaloneLeaderRetrievalService(String) - Constructor for class org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
-
Deprecated.Use
StandaloneLeaderRetrievalService(String, UUID)instead - StandaloneLeaderRetrievalService(String, UUID) - Constructor for class org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
-
Creates a StandaloneLeaderRetrievalService with the given leader address.
- StandaloneResourceManager - Class in org.apache.flink.runtime.resourcemanager
-
A standalone implementation of the resource manager.
- StandaloneResourceManager(RpcService, UUID, ResourceID, HeartbeatServices, DelegationTokenManager, SlotManager, ResourceManagerPartitionTrackerFactory, BlocklistHandler.Factory, JobLeaderIdService, ClusterInformation, FatalErrorHandler, ResourceManagerMetricGroup, Duration, Duration, Executor) - Constructor for class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
- StandaloneResourceManagerFactory - Class in org.apache.flink.runtime.resourcemanager
-
ResourceManagerFactorywhich creates aStandaloneResourceManager. - StandaloneSessionClusterEntrypoint - Class in org.apache.flink.runtime.entrypoint
-
Entry point for the standalone session cluster.
- StandaloneSessionClusterEntrypoint(Configuration) - Constructor for class org.apache.flink.runtime.entrypoint.StandaloneSessionClusterEntrypoint
- StandardSinkTopologies - Class in org.apache.flink.streaming.api.connector.sink2
-
This utility class provides building blocks for custom topologies.
- start() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
-
Starts the
CheckpointIDCounterservice down. - start() - Method in enum org.apache.flink.runtime.checkpoint.DeactivatedCheckpointIDCounter
- start() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
- start() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
- start() - Method in class org.apache.flink.runtime.dispatcher.cleanup.CheckpointResourcesCleanupRunner
- start() - Method in class org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess
- start() - Method in enum org.apache.flink.runtime.dispatcher.runner.StoppedDispatcherLeaderProcess
- start() - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
-
Starts the internal related components for network connection and communication.
- start() - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
- start() - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
- start() - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
- start() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageConsumerClient
- start() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskTierConsumerAgent
- start() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory.MemoryTierConsumerAgent
- start() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteStorageScanner
-
Start the executor.
- start() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierConsumerAgent
- start() - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierConsumerAgent
-
Start the consumer agent.
- start() - Method in class org.apache.flink.runtime.jobmaster.event.FileSystemJobEventStore
- start() - Method in class org.apache.flink.runtime.jobmaster.event.JobEventManager
-
Start the job event manager.
- start() - Method in interface org.apache.flink.runtime.jobmaster.event.JobEventStore
-
Start the store.
- start() - Method in interface org.apache.flink.runtime.jobmaster.JobManagerRunner
-
Start the execution of the
JobMaster. - start() - Method in class org.apache.flink.runtime.jobmaster.JobMasterServiceLeadershipRunner
- start() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
Starts the mini cluster, based on the configured properties.
- start() - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator
-
Starts the coordinator.
- start() - Method in class org.apache.flink.runtime.operators.coordination.OperatorCoordinatorHolder
- start() - Method in class org.apache.flink.runtime.operators.coordination.RecreateOnResetOperatorCoordinator
- start() - Method in interface org.apache.flink.runtime.operators.sort.StageRunner
-
Starts the stage.
- start() - Method in interface org.apache.flink.runtime.query.KvStateServer
-
Starts the server.
- start() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
- start() - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerService
-
Start the service.
- start() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerServiceImpl
- start() - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
-
Starts this REST server endpoint.
- start() - Method in interface org.apache.flink.runtime.shuffle.ShuffleEnvironment
-
Start the internal related services before using the shuffle service environment.
- start() - Method in interface org.apache.flink.runtime.shuffle.ShuffleMaster
-
Starts this shuffle master as a service.
- start() - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinator
- start() - Method in class org.apache.flink.runtime.taskexecutor.KvStateService
- start() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorToServiceAdapter
- start() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
- start() - Method in interface org.apache.flink.runtime.taskexecutor.TaskManagerRunner.TaskExecutorService
- start() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
- start() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
- start() - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
- start(long, CheckpointOptions) - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter.NoOpChannelStateWriter
- start(long, CheckpointOptions) - Method in interface org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter
-
Initiate write of channel state for the given checkpoint id.
- start(long, CheckpointOptions) - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriterImpl
- start(String, RpcService, HighAvailabilityServices, JobLeaderListener) - Method in class org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService
- start(String, RpcService, HighAvailabilityServices, JobLeaderListener) - Method in interface org.apache.flink.runtime.taskexecutor.JobLeaderService
-
Start the job leader service with the given services.
- start(ComponentMainThreadExecutor) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- start(ComponentMainThreadExecutor) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- start(ComponentMainThreadExecutor) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlotRequestBulkChecker
-
Starts the bulk checker by initializing the main thread executor.
- start(ComponentMainThreadExecutor) - Method in class org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlotRequestBulkCheckerImpl
- start(ExecutionGraph, SlowTaskDetectorListener, ComponentMainThreadExecutor) - Method in class org.apache.flink.runtime.scheduler.slowtaskdetector.ExecutionTimeBasedSlowTaskDetector
- start(ExecutionGraph, SlowTaskDetectorListener, ComponentMainThreadExecutor) - Method in interface org.apache.flink.runtime.scheduler.slowtaskdetector.SlowTaskDetector
-
Start detecting slow tasks periodically.
- start(JobGraphStore.JobGraphListener) - Method in class org.apache.flink.runtime.jobmanager.DefaultJobGraphStore
- start(JobGraphStore.JobGraphListener) - Method in interface org.apache.flink.runtime.jobmanager.JobGraphStore
-
Starts the
JobGraphStoreservice. - start(JobGraphStore.JobGraphListener) - Method in interface org.apache.flink.runtime.jobmanager.JobGraphStoreWatcher
-
Start the watcher on
JobGraphStore. - start(JobGraphStore.JobGraphListener) - Method in enum org.apache.flink.runtime.jobmanager.NoOpJobGraphStoreWatcher
- start(JobGraphStore.JobGraphListener) - Method in class org.apache.flink.runtime.jobmanager.StandaloneJobGraphStore
- start(JobGraphStore.JobGraphListener) - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperJobGraphStoreWatcher
- start(JobMasterId, String) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPoolService
- start(JobMasterId, String) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
- start(JobMasterId, String) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolService
-
Start the encapsulated slot pool implementation.
- start(LeaderRetrievalListener) - Method in class org.apache.flink.runtime.leaderretrieval.DefaultLeaderRetrievalService
- start(LeaderRetrievalListener) - Method in interface org.apache.flink.runtime.leaderretrieval.LeaderRetrievalService
-
Starts the leader retrieval service with the given listener to listen for new leaders.
- start(LeaderRetrievalListener) - Method in class org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
- start(JobLeaderIdActions) - Method in class org.apache.flink.runtime.resourcemanager.DefaultJobLeaderIdService
- start(JobLeaderIdActions) - Method in interface org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
Start the service with the given job leader actions.
- start(ResourceManagerId, Executor, ResourceAllocator, ResourceEventListener, BlockedTaskManagerChecker) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedSlotManager
-
Starts the slot manager with the given leader id and resource manager actions.
- start(ResourceManagerId, Executor, ResourceAllocator, ResourceEventListener, BlockedTaskManagerChecker) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Starts the slot manager with the given leader id and resource manager actions.
- start(DelegationTokenManager.Listener) - Method in class org.apache.flink.runtime.security.token.DefaultDelegationTokenManager
-
Creates a re-occurring task which obtains new tokens and automatically distributes them to task managers.
- start(DelegationTokenManager.Listener) - Method in interface org.apache.flink.runtime.security.token.DelegationTokenManager
-
Creates a re-occurring task which obtains new tokens and automatically distributes them to all receivers (in local JVM as well as in registered task managers too).
- start(DelegationTokenManager.Listener) - Method in class org.apache.flink.runtime.security.token.NoOpDelegationTokenManager
- start(SlotActions, ComponentMainThreadExecutor) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Start the task slot table with the given slot actions.
- start(SlotActions, ComponentMainThreadExecutor) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- start(TimeoutListener<K>) - Method in class org.apache.flink.runtime.taskexecutor.slot.DefaultTimerService
- start(TimeoutListener<K>) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TimerService
-
Starts this timer service.
- START_WORKER_FAILURE_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- startAllOperatorCoordinators() - Method in class org.apache.flink.runtime.scheduler.DefaultOperatorCoordinatorHandler
- startAllOperatorCoordinators() - Method in interface org.apache.flink.runtime.scheduler.OperatorCoordinatorHandler
-
Start all operator coordinators.
- startCheckpointScheduler() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
- startCheckpointScheduler() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointScheduling
-
Starts the periodic scheduling if possible.
- startCheckpointScheduler() - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- startCluster() - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
- startCuratorFramework(Configuration, FatalErrorHandler) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Starts a
CuratorFrameworkinstance and connects it to the given ZooKeeper quorum. - startCuratorFramework(CuratorFrameworkFactory.Builder, FatalErrorHandler) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Starts a
CuratorFrameworkinstance and connects it to the given ZooKeeper quorum from a builder. - startFetchAndRetainPartitionWithMetricsOnTaskManager() - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- startFetchAndRetainPartitionWithMetricsOnTaskManager() - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Notify jobMaster to fetch and retain partitions on task managers.
- startIfConfigured(Logger, Configuration, CompletableFuture<Void>) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
- startIndex - Variable in class org.apache.flink.runtime.executiongraph.IndexRange
- startInternal() - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
-
Hook to start sub class specific services.
- startInternal() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
- startLatencyMeasurement() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxMetricsController
-
Starts mailbox latency measurement.
- startLeaderElection(LeaderContender) - Method in interface org.apache.flink.runtime.leaderelection.LeaderElection
-
Registers the passed
LeaderContenderwith the leader election process. - startLeaderElection(LeaderContender) - Method in class org.apache.flink.runtime.leaderelection.StandaloneLeaderElection
- startLocalMetricsRpcService(Configuration, RpcSystem) - Static method in class org.apache.flink.runtime.metrics.util.MetricUtils
- startNewChain() - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Starts a new task chain beginning at this operator.
- startNewKeyGroup(int) - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
-
User code can call this method to signal that it begins to write a new key group with the given key group id.
- startNewPartition() - Method in class org.apache.flink.runtime.state.OperatorStateCheckpointOutputStream
-
User code can call this method to signal that it begins to write a new partition of operator state.
- startNewRegion(boolean) - Method in class org.apache.flink.runtime.io.network.partition.PartitionedFileWriter
-
Persists the region index of the current data region and starts a new region to write.
- startNextSuperstep() - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
- startNextSuperstep() - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
- startPeriodicWatermarkEmits() - Method in class org.apache.flink.streaming.api.operators.source.NoOpTimestampsAndWatermarks
- startPeriodicWatermarkEmits() - Method in class org.apache.flink.streaming.api.operators.source.ProgressiveTimestampsAndWatermarks
- startPeriodicWatermarkEmits() - Method in interface org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks
-
Starts emitting periodic watermarks, if this implementation produces watermarks, and if periodic watermarks are configured.
- startPersisting(long, List<Buffer>) - Method in class org.apache.flink.runtime.io.network.partition.consumer.ChannelStatePersister
- startQueryService(RpcService, ResourceID) - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
Initializes the MetricQueryService.
- startReading() - Method in class org.apache.flink.runtime.operators.TempBarrier
- startRecovering() - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.BatchJobRecoveryHandler
-
Starts the recovery process.
- startRecovering() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DefaultBatchJobRecoveryHandler
- startRecovering() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DummyBatchJobRecoveryHandler
- startRegistration() - Method in class org.apache.flink.runtime.registration.RetryingRegistration
-
This method resolves the target address to a callable gateway and starts the registration after that.
- startRemoteMetricsRpcService(Configuration, String, String, RpcSystem) - Static method in class org.apache.flink.runtime.metrics.util.MetricUtils
- startReplay() - Method in interface org.apache.flink.runtime.jobmaster.event.JobEventReplayHandler
-
Called when starting replaying job event.
- startReplay() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DefaultBatchJobRecoveryHandler
- startScheduling() - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- startScheduling() - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- startScheduling() - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
- startScheduling() - Method in class org.apache.flink.runtime.scheduler.strategy.PipelinedRegionSchedulingStrategy
- startScheduling() - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingStrategy
-
Called when the scheduling is started (initial scheduling operation).
- startScheduling() - Method in class org.apache.flink.runtime.scheduler.strategy.VertexwiseSchedulingStrategy
- startSchedulingInternal() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.AdaptiveBatchScheduler
- startSchedulingInternal() - Method in class org.apache.flink.runtime.scheduler.DefaultScheduler
- startSchedulingInternal() - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- startTaskManager() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
Starts additional TaskManager process.
- startTaskManager(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, TaskExecutorBlobService, boolean, ExternalResourceInfoProvider, WorkingDirectory, FatalErrorHandler, DelegationTokenReceiverRepository) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
- startTaskThread() - Method in class org.apache.flink.runtime.taskmanager.Task
-
Starts the task's thread.
- startTime - Variable in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator.PendingStatsRequest
-
The time when the request is created.
- startTimerService(TypeSerializer<K>, TypeSerializer<N>, Triggerable<K, N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
-
Starts the local
InternalTimerServiceImplby: Setting thekeySerializedandnamespaceSerializerfor the timers it will contain. - startTrackingPartition(JobID, TaskExecutorPartitionInfo) - Method in interface org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTracker
-
Starts the tracking of the given partition for the given job.
- startTrackingPartition(JobID, TaskExecutorPartitionInfo) - Method in class org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTrackerImpl
- startTrackingPartition(ResourceID, ResultPartitionDeploymentDescriptor) - Method in interface org.apache.flink.runtime.io.network.partition.JobMasterPartitionTracker
-
Starts the tracking of the given partition for the given task executor ID.
- startTrackingPartition(ResourceID, ResultPartitionDeploymentDescriptor) - Method in class org.apache.flink.runtime.io.network.partition.JobMasterPartitionTrackerImpl
- startTrackingPartitions(K, Collection<ResultPartitionID>) - Method in class org.apache.flink.runtime.taskexecutor.partition.PartitionTable
-
Starts the tracking of the given partition for the given key.
- startTrackingPendingDeploymentOf(ExecutionAttemptID, ResourceID) - Method in class org.apache.flink.runtime.jobmaster.DefaultExecutionDeploymentTracker
- startTrackingPendingDeploymentOf(ExecutionAttemptID, ResourceID) - Method in interface org.apache.flink.runtime.jobmaster.ExecutionDeploymentTracker
-
Starts tracking the given execution that is being deployed on the given host.
- STARTUP_FAILURE_RETURN_CODE - Static variable in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
- state - Variable in class org.apache.flink.runtime.state.SnapshotDirectory
-
This reference tracks the lifecycle state of the snapshot directory.
- StateAdaptor<K,N,S extends InternalKvState<K,N,?>> - Class in org.apache.flink.runtime.state.v2.adaptor
-
An base implementation of state adaptor from v1 to v2.
- StateAssignmentOperation - Class in org.apache.flink.runtime.checkpoint
-
This class encapsulates the operation of assigning restored state when restoring from a checkpoint.
- StateAssignmentOperation(long, Set<ExecutionJobVertex>, Map<OperatorID, OperatorState>, boolean) - Constructor for class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
- stateBackend - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Our state backend.
- StateBackend - Interface in org.apache.flink.runtime.state
-
A State Backend defines how the state of a streaming application is stored locally within the cluster.
- StateBackend.CustomInitializationMetrics - Interface in org.apache.flink.runtime.state
- StateBackend.KeyedStateBackendParameters<K> - Interface in org.apache.flink.runtime.state
-
Parameters passed to
StateBackend.createKeyedStateBackend(KeyedStateBackendParameters). - StateBackend.OperatorStateBackendParameters - Interface in org.apache.flink.runtime.state
-
Parameters passed to
StateBackend.createOperatorStateBackend(OperatorStateBackendParameters). - StateBackendBuilder<T,E extends Throwable> - Interface in org.apache.flink.runtime.state
-
A mutable builder to build a state backend instance.
- StateBackendFactory<T extends StateBackend> - Interface in org.apache.flink.runtime.state
-
A factory to create a specific state backend.
- stateBackendFromApplicationOrConfigOrDefaultUseManagedMemory(Configuration, Optional<Boolean>, ClassLoader) - Static method in class org.apache.flink.runtime.state.StateBackendLoader
-
Checks whether state backend uses managed memory, without having to deserialize or load the state backend.
- StateBackendLoader - Class in org.apache.flink.runtime.state
-
This class contains utility methods to load state backends from configurations.
- StateChange - Class in org.apache.flink.runtime.state.changelog
-
Change of state of a keyed operator.
- stateChanged(CuratorFramework, ConnectionState) - Method in class org.apache.flink.runtime.checkpoint.DefaultLastStateConnectionStateListener
- StateChangelogHandleReader<Handle extends ChangelogStateHandle> - Interface in org.apache.flink.runtime.state.changelog
-
Allows to read state changelog referenced by the provided
ChangelogStateHandle. - StateChangelogHandleStreamHandleReader - Class in org.apache.flink.runtime.state.changelog
-
A reader for
ChangelogStateHandleStreamImplthat iterates over its underlyingstream handlesand offsets. - StateChangelogHandleStreamHandleReader(StateChangelogHandleStreamHandleReader.StateChangeIterator) - Constructor for class org.apache.flink.runtime.state.changelog.StateChangelogHandleStreamHandleReader
- StateChangelogHandleStreamHandleReader.StateChangeIterator - Interface in org.apache.flink.runtime.state.changelog
-
Reads a stream of state changes starting from a specified offset.
- StateChangelogStorage<Handle extends ChangelogStateHandle> - Interface in org.apache.flink.runtime.state.changelog
-
A storage for changelog.
- StateChangelogStorageFactory - Interface in org.apache.flink.runtime.state.changelog
-
A factory for
StateChangelogStorage. - stateChangelogStorageForJob(JobID, Configuration, TaskManagerJobMetricGroup, LocalRecoveryConfig) - Method in class org.apache.flink.runtime.state.TaskExecutorStateChangelogStoragesManager
- StateChangelogStorageLoader - Class in org.apache.flink.runtime.state.changelog
-
A thin wrapper around
PluginManagerto loadStateChangelogStorage. - StateChangelogStorageLoader() - Constructor for class org.apache.flink.runtime.state.changelog.StateChangelogStorageLoader
- StateChangelogStorageView<Handle extends ChangelogStateHandle> - Interface in org.apache.flink.runtime.state.changelog
-
A storage view for changelog.
- StateChangelogWriter<Handle extends ChangelogStateHandle> - Interface in org.apache.flink.runtime.state.changelog
-
Allows to write data to the log.
- StateContentMetaInfo() - Constructor for class org.apache.flink.runtime.state.AbstractChannelStateHandle.StateContentMetaInfo
- StateContentMetaInfo(List<Long>, long) - Constructor for class org.apache.flink.runtime.state.AbstractChannelStateHandle.StateContentMetaInfo
- StateDescriptor<T> - Class in org.apache.flink.runtime.state.v2
-
Base class for state descriptors.
- StateDescriptor(String, TypeInformation<T>) - Constructor for class org.apache.flink.runtime.state.v2.StateDescriptor
-
Create a new
StateDescriptorwith the given stateId and the given type information. - StateDescriptor(String, TypeInformation<T>, SerializerConfig) - Constructor for class org.apache.flink.runtime.state.v2.StateDescriptor
-
Create a new
StateDescriptorwith the given stateId and the given type information. - StateDescriptor.Type - Enum in org.apache.flink.runtime.state.v2
-
An enumeration of the types of supported states.
- StateDescriptorUtils - Class in org.apache.flink.runtime.state.v2
-
Utilities for transforming
StateDescriptortoStateDescriptor. - StateEntry<K,N,S> - Interface in org.apache.flink.runtime.state
-
Interface of entries in a state backend.
- StateEntry.SimpleStateEntry<K,N,S> - Class in org.apache.flink.runtime.state
- StateExecutor - Interface in org.apache.flink.runtime.asyncprocessing
-
Executor for executing batch
StateRequests. - StateFactory<T extends org.apache.flink.runtime.scheduler.adaptive.State> - Interface in org.apache.flink.runtime.scheduler.adaptive
-
Factory for creating adaptive scheduler state instances.
- StatefulSequenceSource - Class in org.apache.flink.streaming.api.functions.source.legacy
-
Deprecated.This class is based on the
SourceFunctionAPI, which is due to be removed. Use the newSourceAPI instead. - StatefulSequenceSource(long, long) - Constructor for class org.apache.flink.streaming.api.functions.source.legacy.StatefulSequenceSource
-
Deprecated.Creates a source that emits all numbers from the given interval exactly once.
- StateFutureFactory<K> - Class in org.apache.flink.runtime.asyncprocessing
-
An internal factory for
InternalStateFuturethat build future with necessary context switch and wired with mailbox executor. - stateHandleId - Variable in class org.apache.flink.runtime.state.AbstractIncrementalStateHandle
-
Unique id for this state handle.
- StateHandleID - Class in org.apache.flink.runtime.state
-
Unique ID that allows for logical comparison between state handles.
- StateHandleID(String) - Constructor for class org.apache.flink.runtime.state.StateHandleID
- stateHandler - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- stateHandler - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- StateHandleStore<T extends Serializable,R extends ResourceVersion<R>> - Interface in org.apache.flink.runtime.persistence
-
Class which stores state via the provided
RetrievableStateStorageHelperand writes the returned state handle to distributed coordination system(e.g. - StateHandleStore.AlreadyExistException - Exception in org.apache.flink.runtime.persistence
-
The key already exists in ConfigMap or the Zookeeper node already exists.
- StateHandleStore.NotExistException - Exception in org.apache.flink.runtime.persistence
-
The key does not exist in ConfigMap or the Zookeeper node does not exists.
- StateHandleStoreUtils - Class in org.apache.flink.runtime.util
-
StateHandleStoreUtilscollects utility methods that might be usefule for anyStateHandleStoreimplementation. - StateHandleStoreUtils() - Constructor for class org.apache.flink.runtime.util.StateHandleStoreUtils
- StateInitializationContext - Interface in org.apache.flink.runtime.state
-
This interface provides a context in which operators can initialize by registering to managed state (i.e. state that is managed by state backends) or iterating over streams of state partitions written as raw state in a previous snapshot.
- StateInitializationContextImpl - Class in org.apache.flink.runtime.state
-
Default implementation of
StateInitializationContext. - StateInitializationContextImpl(Long, OperatorStateStore, KeyedStateStore, Iterable<KeyGroupStatePartitionStreamProvider>, Iterable<StatePartitionStreamProvider>) - Constructor for class org.apache.flink.runtime.state.StateInitializationContextImpl
- stateKeySelector1 - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
KeySelectorfor extracting a key from an element being processed. - stateKeySelector2 - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
KeySelectorfor extracting a key from an element being processed. - stateKeyType - Variable in class org.apache.flink.streaming.api.transformations.KeyedMultipleInputTransformation
- StateLocalitySlotAssigner - Class in org.apache.flink.runtime.scheduler.adaptive.allocator
-
A
SlotAssignerthat assigns slots based on the number of local key groups. - StateLocalitySlotAssigner() - Constructor for class org.apache.flink.runtime.scheduler.adaptive.allocator.StateLocalitySlotAssigner
- stateLocationRetriever - Variable in class org.apache.flink.runtime.scheduler.SchedulerBase
- StateLocationRetriever - Interface in org.apache.flink.runtime.scheduler
-
Component to retrieve the state location of an execution vertex.
- stateLock - Variable in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
The lock to synchronize state changes (open / close) on
- StateMap<K,N,S> - Class in org.apache.flink.runtime.state.heap
-
Base class for state maps.
- StateMap() - Constructor for class org.apache.flink.runtime.state.heap.StateMap
- StateMapSnapshot<K,N,S,T extends StateMap<K,N,S>> - Class in org.apache.flink.runtime.state.heap
-
Base class for snapshots of a
StateMap. - StateMapSnapshot(T) - Constructor for class org.apache.flink.runtime.state.heap.StateMapSnapshot
- StateMetaInfo(long[], OperatorStateHandle.Mode) - Constructor for class org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
- StateMetaInfoReader - Interface in org.apache.flink.runtime.state.metainfo
-
Functional interface to read
StateMetaInfoSnapshot. - StateMetaInfoSnapshot - Class in org.apache.flink.runtime.state.metainfo
-
Generalized snapshot for meta information about one state in a state backend (e.g.
- StateMetaInfoSnapshot(String, StateMetaInfoSnapshot.BackendStateType, Map<String, String>, Map<String, TypeSerializerSnapshot<?>>) - Constructor for class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
- StateMetaInfoSnapshot(String, StateMetaInfoSnapshot.BackendStateType, Map<String, String>, Map<String, TypeSerializerSnapshot<?>>, Map<String, TypeSerializer<?>>) - Constructor for class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
-
TODO this variant, which requires providing the serializers, TODO should actually be removed, leaving only
StateMetaInfoSnapshot(String, BackendStateType, Map, Map). - StateMetaInfoSnapshot.BackendStateType - Enum in org.apache.flink.runtime.state.metainfo
-
Enum that defines the different types of state that live in Flink backends.
- StateMetaInfoSnapshot.CommonOptionsKeys - Enum in org.apache.flink.runtime.state.metainfo
-
Predefined keys for the most common options in the meta info.
- StateMetaInfoSnapshot.CommonSerializerKeys - Enum in org.apache.flink.runtime.state.metainfo
-
Predefined keys for the most common serializer types in the meta info.
- StateMetaInfoSnapshotReadersWriters - Class in org.apache.flink.runtime.state.metainfo
-
Static factory that gives out the write and readers for different versions of
StateMetaInfoSnapshot. - StateMetaInfoWriter - Interface in org.apache.flink.runtime.state.metainfo
-
Functional interface to write
StateMetaInfoSnapshot. - StateObject - Interface in org.apache.flink.runtime.state
-
Base of all handles that represent checkpointed state in some form.
- StateObject.StateObjectLocation - Enum in org.apache.flink.runtime.state
-
Enum for state locations.
- StateObject.StateObjectSizeStatsCollector - Class in org.apache.flink.runtime.state
-
Collector for size and location stats from a state object via
StateObject.collectSizeStats(StateObjectSizeStatsCollector). - StateObjectCollection<T extends StateObject> - Class in org.apache.flink.runtime.checkpoint
-
This class represents a generic collection for
StateObjects. - StateObjectCollection() - Constructor for class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
Creates a new StateObjectCollection that is backed by an
ArrayList. - StateObjectCollection(Collection<T>) - Constructor for class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
Creates a new StateObjectCollection wraps the given collection and delegates to it.
- StatePartitionStreamProvider - Class in org.apache.flink.runtime.state
-
This class provides access to input streams that contain data of one state partition of a partitionable state.
- StatePartitionStreamProvider(InputStream) - Constructor for class org.apache.flink.runtime.state.StatePartitionStreamProvider
- StatePartitionStreamProvider(IOException) - Constructor for class org.apache.flink.runtime.state.StatePartitionStreamProvider
- StateRequest<K,N,IN,OUT> - Class in org.apache.flink.runtime.asyncprocessing
-
A request encapsulates the necessary data to perform a state request.
- StateRequest(State, StateRequestType, IN, InternalStateFuture<OUT>, RecordContext<K>) - Constructor for class org.apache.flink.runtime.asyncprocessing.StateRequest
- StateRequestBuffer<K> - Class in org.apache.flink.runtime.asyncprocessing
-
A buffer to hold state requests to execute state requests in batch, which can only be manipulated within task thread.
- StateRequestBuffer(long, long, Consumer<Long>) - Constructor for class org.apache.flink.runtime.asyncprocessing.StateRequestBuffer
- StateRequestContainer - Interface in org.apache.flink.runtime.asyncprocessing
-
A container which is used to hold
StateRequests. - stateRequestHandler - Variable in class org.apache.flink.runtime.state.v2.AbstractKeyedState
- StateRequestHandler - Interface in org.apache.flink.runtime.asyncprocessing
-
The handler which can process
StateRequest. - StateRequestType - Enum in org.apache.flink.runtime.asyncprocessing
-
The type of processing request for
Statefrom **users' perspective**. - stateSerializer - Variable in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
The serializer of the state.
- StateSerializerProvider<T> - Class in org.apache.flink.runtime.state
-
A
StateSerializerProviderwraps logic on how to obtain serializers for registered state, either with the previous schema of state in checkpoints or the current schema of state. - stateSize - Variable in class org.apache.flink.runtime.state.filemerging.SegmentFileStateHandle
-
The size of the state in the file.
- StateSizeEstimates - Class in org.apache.flink.runtime.scheduler.adaptive.allocator
-
Managed Keyed State size estimates used to make scheduling decisions.
- StateSizeEstimates() - Constructor for class org.apache.flink.runtime.scheduler.adaptive.allocator.StateSizeEstimates
- StateSizeEstimates(Map<ExecutionVertexID, Long>) - Constructor for class org.apache.flink.runtime.scheduler.adaptive.allocator.StateSizeEstimates
- stateSizeInBytes - Variable in class org.apache.flink.runtime.scheduler.adaptive.allocator.JobAllocationsInformation.VertexAllocationInformation
- stateSnapshot() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
Creates a snapshot of this
CopyOnWriteStateMap, to be written in checkpointing. - stateSnapshot() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
-
Creates a snapshot of this
CopyOnWriteStateTable, to be written in checkpointing. - stateSnapshot() - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueSnapshotRestoreWrapper
- stateSnapshot() - Method in class org.apache.flink.runtime.state.heap.StateMap
-
Creates a snapshot of this
StateMap, to be written in checkpointing. - stateSnapshot() - Method in class org.apache.flink.runtime.state.heap.StateTable
- stateSnapshot() - Method in interface org.apache.flink.runtime.state.StateSnapshotRestore
-
Returns a snapshot of the state.
- StateSnapshot - Interface in org.apache.flink.runtime.state
-
General interface for state snapshots that should be written partitioned by key-groups.
- StateSnapshot.StateKeyGroupWriter - Interface in org.apache.flink.runtime.state
-
Interface for writing a snapshot that is partitioned into key-groups.
- StateSnapshotContext - Interface in org.apache.flink.runtime.state
-
This interface provides a context in which operators that use managed (i.e. state that is managed by state backends) or raw (i.e. the operator can write it's state streams) state can perform a snapshot.
- StateSnapshotContextSynchronousImpl - Class in org.apache.flink.runtime.state
-
This class is a default implementation for StateSnapshotContext.
- StateSnapshotContextSynchronousImpl(long, long) - Constructor for class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
- StateSnapshotContextSynchronousImpl(long, long, CheckpointStreamFactory, KeyGroupRange, CloseableRegistry) - Constructor for class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
- StateSnapshotKeyGroupReader - Interface in org.apache.flink.runtime.state
-
Interface for state de-serialization into
StateTables by key-group. - StateSnapshotRestore - Interface in org.apache.flink.runtime.state
-
Interface to deal with state snapshot and restore of state.
- StateSnapshotTransformer<T> - Interface in org.apache.flink.runtime.state
-
Transformer of state values which are included or skipped in the snapshot.
- StateSnapshotTransformer.CollectionStateSnapshotTransformer<T> - Interface in org.apache.flink.runtime.state
-
Collection state specific transformer which says how to transform entries of the collection.
- StateSnapshotTransformer.CollectionStateSnapshotTransformer.TransformStrategy - Enum in org.apache.flink.runtime.state
- StateSnapshotTransformer.StateSnapshotTransformFactory<T> - Interface in org.apache.flink.runtime.state
-
This factory creates state transformers depending on the form of values to transform.
- StateSnapshotTransformers - Class in org.apache.flink.runtime.state
-
Collection of common state snapshot transformers and their factories.
- StateSnapshotTransformers() - Constructor for class org.apache.flink.runtime.state.StateSnapshotTransformers
- StateSnapshotTransformers.ListStateSnapshotTransformer<T> - Class in org.apache.flink.runtime.state
-
General implementation of list state transformer.
- StateSnapshotTransformers.ListStateSnapshotTransformFactory<T> - Class in org.apache.flink.runtime.state
- StateSnapshotTransformers.MapStateSnapshotTransformer<K,V> - Class in org.apache.flink.runtime.state
-
General implementation of map state transformer.
- StateSnapshotTransformers.MapStateSnapshotTransformFactory<K,V> - Class in org.apache.flink.runtime.state
- StateSnapshotTransformers.StateSnapshotTransformFactoryWrapAdaptor<S,T> - Class in org.apache.flink.runtime.state
- stateTable - Variable in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
Map containing the actual key/value pairs.
- StateTable<K,N,S> - Class in org.apache.flink.runtime.state.heap
-
Base class for state tables.
- StateTable(InternalKeyContext<K>, RegisteredKeyValueStateBackendMetaInfo<N, S>, TypeSerializer<K>) - Constructor for class org.apache.flink.runtime.state.heap.StateTable
- StateTableByKeyGroupReaders - Class in org.apache.flink.runtime.state.heap
-
This class provides a static factory method to create different implementations of
StateSnapshotKeyGroupReaderdepending on the provided serialization format version. - StateTableByKeyGroupReaders() - Constructor for class org.apache.flink.runtime.state.heap.StateTableByKeyGroupReaders
- StateTimeMetric - Interface in org.apache.flink.runtime.scheduler.metrics
-
Utility to define metrics that capture the time that some component spends in a state.
- StateTransformationFunction<S,T> - Interface in org.apache.flink.runtime.state
-
Interface for a binary function that is used for push-down of state transformation into state backends.
- StateTransitionManager - Interface in org.apache.flink.runtime.scheduler.adaptive
-
The
StateTransitionManagerdecides on whetherAdaptiveSchedulerstate transition should happen or not. - StateTransitionManager.Context - Interface in org.apache.flink.runtime.scheduler.adaptive
-
The interface that can be used by the
StateTransitionManagerto communicate with the underlying system. - StateTransitions - Interface in org.apache.flink.runtime.scheduler.adaptive
-
An interface covering all possible
Statetransitions. - StateTransitions.ToCancelling - Interface in org.apache.flink.runtime.scheduler.adaptive
-
Interface covering transition to the
Cancelingstate. - StateTransitions.ToCreatingExecutionGraph - Interface in org.apache.flink.runtime.scheduler.adaptive
-
Interface covering transition to the
CreatingExecutionGraphstate. - StateTransitions.ToExecuting - Interface in org.apache.flink.runtime.scheduler.adaptive
-
Interface covering transition to the
Executingstate. - StateTransitions.ToFailing - Interface in org.apache.flink.runtime.scheduler.adaptive
-
Interface covering transition to the
Failingstate. - StateTransitions.ToFinished - Interface in org.apache.flink.runtime.scheduler.adaptive
-
Interface covering transition to the
Finishedstate. - StateTransitions.ToRestarting - Interface in org.apache.flink.runtime.scheduler.adaptive
-
Interface covering transition to the
Restartingstate. - StateTransitions.ToStopWithSavepoint - Interface in org.apache.flink.runtime.scheduler.adaptive
-
Interface covering transition to the
StopWithSavepointstate. - StateTransitions.ToWaitingForResources - Interface in org.apache.flink.runtime.scheduler.adaptive
-
Interface covering transition to the
WaitingForResourcesstate. - StateUtil - Class in org.apache.flink.runtime.state
-
Helpers for
StateObjectrelated code. - StaticExternalResourceInfoProvider - Class in org.apache.flink.runtime.externalresource
-
Static implementation of
ExternalResourceInfoProviderwhich return fixed collection ofExternalResourceInfo. - StaticExternalResourceInfoProvider(Map<String, Set<? extends ExternalResourceInfo>>) - Constructor for class org.apache.flink.runtime.externalresource.StaticExternalResourceInfoProvider
- StaticFileServerHandler<T extends RestfulGateway> - Class in org.apache.flink.runtime.rest.handler.legacy.files
-
Simple file server handler that serves requests to web frontend's static files, such as HTML, CSS, or JS files.
- StaticFileServerHandler(GatewayRetriever<? extends T>, Duration, File) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
- Statistics - Interface in org.apache.flink.runtime.webmonitor.stats
-
Represents one or more statistics samples.
- statsResultByTaskGroup - Variable in class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator.PendingStatsRequest
-
Results returned by individual tasks and stored by the tasks'
ExecutionAttemptID. - StatsSummary - Class in org.apache.flink.runtime.checkpoint
-
Aggregated values of some measurement such as min/max/average state size.
- StatsSummaryDto - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Transfer object for
statistics summary. - StatsSummaryDto(long, long, long, double, double, double, double, double) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.StatsSummaryDto
- StatsSummarySnapshot - Class in org.apache.flink.runtime.checkpoint
-
Immutable snapshot of
StatsSummary. - StatsSummarySnapshot(long, long, long, long, HistogramStatistics) - Constructor for class org.apache.flink.runtime.checkpoint.StatsSummarySnapshot
- status - Variable in class org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
- StatusDurationUtils - Class in org.apache.flink.runtime.rest.messages.job
-
Utilities to calculate status duration.
- StatusDurationUtils() - Constructor for class org.apache.flink.runtime.rest.messages.job.StatusDurationUtils
- StatusHandler(GatewayRetriever<? extends T>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, AsynchronousOperationResult<V>, M>) - Constructor for class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.StatusHandler
- statusWatermarkValve - Variable in class org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput
-
Valve that controls how watermarks and watermark statuses are forwarded.
- StatusWatermarkValve - Class in org.apache.flink.streaming.runtime.watermarkstatus
-
A
StatusWatermarkValveembodies the logic of howWatermarkandWatermarkStatusare propagated to downstream outputs, given a set of one or multiple subpartitions that continuously receive them. - StatusWatermarkValve(int) - Constructor for class org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve
-
Returns a new
StatusWatermarkValve. - StatusWatermarkValve(ResultSubpartitionIndexSet[]) - Constructor for class org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve
- StatusWatermarkValve(CheckpointedInputGate) - Constructor for class org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve
- StatusWatermarkValve.SubpartitionStatus - Class in org.apache.flink.streaming.runtime.watermarkstatus
-
An
SubpartitionStatuskeeps track of a subpartition's last watermark, stream status, and whether or not the subpartition's current watermark is aligned with the overall watermark output from the valve. - stddev - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
- STDOUT - org.apache.flink.runtime.taskexecutor.FileType
-
The stdout file type for taskmanager.
- stdOutFile - Variable in class org.apache.flink.runtime.webmonitor.WebMonitorUtils.LogFileLocation
- STEPS - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
- stop() - Method in interface org.apache.flink.runtime.dispatcher.DispatcherBootstrap
-
Stops and frees any resources (e.g. threads) acquired during the execution of the bootstrap.
- stop() - Method in class org.apache.flink.runtime.dispatcher.NoOpDispatcherBootstrap
- stop() - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatManager
-
Stops the heartbeat manager.
- stop() - Method in class org.apache.flink.runtime.heartbeat.NoOpHeartbeatManager
- stop() - Method in class org.apache.flink.runtime.jobmanager.DefaultJobGraphStore
- stop() - Method in interface org.apache.flink.runtime.jobmanager.JobGraphStore
-
Stops the
JobGraphStoreservice. - stop() - Method in interface org.apache.flink.runtime.jobmanager.JobGraphStoreWatcher
-
Stop the watcher on
JobGraphStore. - stop() - Method in enum org.apache.flink.runtime.jobmanager.NoOpJobGraphStoreWatcher
- stop() - Method in class org.apache.flink.runtime.jobmanager.StandaloneJobGraphStore
- stop() - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperJobGraphStoreWatcher
- stop() - Method in class org.apache.flink.runtime.leaderretrieval.DefaultLeaderRetrievalService
- stop() - Method in interface org.apache.flink.runtime.leaderretrieval.LeaderRetrievalService
-
Stops the leader retrieval service.
- stop() - Method in class org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
- stop() - Method in class org.apache.flink.runtime.resourcemanager.DefaultJobLeaderIdService
- stop() - Method in interface org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
Stop the service.
- stop() - Method in class org.apache.flink.runtime.scheduler.slowtaskdetector.ExecutionTimeBasedSlowTaskDetector
- stop() - Method in interface org.apache.flink.runtime.scheduler.slowtaskdetector.SlowTaskDetector
-
Stop detecting slow tasks.
- stop() - Method in class org.apache.flink.runtime.security.token.DefaultDelegationTokenManager
-
Stops re-occurring token obtain task.
- stop() - Method in interface org.apache.flink.runtime.security.token.DelegationTokenManager
-
Stops re-occurring token obtain task.
- stop() - Method in class org.apache.flink.runtime.security.token.NoOpDelegationTokenManager
- stop() - Method in class org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService
- stop() - Method in interface org.apache.flink.runtime.taskexecutor.JobLeaderService
-
Stop the job leader services.
- stop() - Method in class org.apache.flink.runtime.taskexecutor.slot.DefaultTimerService
- stop() - Method in interface org.apache.flink.runtime.taskexecutor.slot.TimerService
-
Stops this timer service.
- stop() - Method in class org.apache.flink.streaming.api.operators.StreamSource
-
Deprecated.
- stop(boolean) - Method in class org.apache.flink.runtime.jobmaster.event.FileSystemJobEventStore
- stop(boolean) - Method in class org.apache.flink.runtime.jobmaster.event.JobEventManager
-
Stop the job event manager.
- stop(boolean) - Method in interface org.apache.flink.runtime.jobmaster.event.JobEventStore
-
Stop the store.
- stop(boolean) - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.BatchJobRecoveryHandler
-
Stops the job recovery handler and optionally clean up.
- stop(boolean) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DefaultBatchJobRecoveryHandler
- stop(boolean) - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DummyBatchJobRecoveryHandler
- stop(StopMode) - Method in class org.apache.flink.streaming.api.operators.SourceOperator
- STOP - org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter.TerminationMode
-
Deprecated.Please use the "stop" command instead.
- STOP_ON_FIRST_INCLUDED - org.apache.flink.runtime.state.StateSnapshotTransformer.CollectionStateSnapshotTransformer.TransformStrategy
-
Skip first null entries.
- stopApplication(ApplicationStatus, String) - Method in class org.apache.flink.runtime.entrypoint.component.DispatcherResourceManagerComponent
-
Deregister the Flink application from the resource management system by signalling the
ResourceManagerand also stop the process. - stopCheckpointScheduler() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
- stopCheckpointScheduler() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointScheduling
-
Stops the periodic scheduling if possible.
- stopCheckpointScheduler() - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- stopClusterServices(boolean) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
- StopMode - Enum in org.apache.flink.runtime.io.network.api
-
Tells if the job is stopping because of consuming all data.
- STOPPED - org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess.State
- STOPPED - org.apache.flink.runtime.io.PullingAsyncDataInput.EndOfDataStatus
- STOPPED - org.apache.flink.streaming.runtime.io.DataInputStatus
-
Indicator that the input was stopped because of stop-with-savepoint without drain.
- StoppedDispatcherLeaderProcess - Enum in org.apache.flink.runtime.dispatcher.runner
-
DispatcherLeaderProcessimplementation which is stopped. - stopPeriodicWatermarkEmits() - Method in class org.apache.flink.streaming.api.operators.source.NoOpTimestampsAndWatermarks
- stopPeriodicWatermarkEmits() - Method in class org.apache.flink.streaming.api.operators.source.ProgressiveTimestampsAndWatermarks
- stopPeriodicWatermarkEmits() - Method in interface org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks
-
Stops emitting periodic watermarks.
- stopPersisting(long) - Method in class org.apache.flink.runtime.io.network.partition.consumer.ChannelStatePersister
- stopProcess() - Method in class org.apache.flink.runtime.entrypoint.component.DispatcherResourceManagerComponent
-
Close the web monitor and cluster components.
- stopSlowTaskDetector() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DefaultSpeculativeExecutionHandler
- stopSlowTaskDetector() - Method in class org.apache.flink.runtime.scheduler.adaptivebatch.DummySpeculativeExecutionHandler
- stopSlowTaskDetector() - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.SpeculativeExecutionHandler
-
Stops the slow task detector.
- stopTrackingAndPromotePartitions(Collection<ResultPartitionID>) - Method in interface org.apache.flink.runtime.io.network.partition.JobMasterPartitionTracker
-
Promotes the given partitions, and stops the tracking of partitions that were promoted.
- stopTrackingAndPromotePartitions(Collection<ResultPartitionID>) - Method in class org.apache.flink.runtime.io.network.partition.JobMasterPartitionTrackerImpl
- stopTrackingAndReleaseAllClusterPartitions() - Method in interface org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTracker
-
Releases and stops tracking all partitions.
- stopTrackingAndReleaseAllClusterPartitions() - Method in class org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTrackerImpl
- stopTrackingAndReleaseClusterPartitions(Collection<IntermediateDataSetID>) - Method in interface org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTracker
-
Releases partitions associated with the given datasets and stops tracking of partitions that were released.
- stopTrackingAndReleaseClusterPartitions(Collection<IntermediateDataSetID>) - Method in class org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTrackerImpl
- stopTrackingAndReleaseJobPartitions(Collection<ResultPartitionID>) - Method in interface org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTracker
-
Releases the given partitions and stop the tracking of partitions that were released.
- stopTrackingAndReleaseJobPartitions(Collection<ResultPartitionID>) - Method in class org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTrackerImpl
- stopTrackingAndReleaseJobPartitionsFor(JobID) - Method in interface org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTracker
-
Releases all partitions for the given job and stop the tracking of partitions that were released.
- stopTrackingAndReleaseJobPartitionsFor(JobID) - Method in class org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTrackerImpl
- stopTrackingAndReleasePartitions(Collection<ResultPartitionID>) - Method in interface org.apache.flink.runtime.io.network.partition.JobMasterPartitionTracker
-
Releases the given partitions and stop the tracking of partitions that were released.
- stopTrackingAndReleasePartitions(Collection<ResultPartitionID>) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- stopTrackingAndReleasePartitions(Collection<ResultPartitionID>) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Notifies the
JobMasterPartitionTrackerto stop tracking the target result partitions and release the locally occupied resources onTaskExecutors if any. - stopTrackingAndReleasePartitions(Collection<ResultPartitionID>) - Method in interface org.apache.flink.runtime.shuffle.JobShuffleContext
-
Notifies the job to stop tracking and release the target result partitions, which means these partitions will be removed and will be reproduced if used afterwards.
- stopTrackingAndReleasePartitions(Collection<ResultPartitionID>) - Method in class org.apache.flink.runtime.shuffle.JobShuffleContextImpl
- stopTrackingAndReleasePartitions(Collection<ResultPartitionID>, boolean) - Method in interface org.apache.flink.runtime.io.network.partition.JobMasterPartitionTracker
-
Releases the given partitions and stop the tracking of partitions that were released.
- stopTrackingAndReleasePartitions(Collection<ResultPartitionID>, boolean) - Method in class org.apache.flink.runtime.io.network.partition.JobMasterPartitionTrackerImpl
- stopTrackingDeploymentOf(ExecutionAttemptID) - Method in class org.apache.flink.runtime.jobmaster.DefaultExecutionDeploymentTracker
- stopTrackingDeploymentOf(ExecutionAttemptID) - Method in interface org.apache.flink.runtime.jobmaster.ExecutionDeploymentTracker
-
Stops tracking the given execution.
- stopTrackingPartitions(Collection<ResultPartitionID>) - Method in class org.apache.flink.runtime.io.network.partition.AbstractPartitionTracker
- stopTrackingPartitions(Collection<ResultPartitionID>) - Method in interface org.apache.flink.runtime.io.network.partition.PartitionTracker
-
Stops the tracking of the given partitions.
- stopTrackingPartitions(K) - Method in class org.apache.flink.runtime.taskexecutor.partition.PartitionTable
-
Stops the tracking of all partition for the given key.
- stopTrackingPartitions(K, Collection<ResultPartitionID>) - Method in class org.apache.flink.runtime.taskexecutor.partition.PartitionTable
-
Stops the tracking of the given set of partitions for the given key.
- stopTrackingPartitionsFor(K) - Method in class org.apache.flink.runtime.io.network.partition.AbstractPartitionTracker
- stopTrackingPartitionsFor(K) - Method in interface org.apache.flink.runtime.io.network.partition.PartitionTracker
-
Stops the tracking of all partitions for the given key.
- stopWithDetachedSavepoint(JobID, String, boolean, SavepointFormatType) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- stopWithSavepoint(boolean, String, SavepointFormatType) - Method in class org.apache.flink.runtime.minicluster.MiniClusterJobClient
- stopWithSavepoint(String, boolean, SavepointFormatType) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- stopWithSavepoint(String, boolean, SavepointFormatType) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- stopWithSavepoint(String, boolean, SavepointFormatType) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
- stopWithSavepoint(String, SavepointFormatType, boolean, Duration) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- stopWithSavepoint(String, SavepointFormatType, boolean, Duration) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Stops the job with a savepoint.
- stopWithSavepoint(CompletableFuture<CompletedCheckpoint>, CompletableFuture<Collection<ExecutionState>>, ComponentMainThreadExecutor) - Method in class org.apache.flink.runtime.scheduler.stopwithsavepoint.StopWithSavepointTerminationManager
-
Enforces the correct completion order of the passed
CompletableFutureinstances in accordance to the contract ofStopWithSavepointTerminationHandler. - stopWithSavepoint(JobID, String, boolean, SavepointFormatType) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- stopWithSavepoint(AsynchronousJobOperationKey, String, SavepointFormatType, TriggerSavepointMode, Duration) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- stopWithSavepoint(AsynchronousJobOperationKey, String, SavepointFormatType, TriggerSavepointMode, Duration) - Method in class org.apache.flink.runtime.dispatcher.DispatcherCachedOperationsHandler
- stopWithSavepoint(AsynchronousJobOperationKey, String, SavepointFormatType, TriggerSavepointMode, Duration) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Stops the job with a savepoint, returning a future that completes when the operation is started.
- stopWithSavepointAndGetLocation(JobID, String, SavepointFormatType, TriggerSavepointMode, Duration) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- stopWithSavepointAndGetLocation(JobID, String, SavepointFormatType, TriggerSavepointMode, Duration) - Method in interface org.apache.flink.runtime.dispatcher.DispatcherGateway
-
Stops the job with a savepoint, returning a future that completes with the savepoint location when the savepoint is completed.
- StopWithSavepointHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.StopWithSavepointHandler
- StopWithSavepointRequestBody - Class in org.apache.flink.runtime.rest.messages.job.savepoints.stop
-
RequestBodyfor stopping a job with a savepoint. - StopWithSavepointRequestBody(String, Boolean, SavepointFormatType, TriggerId) - Constructor for class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointRequestBody
- StopWithSavepointStoppingException - Exception in org.apache.flink.runtime.scheduler.stopwithsavepoint
-
Exception thrown when a savepoint has been created successfully when stopping with savepoint, but the job has not finished.
- StopWithSavepointStoppingException(String, JobID) - Constructor for exception org.apache.flink.runtime.scheduler.stopwithsavepoint.StopWithSavepointStoppingException
- StopWithSavepointStoppingException(String, JobID, Throwable) - Constructor for exception org.apache.flink.runtime.scheduler.stopwithsavepoint.StopWithSavepointStoppingException
- StopWithSavepointTerminationHandler - Interface in org.apache.flink.runtime.scheduler.stopwithsavepoint
-
StopWithSavepointTerminationHandlerhandles the steps necessary for the stop-with-savepoint operation to finish. - StopWithSavepointTerminationHandlerImpl - Class in org.apache.flink.runtime.scheduler.stopwithsavepoint
-
StopWithSavepointTerminationHandlerImplimplementsStopWithSavepointTerminationHandler. - StopWithSavepointTerminationHandlerImpl(JobID, S, Logger) - Constructor for class org.apache.flink.runtime.scheduler.stopwithsavepoint.StopWithSavepointTerminationHandlerImpl
- StopWithSavepointTerminationManager - Class in org.apache.flink.runtime.scheduler.stopwithsavepoint
-
StopWithSavepointTerminationManagerfulfills the contract given byStopWithSavepointTerminationHandlerto run the stop-with-savepoint steps in a specific order. - StopWithSavepointTerminationManager(StopWithSavepointTerminationHandler) - Constructor for class org.apache.flink.runtime.scheduler.stopwithsavepoint.StopWithSavepointTerminationManager
- StopWithSavepointTriggerHeaders - Class in org.apache.flink.runtime.rest.messages.job.savepoints.stop
-
These headers define the protocol for triggering a "stop" action.
- stopWorkerIfSupported(WorkerType) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
Stops the given worker if supported.
- STORAGE_PATH - Static variable in class org.apache.flink.runtime.highavailability.JobResultStoreOptions
- storageDir - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
-
Root directory for local file storage.
- store(T) - Method in class org.apache.flink.runtime.persistence.filesystem.FileSystemStateStorageHelper
- store(T) - Method in interface org.apache.flink.runtime.persistence.RetrievableStateStorageHelper
-
Stores the given state and returns a state handle to it.
- storeCheckpointMetadata(CheckpointMetadata, DataOutputStream) - Static method in class org.apache.flink.runtime.checkpoint.Checkpoints
- storeCheckpointMetadata(CheckpointMetadata, DataOutputStream, MetadataSerializer) - Static method in class org.apache.flink.runtime.checkpoint.Checkpoints
- storeCheckpointMetadata(CheckpointMetadata, OutputStream) - Static method in class org.apache.flink.runtime.checkpoint.Checkpoints
- storedTaskStateByCheckpointID - Variable in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
Maps checkpoint ids to local TaskStateSnapshots.
- storeLocalState(long, TaskStateSnapshot) - Method in class org.apache.flink.runtime.state.ChangelogTaskLocalStateStore
- storeLocalState(long, TaskStateSnapshot) - Method in class org.apache.flink.runtime.state.NoOpTaskLocalStateStoreImpl
- storeLocalState(long, TaskStateSnapshot) - Method in interface org.apache.flink.runtime.state.TaskLocalStateStore
-
Stores the local state for the given checkpoint id.
- storeLocalState(long, TaskStateSnapshot) - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
- storesLocalResourcesOn() - Method in class org.apache.flink.runtime.shuffle.NettyShuffleDescriptor
- storesLocalResourcesOn() - Method in interface org.apache.flink.runtime.shuffle.ShuffleDescriptor
-
Returns the location of the producing task executor if the partition occupies local resources there.
- storesLocalResourcesOn() - Method in class org.apache.flink.runtime.shuffle.UnknownShuffleDescriptor
- stream() - Method in class org.apache.flink.runtime.io.network.partition.PrioritizedDeque
- StreamCompressionDecorator - Class in org.apache.flink.runtime.state
-
Implementations of this interface decorate streams with a compression scheme.
- StreamCompressionDecorator() - Constructor for class org.apache.flink.runtime.state.StreamCompressionDecorator
- StreamConfig - Class in org.apache.flink.streaming.api.graph
-
Internal configuration for a
StreamOperator. - StreamConfig(Configuration) - Constructor for class org.apache.flink.streaming.api.graph.StreamConfig
- StreamConfig.InputConfig - Interface in org.apache.flink.streaming.api.graph
-
Interface representing chained inputs.
- StreamConfig.InputRequirement - Enum in org.apache.flink.streaming.api.graph
-
Requirements of the different inputs of an operator.
- StreamConfig.NetworkInputConfig - Class in org.apache.flink.streaming.api.graph
-
A representation of a Network
StreamConfig.InputConfig. - StreamConfig.SourceInputConfig - Class in org.apache.flink.streaming.api.graph
-
A serialized representation of an input.
- StreamEdge - Class in org.apache.flink.streaming.api.graph
-
An edge in the streaming topology.
- StreamEdge(StreamNode, StreamNode, int, long, StreamPartitioner<?>, OutputTag, StreamExchangeMode, int, IntermediateDataSetID) - Constructor for class org.apache.flink.streaming.api.graph.StreamEdge
- StreamEdge(StreamNode, StreamNode, int, StreamPartitioner<?>, OutputTag) - Constructor for class org.apache.flink.streaming.api.graph.StreamEdge
- StreamEdge(StreamNode, StreamNode, int, StreamPartitioner<?>, OutputTag, StreamExchangeMode, int, IntermediateDataSetID) - Constructor for class org.apache.flink.streaming.api.graph.StreamEdge
- StreamElement - Class in org.apache.flink.streaming.runtime.streamrecord
-
An element in a data stream.
- StreamElement() - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamElement
- StreamElementSerializer<T> - Class in org.apache.flink.streaming.runtime.streamrecord
- StreamElementSerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
- StreamElementSerializer.StreamElementSerializerSnapshot<T> - Class in org.apache.flink.streaming.runtime.streamrecord
-
Configuration snapshot specific to the
StreamElementSerializer. - StreamElementSerializerSnapshot() - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerSnapshot
- StreamExchangeMode - Enum in org.apache.flink.streaming.api.transformations
-
The data exchange mode between operators during
StreamGraphgeneration. - StreamExecutionEnvironment - Class in org.apache.flink.streaming.api.environment
-
The StreamExecutionEnvironment is the context in which a streaming program is executed.
- StreamExecutionEnvironment() - Constructor for class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
- StreamExecutionEnvironment(Configuration) - Constructor for class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new
StreamExecutionEnvironmentthat will use the givenConfigurationto configure thePipelineExecutor. - StreamExecutionEnvironment(Configuration, ClassLoader) - Constructor for class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new
StreamExecutionEnvironmentthat will use the givenConfigurationto configure thePipelineExecutor. - StreamExecutionEnvironment(PipelineExecutorServiceLoader, Configuration, ClassLoader) - Constructor for class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Creates a new
StreamExecutionEnvironmentthat will use the givenConfigurationto configure thePipelineExecutor. - StreamExecutionEnvironmentFactory - Interface in org.apache.flink.streaming.api.environment
-
Factory class for stream execution environments.
- StreamFilter<IN> - Class in org.apache.flink.streaming.api.operators
-
A
StreamOperatorfor executingFilterFunctions. - StreamFilter(FilterFunction<IN>) - Constructor for class org.apache.flink.streaming.api.operators.StreamFilter
- StreamFlatMap<IN,OUT> - Class in org.apache.flink.streaming.api.operators
-
A
StreamOperatorfor executingFlatMapFunctions. - StreamFlatMap(FlatMapFunction<IN, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.StreamFlatMap
- StreamGraph - Class in org.apache.flink.streaming.api.graph
-
Class representing the streaming topology.
- StreamGraph(Configuration, ExecutionConfig, CheckpointConfig, SavepointRestoreSettings) - Constructor for class org.apache.flink.streaming.api.graph.StreamGraph
- StreamGraphGenerator - Class in org.apache.flink.streaming.api.graph
-
A generator that generates a
StreamGraphfrom a graph ofTransformations. - StreamGraphGenerator(List<Transformation<?>>, ExecutionConfig, CheckpointConfig) - Constructor for class org.apache.flink.streaming.api.graph.StreamGraphGenerator
- StreamGraphGenerator(List<Transformation<?>>, ExecutionConfig, CheckpointConfig, Configuration) - Constructor for class org.apache.flink.streaming.api.graph.StreamGraphGenerator
- StreamGraphHasher - Interface in org.apache.flink.streaming.api.graph
-
Interface for different implementations of generating hashes over a stream graph.
- StreamGraphHasherV2 - Class in org.apache.flink.streaming.api.graph
-
StreamGraphHasher from Flink 1.2.
- StreamGraphHasherV2() - Constructor for class org.apache.flink.streaming.api.graph.StreamGraphHasherV2
- StreamGraphUserHashHasher - Class in org.apache.flink.streaming.api.graph
-
StreamGraphHasher that works with user provided hashes.
- StreamGraphUserHashHasher() - Constructor for class org.apache.flink.streaming.api.graph.StreamGraphUserHashHasher
- StreamGraphUtils - Class in org.apache.flink.streaming.util.graph
-
Utility class that contains helper methods to generating
StreamGraph. - StreamGraphUtils() - Constructor for class org.apache.flink.streaming.util.graph.StreamGraphUtils
- StreamGroupedReduceOperator<IN> - Class in org.apache.flink.streaming.api.operators
- StreamGroupedReduceOperator(ReduceFunction<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.streaming.api.operators.StreamGroupedReduceOperator
- STREAMING - org.apache.flink.runtime.jobgraph.JobType
-
Streaming jobs are infinite jobs, consisting of one large pipelined region, not separated by any blocking data exchanges.
- StreamingFunctionUtils - Class in org.apache.flink.streaming.util.functions
-
Utility class that contains helper methods to work with Flink Streaming
Functions. - StreamingJobGraphGenerator - Class in org.apache.flink.streaming.api.graph
-
The StreamingJobGraphGenerator converts a
StreamGraphinto aJobGraph. - StreamingRuntimeContext - Class in org.apache.flink.streaming.api.operators
-
Implementation of the
RuntimeContext, for streaming operators. - StreamingRuntimeContext(Environment, Map<String, Accumulator<?, ?>>, OperatorMetricGroup, OperatorID, ProcessingTimeService, KeyedStateStore, ExternalResourceInfoProvider) - Constructor for class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
- StreamingRuntimeContext(AbstractStreamOperator<?>, Environment, Map<String, Accumulator<?, ?>>) - Constructor for class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
- StreamInputProcessor - Interface in org.apache.flink.streaming.runtime.io
-
Interface for processing records by
StreamTask. - StreamIterationHead<OUT> - Class in org.apache.flink.streaming.runtime.tasks
-
A special
StreamTaskthat is used for executing feedback edges. - StreamIterationHead(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
- StreamIterationTail<IN> - Class in org.apache.flink.streaming.runtime.tasks
-
A special
StreamTaskthat is used for executing feedback edges. - StreamIterationTail(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamIterationTail
- StreamMap<IN,OUT> - Class in org.apache.flink.streaming.api.operators
-
A
StreamOperatorfor executingMapFunctions. - StreamMap(MapFunction<IN, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.StreamMap
- StreamMultipleInputProcessor - Class in org.apache.flink.streaming.runtime.io
-
Input processor for
MultipleInputStreamOperator. - StreamMultipleInputProcessor(MultipleInputSelectionHandler, StreamOneInputProcessor<?>[]) - Constructor for class org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessor
- StreamMultipleInputProcessorFactory - Class in org.apache.flink.streaming.runtime.io
-
A factory for
StreamMultipleInputProcessor. - StreamMultipleInputProcessorFactory() - Constructor for class org.apache.flink.streaming.runtime.io.StreamMultipleInputProcessorFactory
- StreamNode - Class in org.apache.flink.streaming.api.graph
-
Class representing the operators in the streaming programs, with all their properties.
- StreamNode(Integer, String, String, StreamOperator<?>, String, Class<? extends TaskInvokable>) - Constructor for class org.apache.flink.streaming.api.graph.StreamNode
- StreamNode(Integer, String, String, StreamOperatorFactory<?>, String, Class<? extends TaskInvokable>) - Constructor for class org.apache.flink.streaming.api.graph.StreamNode
- StreamOneInputProcessor<IN> - Class in org.apache.flink.streaming.runtime.io
-
Input reader for
OneInputStreamTask. - StreamOneInputProcessor(StreamTaskInput<IN>, PushingAsyncDataInput.DataOutput<IN>, BoundedMultiInput) - Constructor for class org.apache.flink.streaming.runtime.io.StreamOneInputProcessor
- StreamOperator<OUT> - Interface in org.apache.flink.streaming.api.operators
-
Basic interface for stream operators.
- StreamOperatorFactory<OUT> - Interface in org.apache.flink.streaming.api.operators
-
A factory to create
StreamOperator. - StreamOperatorFactoryUtil - Class in org.apache.flink.streaming.api.operators
-
A utility to instantiate new operators with a given factory.
- StreamOperatorFactoryUtil() - Constructor for class org.apache.flink.streaming.api.operators.StreamOperatorFactoryUtil
- StreamOperatorParameters<OUT> - Class in org.apache.flink.streaming.api.operators
-
Helper class to construct
AbstractStreamOperatorV2. - StreamOperatorParameters(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>, Supplier<ProcessingTimeService>, OperatorEventDispatcher, MailboxExecutor) - Constructor for class org.apache.flink.streaming.api.operators.StreamOperatorParameters
- streamOperatorStateContext(OperatorID, String, ProcessingTimeService, KeyContext, TypeSerializer<?>, CloseableRegistry, MetricGroup, double, boolean) - Method in interface org.apache.flink.streaming.api.operators.StreamTaskStateInitializer
-
Returns the
StreamOperatorStateContextfor anAbstractStreamOperatorthat runs in the stream task that owns this manager. - streamOperatorStateContext(OperatorID, String, ProcessingTimeService, KeyContext, TypeSerializer<?>, CloseableRegistry, MetricGroup, double, boolean) - Method in class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
- StreamOperatorStateContext - Interface in org.apache.flink.streaming.api.operators
-
This interface represents a context from which a stream operator can initialize everything connected to state such as e.g. backends, raw state, and timer service manager.
- StreamOperatorStateHandler - Class in org.apache.flink.streaming.api.operators
-
Class encapsulating various state backend handling logic for
StreamOperatorimplementations. - StreamOperatorStateHandler(StreamOperatorStateContext, ExecutionConfig, CloseableRegistry) - Constructor for class org.apache.flink.streaming.api.operators.StreamOperatorStateHandler
- StreamOperatorStateHandler.CheckpointedStreamOperator - Interface in org.apache.flink.streaming.api.operators
-
Custom state handling hooks to be invoked by
StreamOperatorStateHandler. - StreamOperatorUtils - Class in org.apache.flink.streaming.api.operators
- StreamOperatorUtils() - Constructor for class org.apache.flink.streaming.api.operators.StreamOperatorUtils
- StreamOperatorWrapper<OUT,OP extends StreamOperator<OUT>> - Class in org.apache.flink.streaming.runtime.tasks
-
This class handles the finish, endInput and other related logic of a
StreamOperator. - streamOutputs - Variable in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- StreamPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
-
A special
ChannelSelectorfor use in streaming programs. - StreamPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
- StreamProject<IN,OUT extends org.apache.flink.api.java.tuple.Tuple> - Class in org.apache.flink.streaming.api.operators
-
A
StreamOperatorfor executing projections on streams. - StreamProject(int[], TypeSerializer<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.StreamProject
- StreamProjection<IN> - Class in org.apache.flink.streaming.api.datastream
-
The result of
DataStream.project(int...). - StreamProjection(DataStream<IN>, int[]) - Constructor for class org.apache.flink.streaming.api.datastream.StreamProjection
- StreamRecord<T> - Class in org.apache.flink.streaming.runtime.streamrecord
-
One value in a data stream.
- StreamRecord(T) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Creates a new StreamRecord.
- StreamRecord(T, long) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
-
Creates a new StreamRecord wrapping the given value.
- StreamSink<IN> - Class in org.apache.flink.streaming.api.operators
-
A
StreamOperatorfor executingSinkFunctions. - StreamSink(SinkFunction<IN>) - Constructor for class org.apache.flink.streaming.api.operators.StreamSink
- StreamSource<OUT,SRC extends SourceFunction<OUT>> - Class in org.apache.flink.streaming.api.operators
-
Deprecated.This class is based on the
SourceFunctionAPI, which is due to be removed. Use the newSourceAPI instead. - StreamSource(SRC) - Constructor for class org.apache.flink.streaming.api.operators.StreamSource
-
Deprecated.
- StreamSource(SRC, boolean) - Constructor for class org.apache.flink.streaming.api.operators.StreamSource
-
Deprecated.
- StreamSourceContexts - Class in org.apache.flink.streaming.api.operators
-
Deprecated.This class is based on the
SourceFunctionAPI, which is due to be removed. Use the newSourceAPI instead. - StreamSourceContexts() - Constructor for class org.apache.flink.streaming.api.operators.StreamSourceContexts
-
Deprecated.
- StreamStateHandle - Interface in org.apache.flink.runtime.state
-
A
StateObjectthat represents state that was written to a stream. - streamSubHandles() - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
- StreamTask<OUT,OP extends StreamOperator<OUT>> - Class in org.apache.flink.streaming.runtime.tasks
-
Base class for all streaming tasks.
- StreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
- StreamTask(Environment, TimerService) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
- StreamTask(Environment, TimerService, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTask
- StreamTask(Environment, TimerService, Thread.UncaughtExceptionHandler, StreamTaskActionExecutor) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTask
-
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
- StreamTask(Environment, TimerService, Thread.UncaughtExceptionHandler, StreamTaskActionExecutor, TaskMailbox) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTask
- StreamTask.CanEmitBatchOfRecordsChecker - Interface in org.apache.flink.streaming.runtime.tasks
-
Check whether records can be emitted in batch.
- StreamTaskActionExecutor - Interface in org.apache.flink.streaming.runtime.tasks
- StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor - Class in org.apache.flink.streaming.runtime.tasks
-
Deprecated.this class should only be used in
SourceStreamTaskwhich exposes the checkpoint lock as part of Public API. - StreamTaskCancellationContext - Interface in org.apache.flink.streaming.runtime.tasks
-
Context on the
StreamTaskfor figuring out whether it has been cancelled. - StreamTaskException - Exception in org.apache.flink.streaming.runtime.tasks
-
An exception that is thrown by the stream vertices when encountering an illegal condition.
- StreamTaskException() - Constructor for exception org.apache.flink.streaming.runtime.tasks.StreamTaskException
-
Creates a compiler exception with no message and no cause.
- StreamTaskException(String) - Constructor for exception org.apache.flink.streaming.runtime.tasks.StreamTaskException
-
Creates a compiler exception with the given message and no cause.
- StreamTaskException(String, Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.StreamTaskException
-
Creates a compiler exception with the given message and cause.
- StreamTaskException(Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.StreamTaskException
-
Creates a compiler exception with the given cause and no message.
- StreamTaskExternallyInducedSourceInput<T> - Class in org.apache.flink.streaming.runtime.io
-
A subclass of
StreamTaskSourceInputforExternallyInducedSourceReader. - StreamTaskExternallyInducedSourceInput(SourceOperator<T, ?>, Consumer<Long>, int, int) - Constructor for class org.apache.flink.streaming.runtime.io.StreamTaskExternallyInducedSourceInput
- StreamTaskFinishedOnRestoreSourceInput<T> - Class in org.apache.flink.streaming.runtime.tasks
-
A special source input implementation that immediately emit END_OF_INPUT.
- StreamTaskFinishedOnRestoreSourceInput(SourceOperator<T, ?>, int, int) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTaskFinishedOnRestoreSourceInput
- StreamTaskInput<T> - Interface in org.apache.flink.streaming.runtime.io
-
Basic interface for inputs of stream operators.
- StreamTaskNetworkInput<T> - Class in org.apache.flink.streaming.runtime.io
-
Implementation of
StreamTaskInputthat wraps an input from network taken fromCheckpointedInputGate. - StreamTaskNetworkInput(CheckpointedInputGate, TypeSerializer<T>, IOManager, StatusWatermarkValve, int, StreamTask.CanEmitBatchOfRecordsChecker) - Constructor for class org.apache.flink.streaming.runtime.io.StreamTaskNetworkInput
- StreamTaskNetworkInputFactory - Class in org.apache.flink.streaming.runtime.io
-
Factory for
StreamTaskNetworkInputandRescalingStreamTaskNetworkInput. - StreamTaskNetworkInputFactory() - Constructor for class org.apache.flink.streaming.runtime.io.StreamTaskNetworkInputFactory
- StreamTaskSourceInput<T> - Class in org.apache.flink.streaming.runtime.io
-
Implementation of
StreamTaskInputthat reads data from theSourceOperatorand returns theDataInputStatusto indicate whether the source state is available, unavailable or finished. - StreamTaskSourceInput(SourceOperator<T, ?>, int, int) - Constructor for class org.apache.flink.streaming.runtime.io.StreamTaskSourceInput
- StreamTaskStateInitializer - Interface in org.apache.flink.streaming.api.operators
-
This is the interface through which stream task expose a
StreamOperatorStateContextto their operators. - StreamTaskStateInitializerImpl - Class in org.apache.flink.streaming.api.operators
-
This class is the main implementation of a
StreamTaskStateInitializer. - StreamTaskStateInitializerImpl(Environment, StateBackend) - Constructor for class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
- StreamTaskStateInitializerImpl(Environment, StateBackend, SubTaskInitializationMetricsBuilder, TtlTimeProvider, InternalTimeServiceManager.Provider, StreamTaskCancellationContext) - Constructor for class org.apache.flink.streaming.api.operators.StreamTaskStateInitializerImpl
- StreamTaskStateInitializerImpl.KeyedStateBackendCreator<K,R extends org.apache.flink.util.Disposable & Closeable> - Interface in org.apache.flink.streaming.api.operators
-
Functional interface to create the keyed state backend.
- StreamTwoInputProcessorFactory - Class in org.apache.flink.streaming.runtime.io
-
A factory to create
StreamMultipleInputProcessorfor two input case. - StreamTwoInputProcessorFactory() - Constructor for class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessorFactory
- StringifiedAccumulatorResult - Class in org.apache.flink.runtime.accumulators
-
Container class that transports the result of an accumulator as set of strings.
- StringifiedAccumulatorResult(String, String, String) - Constructor for class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
- stringifyAccumulatorResults(Map<String, OptionalFailure<Accumulator<?, ?>>>) - Static method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
-
Flatten a map of accumulator names to Accumulator instances into an array of StringifiedAccumulatorResult values.
- stringifyThreadInfo(ThreadInfo, int) - Static method in class org.apache.flink.runtime.rest.messages.ThreadDumpInfo
-
Custom stringify format of JVM thread info to bypass the MAX_FRAMES = 8 limitation.
- StringResourceVersion - Class in org.apache.flink.runtime.persistence
-
ResourceVersionimplementation withStringvalue. - StronglyConnectedComponentsComputeUtils - Class in org.apache.flink.runtime.executiongraph.failover
-
Utility for computing strongly connected components.
- stub - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The instantiated user code of this task's main operator (driver).
- subComponents() - Method in class org.apache.flink.runtime.metrics.groups.ComponentMetricGroup
-
Gets all component metric groups that are contained in this component metric group.
- subComponents() - Method in class org.apache.flink.runtime.metrics.groups.InternalOperatorMetricGroup
- subComponents() - Method in class org.apache.flink.runtime.metrics.groups.JobManagerJobMetricGroup
- subComponents() - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
- subComponents() - Method in class org.apache.flink.runtime.metrics.groups.JobManagerOperatorMetricGroup
- subComponents() - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
- subComponents() - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
- subComponents() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
- SUBMISSION - org.apache.flink.runtime.dispatcher.Dispatcher.ExecutionType
- submit(ThrowingRunnable<? extends Exception>) - Method in class org.apache.flink.runtime.asyncprocessing.BatchCallbackRunner
-
Submit a callback to run.
- submitFailedJob(JobID, String, Throwable) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- submitFailedJob(JobID, String, Throwable) - Method in interface org.apache.flink.runtime.dispatcher.DispatcherGateway
- submitJob(JobGraph) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- submitJob(JobGraph, Duration) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- submitJob(JobGraph, Duration) - Method in interface org.apache.flink.runtime.dispatcher.DispatcherGateway
-
Submit a job to the dispatcher.
- submitJob(JobGraph, Duration) - Method in class org.apache.flink.runtime.dispatcher.MiniDispatcher
- submitTask(TaskDeploymentDescriptor, Duration) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Submit a task to the task manager.
- submitTask(TaskDeploymentDescriptor, Duration) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
- submitTask(TaskDeploymentDescriptor, JobMasterId, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- submitTask(TaskDeploymentDescriptor, JobMasterId, Duration) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Submit a
Taskto theTaskExecutor. - submitTask(TaskDeploymentDescriptor, JobMasterId, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- SubpartitionBufferContext(int, List<PartitionFileWriter.SegmentBufferContext>) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.PartitionFileWriter.SubpartitionBufferContext
- subpartitionInfo - Variable in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
The info of the subpartition to identify it globally within a task.
- subpartitionReadOrder - Variable in class org.apache.flink.runtime.io.network.partition.SortBuffer
-
Data of different subpartitions in this sort buffer will be read in this order.
- subpartitions - Variable in class org.apache.flink.runtime.io.network.partition.BufferWritingResultPartition
-
The subpartitions of this partition.
- SubpartitionSelector<T> - Interface in org.apache.flink.runtime.io.network.partition
-
SubpartitionSelectorhelps to choose from multiple available subpartitions when their output buffers should union into one stream. - SubpartitionStatus() - Constructor for class org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve.SubpartitionStatus
- subscribe(EventListener<TaskEvent>, Class<? extends TaskEvent>) - Method in class org.apache.flink.runtime.io.network.api.TaskEventHandler
- subscribeToEvent(ResultPartitionID, EventListener<TaskEvent>, Class<? extends TaskEvent>) - Method in class org.apache.flink.runtime.io.network.TaskEventDispatcher
-
Subscribes a listener to this dispatcher for events on a partition.
- substituteDeprecatedConfigKey(Configuration, String, String) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Sets the value of a new config key to the value of a deprecated config key.
- substituteDeprecatedConfigPrefix(Configuration, String, String) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Sets the value of a new config key to the value of a deprecated config key.
- SUBSUME - org.apache.flink.runtime.taskmanager.Task.NotifyCheckpointOperation
- SUBTASK - org.apache.flink.streaming.util.LatencyStats.Granularity
- SubtaskAccumulatorsInfo(int, int, String, Collection<UserAccumulator>) - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo
- SubtaskAttemptMessageParameters - Class in org.apache.flink.runtime.rest.messages.job
-
The type Subtask attempt message parameters.
- SubtaskAttemptMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskAttemptMessageParameters
- SubtaskAttemptNumberStore - Interface in org.apache.flink.runtime.executiongraph
-
Contains the attempt number per subtask.
- subtaskAttemptPathParameter - Variable in class org.apache.flink.runtime.rest.messages.job.SubtaskAttemptMessageParameters
- SubtaskAttemptPathParameter - Class in org.apache.flink.runtime.rest.messages.job
-
Path parameter identifying subtask attempt.
- SubtaskAttemptPathParameter() - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskAttemptPathParameter
-
Instantiates a new Subtask attempt path parameter.
- SubtaskBackPressureInfo(int, Integer, JobVertexBackPressureInfo.VertexBackPressureLevel, double, double, double, List<JobVertexBackPressureInfo.SubtaskBackPressureInfo>) - Constructor for class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
- subtaskBaseDirectory(long) - Method in interface org.apache.flink.runtime.state.LocalSnapshotDirectoryProvider
-
Returns the local state directory for the owning subtask the given checkpoint id w.r.t. our rotation over all available available allocation base directories.
- subtaskBaseDirectory(long) - Method in class org.apache.flink.runtime.state.LocalSnapshotDirectoryProviderImpl
- SubtaskCheckpointCoordinator - Interface in org.apache.flink.streaming.runtime.tasks
-
Coordinates checkpointing-related work for a subtask (i.e.
- SubtaskCheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Checkpoint statistics for a subtask.
- SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Checkpoint statistics for a completed subtask checkpoint.
- SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Alignment statistics of the checkpoint.
- SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Duration of the checkpoint.
- SubtaskCheckpointStatistics.PendingSubtaskCheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Checkpoint statistics for a pending subtask checkpoint.
- SubtaskConnectionDescriptor - Class in org.apache.flink.runtime.io.network.api
-
An event that is used to (de)multiplex old channels over the same new channel.
- SubtaskConnectionDescriptor(int, int) - Constructor for class org.apache.flink.runtime.io.network.api.SubtaskConnectionDescriptor
- SubtaskCurrentAttemptDetailsHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Request handler providing details about a single task execution attempt.
- SubtaskCurrentAttemptDetailsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, SubtaskExecutionAttemptDetailsInfo, SubtaskMessageParameters>, ExecutionGraphCache, Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.SubtaskCurrentAttemptDetailsHandler
- SubtaskCurrentAttemptDetailsHeaders - Class in org.apache.flink.runtime.rest.messages.job
-
Message headers for the
SubtaskCurrentAttemptDetailsHandler. - SubtaskCurrentAttemptDetailsHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
- SubtaskExecutionAttemptAccumulatorsHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Request handler for the subtask execution attempt accumulators.
- SubtaskExecutionAttemptAccumulatorsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, SubtaskExecutionAttemptAccumulatorsInfo, SubtaskAttemptMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.SubtaskExecutionAttemptAccumulatorsHandler
-
Instantiates a new Abstract job vertex handler.
- SubtaskExecutionAttemptAccumulatorsHeaders - Class in org.apache.flink.runtime.rest.messages.job
-
Message headers for the
SubtaskExecutionAttemptAccumulatorsHandler. - SubtaskExecutionAttemptAccumulatorsHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
- SubtaskExecutionAttemptAccumulatorsInfo - Class in org.apache.flink.runtime.rest.messages.job
-
Response type of the
SubtaskExecutionAttemptAccumulatorsHandler. - SubtaskExecutionAttemptAccumulatorsInfo(int, int, String, Collection<UserAccumulator>) - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsInfo
- SubtaskExecutionAttemptDetailsHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Handler of specific sub task execution attempt.
- SubtaskExecutionAttemptDetailsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, SubtaskExecutionAttemptDetailsInfo, SubtaskAttemptMessageParameters>, ExecutionGraphCache, Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.SubtaskExecutionAttemptDetailsHandler
-
Instantiates a new subtask execution attempt details handler.
- SubtaskExecutionAttemptDetailsHeaders - Class in org.apache.flink.runtime.rest.messages.job
-
Message headers for the
SubtaskExecutionAttemptDetailsHandler. - SubtaskExecutionAttemptDetailsHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
- SubtaskExecutionAttemptDetailsInfo - Class in org.apache.flink.runtime.rest.messages.job
-
The sub task execution attempt response.
- SubtaskExecutionAttemptDetailsInfo(int, ExecutionState, int, String, long, long, long, IOMetricsInfo, String, Map<ExecutionState, Long>, List<SubtaskExecutionAttemptDetailsInfo>) - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
- SubtaskFileMergingManagerRestoreOperation - Class in org.apache.flink.runtime.checkpoint.filemerging
-
Restore operation that restores file-merging information belonging to one subtask for
FileMergingSnapshotManager. - SubtaskFileMergingManagerRestoreOperation(long, FileMergingSnapshotManager, JobID, TaskInfo, OperatorID, OperatorSubtaskState) - Constructor for class org.apache.flink.runtime.checkpoint.filemerging.SubtaskFileMergingManagerRestoreOperation
- subtaskId() - Method in class org.apache.flink.runtime.source.event.ReaderRegistrationEvent
- subtaskIndex - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
- subtaskIndex - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
- subtaskIndex - Variable in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
- subtaskIndex - Variable in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
Subtask index of the owning subtask.
- subtaskIndex() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
- subtaskIndexPathParameter - Variable in class org.apache.flink.runtime.rest.messages.job.SubtaskMessageParameters
- SubtaskIndexPathParameter - Class in org.apache.flink.runtime.rest.messages
-
Path parameter specifying the index of a subtask.
- SubtaskIndexPathParameter() - Constructor for class org.apache.flink.runtime.rest.messages.SubtaskIndexPathParameter
- subtaskIndexQueryParameter - Variable in class org.apache.flink.runtime.rest.messages.JobVertexFlameGraphParameters
- SubtaskIndexQueryParameter - Class in org.apache.flink.runtime.rest.messages
-
Query parameter specifying the index of a subtask.
- SubtaskIndexQueryParameter() - Constructor for class org.apache.flink.runtime.rest.messages.SubtaskIndexQueryParameter
- SubTaskInitializationMetrics - Class in org.apache.flink.runtime.checkpoint
-
A collection of simple metrics, around the triggering of a checkpoint.
- SubTaskInitializationMetrics(long, long, Map<String, Long>, InitializationStatus) - Constructor for class org.apache.flink.runtime.checkpoint.SubTaskInitializationMetrics
- SubTaskInitializationMetricsBuilder - Class in org.apache.flink.runtime.checkpoint
-
A builder for
SubTaskInitializationMetrics. - SubTaskInitializationMetricsBuilder(long) - Constructor for class org.apache.flink.runtime.checkpoint.SubTaskInitializationMetricsBuilder
- SubtaskKey(String, String, int, int) - Constructor for class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager.SubtaskKey
- SubtaskKey(JobID, OperatorID, TaskInfo) - Constructor for class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager.SubtaskKey
- SubtaskMessageParameters - Class in org.apache.flink.runtime.rest.messages.job
-
Message parameters for subtask REST handlers.
- SubtaskMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskMessageParameters
- SubtaskMetricsHandler - Class in org.apache.flink.runtime.rest.handler.job.metrics
-
Handler that returns subtask metrics.
- SubtaskMetricsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.SubtaskMetricsHandler
- SubtaskMetricsHeaders - Class in org.apache.flink.runtime.rest.messages.job.metrics
- SubtaskMetricsMessageParameters - Class in org.apache.flink.runtime.rest.messages.job.metrics
- SubtaskMetricsMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsMessageParameters
- subtaskReset(int, long) - Method in interface org.apache.flink.runtime.checkpoint.OperatorCoordinatorCheckpointContext
-
Called if a task is recovered as part of a partial failover, meaning a failover handled by the scheduler's failover strategy (by default recovering a pipelined region).
- subtaskReset(int, long) - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator
-
Called if a subtask is recovered as part of a partial failover, meaning a failover handled by the scheduler's failover strategy (by default recovering a pipelined region).
- subtaskReset(int, long) - Method in class org.apache.flink.runtime.operators.coordination.OperatorCoordinatorHolder
- subtaskReset(int, long) - Method in class org.apache.flink.runtime.operators.coordination.RecreateOnResetOperatorCoordinator
- subtaskReset(int, long) - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinator
- subtaskReset(int, long) - Method in class org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator
- SubtasksAllAccumulatorsHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Request handler for the subtasks all accumulators.
- SubtasksAllAccumulatorsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, SubtasksAllAccumulatorsInfo, JobVertexMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.SubtasksAllAccumulatorsHandler
- SubtasksAllAccumulatorsHeaders - Class in org.apache.flink.runtime.rest.messages
-
Message headers for the
SubtasksAllAccumulatorsHandler. - SubtasksAllAccumulatorsInfo - Class in org.apache.flink.runtime.rest.messages.job
-
Response type of the
SubtasksAllAccumulatorsHandler. - SubtasksAllAccumulatorsInfo(JobVertexID, int, Collection<SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo>) - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo
- SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo - Class in org.apache.flink.runtime.rest.messages.job
-
Detailed information about subtask accumulators.
- SubtasksFilterQueryParameter - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
MessageQueryParameterfor selecting subtasks when aggregating metrics. - subtaskSpecificCheckpointDirectory(long) - Method in interface org.apache.flink.runtime.state.LocalSnapshotDirectoryProvider
-
Returns the local state directory for the specific operator subtask and the given checkpoint id w.r.t. our rotation over all available root dirs.
- subtaskSpecificCheckpointDirectory(long) - Method in class org.apache.flink.runtime.state.LocalSnapshotDirectoryProviderImpl
- SubtaskState - Class in org.apache.flink.runtime.checkpoint
-
Deprecated.Internal class for savepoint backwards compatibility. Don't use for other purposes.
- SubtaskState(ChainedStateHandle<OperatorStateHandle>, ChainedStateHandle<OperatorStateHandle>, KeyedStateHandle, KeyedStateHandle) - Constructor for class org.apache.flink.runtime.checkpoint.SubtaskState
-
Deprecated.
- SubtaskStateMapper - Enum in org.apache.flink.runtime.io.network.api.writer
-
The
SubtaskStateMappernarrows down the subtasks that need to be read during rescaling to recover from a particular subtask when in-flight data has been stored in the checkpoint. - SubtaskStateStats - Class in org.apache.flink.runtime.checkpoint
-
Statistics for a single subtask that is part of a checkpoint.
- SubtasksTimesHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Request handler for the subtasks times info.
- SubtasksTimesHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, SubtasksTimesInfo, JobVertexMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.SubtasksTimesHandler
- SubtasksTimesHeaders - Class in org.apache.flink.runtime.rest.messages
-
Message headers for the
SubtasksTimesHandler. - SubtasksTimesHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
- SubtasksTimesInfo - Class in org.apache.flink.runtime.rest.messages
-
Response type of the
SubtasksTimesHandler. - SubtasksTimesInfo(String, String, long, List<SubtasksTimesInfo.SubtaskTimeInfo>) - Constructor for class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
- SubtasksTimesInfo.SubtaskTimeInfo - Class in org.apache.flink.runtime.rest.messages
-
Nested class to encapsulate the sub task times info.
- SubtaskTimeInfo(int, String, long, Map<ExecutionState, Long>) - Constructor for class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
- subtract(Map<ResourceProfile, Integer>) - Method in class org.apache.flink.runtime.util.ResourceCounter
-
Subtracts decrement from this resource counter value and returns the new value.
- subtract(ResourceProfile) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Subtracts another piece of resource profile from this one.
- subtract(ResourceProfile, int) - Method in class org.apache.flink.runtime.util.ResourceCounter
-
Subtracts decrement from the count of the given resourceProfile and returns the new value.
- subtract(ResourceCounter) - Method in class org.apache.flink.runtime.util.ResourceCounter
-
Subtracts decrement from this resource counter value and returns the new value.
- SUCCEEDED - org.apache.flink.runtime.clusterframework.ApplicationStatus
-
Application finished successfully.
- success(String) - Method in class org.apache.flink.runtime.rest.messages.ProfilingInfo
- success(R) - Static method in class org.apache.flink.runtime.rest.handler.async.OperationResult
- Success() - Constructor for class org.apache.flink.runtime.registration.RegistrationResponse.Success
- SUCCESS - org.apache.flink.runtime.checkpoint.PendingCheckpoint.TaskAcknowledgeResult
- SUCCESS - org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager.RegistrationResult
- SUCCESS - org.apache.flink.runtime.rest.handler.async.OperationResultStatus
- SUCCESS - org.apache.flink.runtime.taskexecutor.TaskManagerRunner.Result
- SUCCESSFUL_COMMITTABLES - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- SUFFIX_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- sum(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that sums every window of the data stream at the given position.
- sum(int) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives a rolling sum of the data stream at the given position grouped by the given key.
- sum(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that sums every window of the data stream at the given position.
- sum(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Applies an aggregation that sums every window of the pojo data stream at the given field for every window.
- sum(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Applies an aggregation that gives the current sum of the data stream at the given field by the given key.
- sum(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Applies an aggregation that sums every window of the pojo data stream at the given field for every window.
- SUM - org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter.AggregationMode
- SUM - org.apache.flink.streaming.api.functions.aggregation.AggregationFunction.AggregationType
- SumAggregator<T> - Class in org.apache.flink.streaming.api.functions.aggregation
-
An
AggregationFunctionthat sums up fields. - SumAggregator(int, TypeInformation<T>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumAggregator
- SumAggregator(String, TypeInformation<T>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumAggregator
- SumFunction - Class in org.apache.flink.streaming.api.functions.aggregation
-
Internal function for summing up contents of fields.
- SumFunction() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction
- Summary(StatsSummaryDto, StatsSummaryDto, StatsSummaryDto, StatsSummaryDto, StatsSummaryDto, StatsSummaryDto) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
- Summary(StatsSummaryDto, StatsSummaryDto, StatsSummaryDto, TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration, TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment, StatsSummaryDto) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
- SuperstepBarrier - Class in org.apache.flink.runtime.iterative.concurrent
-
A resettable one-shot latch.
- SuperstepBarrier(ClassLoader) - Constructor for class org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
- SuperstepKickoffLatch - Class in org.apache.flink.runtime.iterative.concurrent
-
Latch used to wait for the previous superstep to complete.
- SuperstepKickoffLatch() - Constructor for class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
- SuperstepKickoffLatchBroker - Class in org.apache.flink.runtime.iterative.concurrent
- supportCompression() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
- supportMultiLeaderSession() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerFactory
-
This indicates whether the process should be terminated after losing leadership.
- supportsAsyncKeyedStateBackend() - Method in interface org.apache.flink.runtime.state.StateBackend
-
Tells if a state backend supports the
AsyncKeyedStateBackend. - supportsBatchSnapshot() - Method in interface org.apache.flink.runtime.operators.coordination.OperatorCoordinator
-
Whether the operator coordinator supports taking snapshot in no-checkpoint/batch scenarios.
- supportsBatchSnapshot() - Method in class org.apache.flink.runtime.operators.coordination.RecreateOnResetOperatorCoordinator
- supportsBatchSnapshot() - Method in class org.apache.flink.runtime.shuffle.NettyShuffleMaster
- supportsBatchSnapshot() - Method in interface org.apache.flink.runtime.shuffle.ShuffleMaster
-
Whether the shuffle master supports taking snapshot in batch scenarios if
BatchExecutionOptions.JOB_RECOVERY_ENABLEDis true. - supportsBatchSnapshot() - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinator
-
Whether the enumerator supports batch snapshot.
- supportsHighlyAvailableStorage() - Method in interface org.apache.flink.runtime.state.CheckpointStorageCoordinatorView
-
Checks whether this backend supports highly available storage of data.
- supportsHighlyAvailableStorage() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageAccess
- supportsHighlyAvailableStorage() - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorageAccess
- supportsNoClaimRestoreMode() - Method in class org.apache.flink.runtime.state.hashmap.HashMapStateBackend
- supportsNoClaimRestoreMode() - Method in interface org.apache.flink.runtime.state.StateBackend
-
Tells if a state backend supports the
RecoveryClaimMode.NO_CLAIMmode. - supportsNormalizedKey() - Method in class org.apache.flink.streaming.api.operators.sortpartition.FixedLengthByteKeyAndValueComparator
- supportsNormalizedKey() - Method in class org.apache.flink.streaming.api.operators.sortpartition.VariableLengthByteKeyAndValueComparator
- SupportsPostCommitTopology<CommittableT> - Interface in org.apache.flink.streaming.api.connector.sink2
-
Allows expert users to implement a custom topology after
Committer. - SupportsPreCommitTopology<WriterResultT,CommittableT> - Interface in org.apache.flink.streaming.api.connector.sink2
-
Allows expert users to implement a custom topology after
SinkWriterand beforeCommitter. - SupportsPreWriteTopology<InputT> - Interface in org.apache.flink.streaming.api.connector.sink2
-
Allows expert users to implement a custom topology before
SinkWriter. - supportsReactiveMode() - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
- supportsSavepointFormat(SavepointFormatType) - Method in class org.apache.flink.runtime.state.hashmap.HashMapStateBackend
- supportsSavepointFormat(SavepointFormatType) - Method in interface org.apache.flink.runtime.state.StateBackend
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.streaming.api.operators.sortpartition.FixedLengthByteKeyAndValueComparator
- supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.streaming.api.operators.sortpartition.VariableLengthByteKeyAndValueComparator
- supportsUnalignedCheckpoints() - Method in class org.apache.flink.streaming.api.graph.NonChainedOutput
- supportsUnalignedCheckpoints() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
- SuppressRestartsException - Exception in org.apache.flink.runtime.execution
-
Exception thrown in order to suppress job restarts.
- SuppressRestartsException(Throwable) - Constructor for exception org.apache.flink.runtime.execution.SuppressRestartsException
- suspend() - Method in class org.apache.flink.runtime.executiongraph.Execution
- suspend() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
- suspend() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- suspend() - Method in class org.apache.flink.runtime.executiongraph.SpeculativeExecutionVertex
- suspend() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedSlotManager
-
Suspends the component.
- suspend() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Suspends the component.
- suspend() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor
-
Suspend the running of the loop which was started by
MailboxProcessor.runMailboxLoop()}. - suspend(Throwable) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- suspend(Throwable) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Suspends the current ExecutionGraph.
- suspend(SavepointFormatType) - Static method in class org.apache.flink.runtime.checkpoint.SavepointType
- SUSPEND - org.apache.flink.runtime.checkpoint.SavepointType.PostCheckpointAction
- SUSPEND_WITH_SAVEPOINT - org.apache.flink.runtime.dispatcher.TriggerSavepointMode
- suspendDefaultAction() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.MailboxDefaultAction.Controller
-
Same as
MailboxDefaultAction.Controller.suspendDefaultAction(PeriodTimer)but without any associated timer measuring the idle time. - suspendDefaultAction() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.MailboxController
- suspendDefaultAction(PeriodTimer) - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.MailboxDefaultAction.Controller
-
Calling this method signals that the mailbox-thread should (temporarily) stop invoking the default action, e.g. because there is currently no input available.
- suspendDefaultAction(PeriodTimer) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.MailboxController
- swap(int, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
- swap(int, int) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
-
Swap items at the given addresses.
- swap(int, int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
- swap(int, int, int, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
- swap(int, int, int, int) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
-
Swap records at the given addresses.
- swap(int, int, int, int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
- switchBuffers() - Method in class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
- switchContext(RecordContext<K>) - Method in interface org.apache.flink.runtime.asyncprocessing.AsyncExecutionController.SwitchContextListener
- switchContext(RecordContext<K>) - Method in interface org.apache.flink.runtime.state.AsyncKeyedStateBackend
-
By default, a state backend does nothing when a key is switched in async processing.
- switchContext(RecordContext<K>) - Method in class org.apache.flink.runtime.state.v2.adaptor.AsyncKeyedStateBackendAdaptor
- SYMMETRIC_IDENTITY - Static variable in class org.apache.flink.runtime.checkpoint.RescaleMappings
- sync() - Method in class org.apache.flink.runtime.state.CompressibleFSDataOutputStream
- sync() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
- sync() - Method in class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
- sync() - Method in class org.apache.flink.runtime.state.filesystem.FileMergingCheckpointStateOutputStream
- sync() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
- sync() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
- sync() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
- SYNC_POINT - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
A sync point with AEC, does nothing with state, checking if the key is occupied by others and blocking if needed.
- SyncEventHandler - Class in org.apache.flink.runtime.iterative.task
-
Listener for
WorkerDoneEventwhich also aggregates all aggregators from iteration tasks and signals the end of the superstep. - SyncEventHandler(int, Map<String, Aggregator<?>>, ClassLoader) - Constructor for class org.apache.flink.runtime.iterative.task.SyncEventHandler
- synchronizedExecutor() - Static method in interface org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
-
Returns an ExecutionDecorator that synchronizes each invocation.
- synchronizedExecutor(Object) - Static method in interface org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor
-
Returns an ExecutionDecorator that synchronizes each invocation on a given object.
- SynchronizedStreamTaskActionExecutor(Object) - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTaskActionExecutor.SynchronizedStreamTaskActionExecutor
-
Deprecated.
- SYNCHRONOUS - org.apache.flink.runtime.state.SnapshotExecutionType
- SynchronousBufferFileReader - Class in org.apache.flink.runtime.io.disk.iomanager
-
A synchronous
BufferFileReaderimplementation. - SynchronousBufferFileReader(FileIOChannel.ID, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.SynchronousBufferFileReader
- SynchronousChainedCombineDriver<IN,OUT> - Class in org.apache.flink.runtime.operators.chaining
-
The chained variant of the combine driver which is also implemented in GroupReduceCombineDriver.
- SynchronousChainedCombineDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
- SynchronousFileIOChannel - Class in org.apache.flink.runtime.io.disk.iomanager
-
A base class for synchronous readers and writers.
- SynchronousFileIOChannel(FileIOChannel.ID, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.SynchronousFileIOChannel
- SyncIteratorWrapper<T> - Class in org.apache.flink.runtime.state.v2
- SyncIteratorWrapper(StateIterator<T>) - Constructor for class org.apache.flink.runtime.state.v2.SyncIteratorWrapper
- syncPointRequestWithCallback(ThrowingRunnable<Exception>) - Method in class org.apache.flink.runtime.asyncprocessing.AsyncExecutionController
-
A helper to request a
StateRequestType.SYNC_POINTand run a callback if it finishes (once the record is not blocked). - SyncPreferredLocationsRetriever - Interface in org.apache.flink.runtime.scheduler
-
Component to retrieve the preferred locations of an execution vertex.
- syncPrepareResources(long) - Method in class org.apache.flink.runtime.state.SavepointSnapshotStrategy
- syncPrepareResources(long) - Method in interface org.apache.flink.runtime.state.SnapshotStrategy
-
Performs the synchronous part of the snapshot.
- SystemOutRedirectionUtils - Class in org.apache.flink.runtime.taskexecutor
-
Utility class for redirect the
System.outandSystem.err. - SystemOutRedirectionUtils() - Constructor for class org.apache.flink.runtime.taskexecutor.SystemOutRedirectionUtils
- SystemProcessingTimeService - Class in org.apache.flink.streaming.runtime.tasks
-
A
TimerServicewhich assigns as current processing time the result of callingSystem.currentTimeMillis()and registers timers using aScheduledThreadPoolExecutor. - SystemResourcesCounter - Class in org.apache.flink.runtime.metrics.util
-
Daemon thread probing system resources.
- SystemResourcesCounter(Duration) - Constructor for class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
- SystemResourcesMetricsInitializer - Class in org.apache.flink.runtime.metrics.util
-
Utility class to initialize system resource metrics.
- SystemResourcesMetricsInitializer() - Constructor for class org.apache.flink.runtime.metrics.util.SystemResourcesMetricsInitializer
- systemTimerService - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
In contrast to
StreamTask.timerServicewe should not register any user timers here.
T
- tailOperatorWrapper - Variable in class org.apache.flink.streaming.runtime.tasks.OperatorChain
- take(int) - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
This method returns the oldest mail from the mailbox (head of queue) or blocks until a mail is available.
- take(int) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
- take(StageRunner.SortStage) - Method in interface org.apache.flink.runtime.operators.sort.StageRunner.StageMessageDispatcher
-
Retrieves and removes the head of the given queue, waiting if necessary until an element becomes available.
- target() - Method in class org.apache.flink.runtime.rest.handler.router.RouteResult
- targetPartition - Variable in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
- targetTotalBuffersPerGate() - Method in class org.apache.flink.runtime.io.network.partition.consumer.GateBuffersSpec
- Task - Class in org.apache.flink.runtime.taskmanager
-
The Task represents one execution of a parallel subtask on a TaskManager.
- Task(JobInformation, TaskInformation, ExecutionAttemptID, AllocationID, List<ResultPartitionDeploymentDescriptor>, List<InputGateDeploymentDescriptor>, MemoryManager, SharedResources, IOManager, ShuffleEnvironment<?, ?>, KvStateService, BroadcastVariableManager, TaskEventDispatcher, ExternalResourceInfoProvider, TaskStateManager, TaskManagerActions, InputSplitProvider, CheckpointResponder, TaskOperatorEventGateway, GlobalAggregateManager, LibraryCacheManager.ClassLoaderHandle, FileCache, TaskManagerRuntimeInfo, TaskMetricGroup, PartitionProducerStateChecker, Executor, ChannelStateWriteRequestExecutorFactory) - Constructor for class org.apache.flink.runtime.taskmanager.Task
-
IMPORTANT: This constructor may not start any work that would need to be undone in the case of a failing task deployment.
- TASK_BACK_PRESSURED_TIME - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- TASK_BUSY_TIME - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- TASK_CHECKPOINT_FAILURE - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- TASK_FAILURE - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- TASK_HARD_BACK_PRESSURED_TIME - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- TASK_IDLE_TIME - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- TASK_MANAGER_NAME - Static variable in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- TASK_MANAGERS_FIELD_AGGREGATED - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
- TASK_MANAGERS_FIELD_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
- TASK_MANAGERS_FIELD_END_TIME - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
- TASK_MANAGERS_FIELD_ENDPOINT - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
- TASK_MANAGERS_FIELD_METRICS - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
- TASK_MANAGERS_FIELD_START_TIME - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
- TASK_MANAGERS_FIELD_STATUS - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
- TASK_MANAGERS_FIELD_STATUS_COUNTS - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
- TASK_MANAGERS_FIELD_TASKMANAGER_ID - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
- TASK_MAX_HARD_BACK_PRESSURED_TIME - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- TASK_MAX_SOFT_BACK_PRESSURED_TIME - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- TASK_SLOTS_AVAILABLE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- TASK_SLOTS_TOTAL - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- TASK_SOFT_BACK_PRESSURED_TIME - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- TASK_STATE_SNAPSHOT_FILENAME - Static variable in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
- Task.NotifyCheckpointOperation - Enum in org.apache.flink.runtime.taskmanager
-
Various operation of notify checkpoint.
- TaskActions - Interface in org.apache.flink.runtime.taskmanager
-
Actions which can be performed on a
Task. - TaskBackPressureResponse - Class in org.apache.flink.runtime.messages
-
Response to the task back pressure request rpc call.
- TaskBackPressureResponse(int, ExecutionAttemptID, double) - Constructor for class org.apache.flink.runtime.messages.TaskBackPressureResponse
- TaskCheckpointMessageParameters - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Message parameters for subtask related checkpoint message.
- TaskCheckpointMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointMessageParameters
- TaskCheckpointStatisticDetailsHandler - Class in org.apache.flink.runtime.rest.handler.job.checkpoints
-
REST handler which serves checkpoint statistics for subtasks.
- TaskCheckpointStatisticDetailsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, TaskCheckpointStatisticsWithSubtaskDetails, TaskCheckpointMessageParameters>, Executor, Cache<JobID, CompletableFuture<CheckpointStatsSnapshot>>, CheckpointStatsCache) - Constructor for class org.apache.flink.runtime.rest.handler.job.checkpoints.TaskCheckpointStatisticDetailsHandler
- TaskCheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Checkpoint statistics for a single task.
- TaskCheckpointStatistics(long, CheckpointStatsStatus, long, long, long, long, long, long, long, int, int) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
- TaskCheckpointStatisticsHeaders - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Headers for the
TaskCheckpointStatisticDetailsHandler. - TaskCheckpointStatisticsWithSubtaskDetails - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Task checkpoint statistics which also includes information about the sub task checkpoint statistics.
- TaskCheckpointStatisticsWithSubtaskDetails(long, CheckpointStatsStatus, long, long, long, long, long, long, long, int, int, TaskCheckpointStatisticsWithSubtaskDetails.Summary, List<SubtaskCheckpointStatistics>) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails
- TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Alignment information for a specific checkpoint at a given task.
- TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Duration of a checkpoint split up into its synchronous and asynchronous part.
- TaskCheckpointStatisticsWithSubtaskDetails.Summary - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Summary of the checkpoint statistics for a given task.
- TaskConfig - Class in org.apache.flink.runtime.operators.util
-
Configuration class which stores all relevant parameters required to set up the Pact tasks.
- TaskConfig(Configuration) - Constructor for class org.apache.flink.runtime.operators.util.TaskConfig
-
Creates a new Task Config that wraps the given configuration.
- taskContext - Variable in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
- taskContext - Variable in class org.apache.flink.runtime.operators.JoinDriver
- TaskContext<S,OT> - Interface in org.apache.flink.runtime.operators
-
The task context gives a driver (e.g.,
MapDriver, orJoinDriver) access to the runtime components and configuration that they can use to fulfil their task. - TaskDeploymentDescriptor - Class in org.apache.flink.runtime.deployment
-
A task deployment descriptor contains all the information necessary to deploy a task on a task manager.
- TaskDeploymentDescriptor(JobID, TaskDeploymentDescriptor.MaybeOffloaded<JobInformation>, TaskDeploymentDescriptor.MaybeOffloaded<TaskInformation>, ExecutionAttemptID, AllocationID, JobManagerTaskRestore, List<ResultPartitionDeploymentDescriptor>, List<InputGateDeploymentDescriptor>) - Constructor for class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
- TaskDeploymentDescriptor.MaybeOffloaded<T> - Class in org.apache.flink.runtime.deployment
-
Wrapper class for serialized values which may be offloaded to the
BlobServeror not. - TaskDeploymentDescriptor.NonOffloaded<T> - Class in org.apache.flink.runtime.deployment
-
A serialized value that is not offloaded to the
BlobServer. - TaskDeploymentDescriptor.Offloaded<T> - Class in org.apache.flink.runtime.deployment
-
Reference to a serialized value that was offloaded to the
BlobServer. - TaskDeploymentDescriptorFactory - Class in org.apache.flink.runtime.deployment
- TaskDeploymentDescriptorFactory(Either<SerializedValue<JobInformation>, PermanentBlobKey>, JobID, TaskDeploymentDescriptorFactory.PartitionLocationConstraint, BlobWriter, boolean, int) - Constructor for class org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory
- TaskDeploymentDescriptorFactory.PartitionLocationConstraint - Enum in org.apache.flink.runtime.deployment
-
Defines whether the partition's location must be known at deployment time or can be unknown and, therefore, updated later.
- TaskDeploymentDescriptorFactory.ShuffleDescriptorAndIndex - Class in org.apache.flink.runtime.deployment
-
This class represents the shuffle descriptor with it index in
ConsumedPartitionGroup. - TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup - Class in org.apache.flink.runtime.deployment
-
A set of shuffle descriptors that will be serialized together.
- TaskEvent - Class in org.apache.flink.runtime.event
-
Subclasses of this event are recognized as custom events that are not part of the core flink runtime.
- TaskEvent() - Constructor for class org.apache.flink.runtime.event.TaskEvent
- TaskEventDispatcher - Class in org.apache.flink.runtime.io.network
-
The task event dispatcher dispatches events flowing backwards from a consuming task to the task producing the consumed result.
- TaskEventDispatcher() - Constructor for class org.apache.flink.runtime.io.network.TaskEventDispatcher
- TaskEventHandler - Class in org.apache.flink.runtime.io.network.api
-
The event handler manages
EventListenerinstances and allows to publish events to them. - TaskEventHandler() - Constructor for class org.apache.flink.runtime.io.network.api.TaskEventHandler
- taskEventPublisher - Variable in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGateFactory
- TaskEventPublisher - Interface in org.apache.flink.runtime.io.network
-
The task event publisher is used for publishing the event to the registered
EventListenerinstances. - TaskException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
-
Exception indicating a task related problem on the
TaskExecutor. - TaskException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskException
- TaskException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskException
- TaskException(Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskException
- TaskExecutionState - Class in org.apache.flink.runtime.taskmanager
-
This class represents an update about a task's execution state.
- TaskExecutionState(ExecutionAttemptID, ExecutionState) - Constructor for class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
Creates a new task execution state update, with no attached exception and no accumulators.
- TaskExecutionState(ExecutionAttemptID, ExecutionState, Throwable) - Constructor for class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
Creates a new task execution state update, with an attached exception but no accumulators.
- TaskExecutionState(ExecutionAttemptID, ExecutionState, Throwable, AccumulatorSnapshot, IOMetrics) - Constructor for class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
Creates a new task execution state update, with an attached exception.
- TaskExecutionStateTransition - Class in org.apache.flink.runtime.executiongraph
-
Wraps
TaskExecutionState, along with actions to take if it is FAILED state. - TaskExecutionStateTransition(TaskExecutionState) - Constructor for class org.apache.flink.runtime.executiongraph.TaskExecutionStateTransition
- TaskExecutionStateTransition(TaskExecutionState, boolean, boolean) - Constructor for class org.apache.flink.runtime.executiongraph.TaskExecutionStateTransition
- TaskExecutor - Class in org.apache.flink.runtime.taskexecutor
-
TaskExecutor implementation.
- TaskExecutor(RpcService, TaskManagerConfiguration, HighAvailabilityServices, TaskManagerServices, ExternalResourceInfoProvider, HeartbeatServices, TaskManagerMetricGroup, String, TaskExecutorBlobService, FatalErrorHandler, TaskExecutorPartitionTracker, DelegationTokenReceiverRepository) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskExecutor
- TaskExecutorBlobService - Interface in org.apache.flink.runtime.blob
-
BlobServicethat gives access to aJobPermanentBlobServiceand allows to set the target blob server address. - TaskExecutorChannelStateExecutorFactoryManager - Class in org.apache.flink.runtime.state
-
This class holds the all
ChannelStateWriteRequestExecutorFactoryobjects for a task executor (manager). - TaskExecutorChannelStateExecutorFactoryManager() - Constructor for class org.apache.flink.runtime.state.TaskExecutorChannelStateExecutorFactoryManager
- TaskExecutorClusterPartitionReleaser - Interface in org.apache.flink.runtime.io.network.partition
-
Interface for releasing cluster partitions on a task executor.
- TaskExecutorConnection - Class in org.apache.flink.runtime.resourcemanager.registration
-
This class is responsible for grouping the TaskExecutorGateway and the InstanceID of a registered task executor.
- TaskExecutorConnection(ResourceID, TaskExecutorGateway) - Constructor for class org.apache.flink.runtime.resourcemanager.registration.TaskExecutorConnection
- TaskExecutorFileMergingManager - Class in org.apache.flink.runtime.state
-
There is one
FileMergingSnapshotManagerfor each job per task manager. - TaskExecutorFileMergingManager() - Constructor for class org.apache.flink.runtime.state.TaskExecutorFileMergingManager
- TaskExecutorFlinkMemory - Class in org.apache.flink.runtime.util.config.memory.taskmanager
-
Flink internal memory components of Task Executor.
- TaskExecutorFlinkMemory(MemorySize, MemorySize, MemorySize, MemorySize, MemorySize, MemorySize) - Constructor for class org.apache.flink.runtime.util.config.memory.taskmanager.TaskExecutorFlinkMemory
- TaskExecutorFlinkMemoryUtils - Class in org.apache.flink.runtime.util.config.memory.taskmanager
-
FlinkMemoryUtilsfor Task Executor. - TaskExecutorFlinkMemoryUtils() - Constructor for class org.apache.flink.runtime.util.config.memory.taskmanager.TaskExecutorFlinkMemoryUtils
- TaskExecutorGateway - Interface in org.apache.flink.runtime.taskexecutor
-
TaskExecutorRPC gateway interface. - TaskExecutorGatewayDecoratorBase - Class in org.apache.flink.runtime.taskexecutor
-
A class that decorates/forwards calls to a
TaskExecutorGateway. - TaskExecutorGatewayDecoratorBase(TaskExecutorGateway) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- TaskExecutorHeartbeatPayload - Class in org.apache.flink.runtime.taskexecutor
-
Payload for heartbeats sent from the TaskExecutor to the ResourceManager.
- TaskExecutorHeartbeatPayload(SlotReport, ClusterPartitionReport) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskExecutorHeartbeatPayload
- TaskExecutorLocalStateStoresManager - Class in org.apache.flink.runtime.state
-
This class holds the all
TaskLocalStateStoreImplobjects for a task executor (manager). - TaskExecutorLocalStateStoresManager(boolean, boolean, Reference<File[]>, Executor) - Constructor for class org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager
- TaskExecutorMemoryConfiguration - Class in org.apache.flink.runtime.taskexecutor
-
TaskExecutorConfiguration collects the configuration of a TaskExecutor instance.
- TaskExecutorMemoryConfiguration(Long, Long, Long, Long, Long, Long, Long, Long, Long, Long) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
- TaskExecutorOperatorEventGateway - Interface in org.apache.flink.runtime.taskexecutor
-
The gateway through which the
OperatorCoordinatorcan send an event to an Operator on the Task Manager side. - TaskExecutorPartitionInfo - Class in org.apache.flink.runtime.io.network.partition
-
Encapsulates meta-information the TaskExecutor requires to be kept for each partition.
- TaskExecutorPartitionInfo(ShuffleDescriptor, IntermediateDataSetID, int) - Constructor for class org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionInfo
- TaskExecutorPartitionTracker - Interface in org.apache.flink.runtime.io.network.partition
-
Utility for tracking partitions.
- TaskExecutorPartitionTrackerImpl - Class in org.apache.flink.runtime.io.network.partition
-
Utility for tracking partitions and issuing release calls to task executors and shuffle masters.
- TaskExecutorPartitionTrackerImpl(ShuffleEnvironment<?, ?>) - Constructor for class org.apache.flink.runtime.io.network.partition.TaskExecutorPartitionTrackerImpl
- TaskExecutorProcessSpec - Class in org.apache.flink.runtime.clusterframework
-
Describe the specifics of different resource dimensions of the TaskExecutor process.
- TaskExecutorProcessSpec(CPUResource, MemorySize, MemorySize, MemorySize, MemorySize, MemorySize, MemorySize, MemorySize, MemorySize, Collection<ExternalResource>) - Constructor for class org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
- TaskExecutorProcessSpec(CPUResource, TaskExecutorFlinkMemory, JvmMetaspaceAndOverhead, int, Collection<ExternalResource>) - Constructor for class org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
- TaskExecutorProcessSpecBuilder - Class in org.apache.flink.runtime.clusterframework
-
Builder for
TaskExecutorProcessSpec. - TaskExecutorProcessUtils - Class in org.apache.flink.runtime.clusterframework
-
Utility class for TaskExecutor memory configurations.
- TaskExecutorRegistration - Class in org.apache.flink.runtime.resourcemanager
-
Information provided by the TaskExecutor when it registers to the ResourceManager.
- TaskExecutorRegistration(String, ResourceID, int, int, HardwareDescription, TaskExecutorMemoryConfiguration, ResourceProfile, ResourceProfile, String) - Constructor for class org.apache.flink.runtime.resourcemanager.TaskExecutorRegistration
- TaskExecutorRegistrationRejection - Class in org.apache.flink.runtime.taskexecutor
-
Rejection response from the
ResourceManagerfor theTaskExecutor. - TaskExecutorRegistrationRejection(String) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationRejection
- TaskExecutorRegistrationSuccess - Class in org.apache.flink.runtime.taskexecutor
-
Base class for responses from the ResourceManager to a registration attempt by a TaskExecutor.
- TaskExecutorRegistrationSuccess(InstanceID, ResourceID, ClusterInformation, byte[]) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
-
Create a new
TaskExecutorRegistrationSuccessmessage. - taskExecutorResourceId - Variable in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGateFactory
- TaskExecutorResourceSpec - Class in org.apache.flink.runtime.taskexecutor
-
Specification of resources to use in running
TaskExecutor. - TaskExecutorResourceSpec(CPUResource, MemorySize, MemorySize, MemorySize, MemorySize, Collection<ExternalResource>) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskExecutorResourceSpec
- TaskExecutorResourceUtils - Class in org.apache.flink.runtime.taskexecutor
-
Utility class for
TaskExecutorResourceSpecof runningTaskExecutor. - TaskExecutorStateChangelogStoragesManager - Class in org.apache.flink.runtime.state
-
This class holds the all
StateChangelogStorageobjects for a task executor (manager). - TaskExecutorStateChangelogStoragesManager() - Constructor for class org.apache.flink.runtime.state.TaskExecutorStateChangelogStoragesManager
- TaskExecutorThreadInfoGateway - Interface in org.apache.flink.runtime.taskexecutor
-
RPC gateway for requesting
ThreadInfoSample. - TaskExecutorToJobManagerHeartbeatPayload - Class in org.apache.flink.runtime.taskexecutor
-
Payload for heartbeats sent from the TaskExecutor to the JobManager.
- TaskExecutorToJobManagerHeartbeatPayload(AccumulatorReport, ExecutionDeploymentReport) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskExecutorToJobManagerHeartbeatPayload
- TaskExecutorToResourceManagerConnection - Class in org.apache.flink.runtime.taskexecutor
-
The connection between a TaskExecutor and the ResourceManager.
- TaskExecutorToResourceManagerConnection(Logger, RpcService, RetryingRegistrationConfiguration, String, ResourceManagerId, Executor, RegistrationConnectionListener<TaskExecutorToResourceManagerConnection, TaskExecutorRegistrationSuccess, TaskExecutorRegistrationRejection>, TaskExecutorRegistration) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskExecutorToResourceManagerConnection
- TaskExecutorToServiceAdapter - Class in org.apache.flink.runtime.taskexecutor
-
Simple adapter for
TaskExecutorto adapt toTaskManagerRunner.TaskExecutorService. - taskID - Variable in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
- TaskInformation - Class in org.apache.flink.runtime.executiongraph
-
Container class for operator/task specific information which are stored at the
ExecutionJobVertex. - TaskInformation(JobVertexID, String, int, int, String, Configuration) - Constructor for class org.apache.flink.runtime.executiongraph.TaskInformation
- TaskInputsOutputsDescriptor - Class in org.apache.flink.runtime.shuffle
-
Describes inputs and outputs information of a task.
- TaskInvokable - Interface in org.apache.flink.runtime.jobgraph.tasks
-
An invokable part of the task.
- taskIOMetricGroup - Variable in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
- TaskIOMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
Metric group that contains shareable pre-defined IO-related metrics.
- TaskIOMetricGroup(TaskMetricGroup) - Constructor for class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- TaskIOMetricGroup(TaskMetricGroup, Clock) - Constructor for class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- TaskIOMetricGroup.SizeSupplier<R> - Interface in org.apache.flink.runtime.metrics.groups
-
Supplier for sizes.
- TaskKvStateRegistry - Class in org.apache.flink.runtime.query
-
A helper for KvState registrations of a single task.
- TaskLocalStateStore - Interface in org.apache.flink.runtime.state
-
Classes that implement this interface serve as a task-manager-level local storage for local checkpointed state.
- TaskLocalStateStoreImpl - Class in org.apache.flink.runtime.state
-
Main implementation of a
TaskLocalStateStore. - TaskLocalStateStoreImpl(JobID, AllocationID, JobVertexID, int, LocalRecoveryConfig, Executor) - Constructor for class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
- TaskMailbox - Interface in org.apache.flink.streaming.runtime.tasks.mailbox
-
A task mailbox provides read and write access to a mailbox and has a lifecycle of open -> (quiesced) -> closed.
- TaskMailbox.MailboxClosedException - Exception in org.apache.flink.streaming.runtime.tasks.mailbox
-
Exception thrown when
TaskMailboxis closed. - TaskMailbox.State - Enum in org.apache.flink.streaming.runtime.tasks.mailbox
-
This enum represents the states of the mailbox lifecycle.
- TaskMailboxImpl - Class in org.apache.flink.streaming.runtime.tasks.mailbox
-
Implementation of
TaskMailboxin aBlockingQueuefashion and tailored towards our use case with multiple writers and single reader. - TaskMailboxImpl() - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
- TaskMailboxImpl(Thread) - Constructor for class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
- TaskManagerActions - Interface in org.apache.flink.runtime.taskmanager
-
Interface for the communication of the
Taskwith theTaskExecutor. - TaskManagerConfiguration - Class in org.apache.flink.runtime.taskexecutor
-
Configuration object for
TaskExecutor. - TaskManagerConfiguration(int, ResourceProfile, ResourceProfile, String[], Duration, Duration, Duration, Configuration, boolean, String, String, String, String, File, RetryingRegistrationConfiguration) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
- TaskManagerCustomLogHandler - Class in org.apache.flink.runtime.rest.handler.taskmanager
-
Rest handler which serves the custom file of the
TaskExecutor. - TaskManagerCustomLogHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, UntypedResponseMessageHeaders<EmptyRequestBody, TaskManagerFileMessageParameters>, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, Duration) - Constructor for class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerCustomLogHandler
- TaskManagerCustomLogHeaders - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
Headers for the
TaskManagerCustomLogHandler. - TaskManagerCustomLogHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerCustomLogHeaders
- TaskManagerDetailsHandler - Class in org.apache.flink.runtime.rest.handler.taskmanager
-
Handler which serves detailed TaskManager information.
- TaskManagerDetailsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, TaskManagerDetailsInfo, TaskManagerMessageParameters>, GatewayRetriever<ResourceManagerGateway>, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerDetailsHandler
- TaskManagerDetailsHeaders - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
Headers for the
TaskManagerDetailsHandlerwhich serves the TaskManager details. - TaskManagerDetailsInfo - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
Message containing base information about a
TaskExecutorand more detailed metrics. - TaskManagerDetailsInfo(ResourceID, String, int, int, long, int, int, ResourceProfileInfo, ResourceProfileInfo, HardwareDescription, TaskExecutorMemoryConfiguration, Boolean, Collection<SlotInfo>, TaskManagerMetricsInfo) - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsInfo
- TaskManagerDetailsInfo(TaskManagerInfoWithSlots, TaskManagerMetricsInfo) - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsInfo
- taskManagerEnv() - Method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
- TaskManagerException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
-
Base exception thrown by the
TaskExecutor. - TaskManagerException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskManagerException
- TaskManagerException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskManagerException
- TaskManagerException(Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskManagerException
- TaskManagerFileMessageParameters - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
Parameters for
TaskManagerCustomLogHandler. - TaskManagerFileMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerFileMessageParameters
- TaskManagerGateway - Interface in org.apache.flink.runtime.jobmanager.slots
-
Task manager gateway interface to communicate with the task manager.
- taskManagerId() - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
- taskManagerID - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskManagerQueryScopeInfo
- taskManagerIdParameter - Variable in class org.apache.flink.runtime.rest.messages.JobTaskManagerMessageParameters
- taskManagerIdParameter - Variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMessageParameters
- TaskManagerIdPathParameter - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
TaskManager id path parameter used by TaskManager related handlers.
- TaskManagerIdPathParameter() - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerIdPathParameter
- TaskManagerInfo - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
Base class containing information for a
TaskExecutor. - TaskManagerInfo - Interface in org.apache.flink.runtime.resourcemanager.slotmanager
-
Information of a TaskManager needed in
SlotManager. - TaskManagerInfo(ResourceID, String, int, int, long, int, int, ResourceProfile, ResourceProfile, HardwareDescription, TaskExecutorMemoryConfiguration, Boolean) - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- TaskManagerInfo(ResourceID, String, int, int, long, int, int, ResourceProfileInfo, ResourceProfileInfo, HardwareDescription, TaskExecutorMemoryConfiguration, Boolean) - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
- TaskManagerInfoWithSlots - Class in org.apache.flink.runtime.resourcemanager
-
Contains the base information about a
TaskExecutorand its allocated slots. - TaskManagerInfoWithSlots(TaskManagerInfo, Collection<SlotInfo>) - Constructor for class org.apache.flink.runtime.resourcemanager.TaskManagerInfoWithSlots
- TaskManagerJobMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
Special
MetricGrouprepresenting everything belonging to a specific job, running on the TaskManager. - TaskManagerJobMetricGroup(MetricRegistry, TaskManagerMetricGroup, JobID, String) - Constructor for class org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
- TaskManagerJobScopeFormat - Class in org.apache.flink.runtime.metrics.scope
-
The scope format for the
JobMetricGroup. - TaskManagerJobScopeFormat(String, TaskManagerScopeFormat) - Constructor for class org.apache.flink.runtime.metrics.scope.TaskManagerJobScopeFormat
- TaskManagerLocation - Class in org.apache.flink.runtime.taskmanager
-
This class encapsulates the connection information of a TaskManager.
- TaskManagerLocation(ResourceID, InetAddress, int) - Constructor for class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
Constructs a new instance connection info object.
- TaskManagerLocation(ResourceID, InetAddress, int, TaskManagerLocation.HostNameSupplier, String) - Constructor for class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
Constructs a new instance connection info object.
- TaskManagerLocation.DefaultHostNameSupplier - Class in org.apache.flink.runtime.taskmanager
-
This Supplier class could retrieve the FQDN host name of the given InetAddress on demand, extract the pure host name and cache the results for later use.
- TaskManagerLocation.HostNameSupplier - Interface in org.apache.flink.runtime.taskmanager
- TaskManagerLocation.IpOnlyHostNameSupplier - Class in org.apache.flink.runtime.taskmanager
-
This Supplier class returns the IP address of the given InetAddress directly, therefore no reverse DNS lookup is required.
- TaskManagerLocation.ResolutionMode - Enum in org.apache.flink.runtime.taskmanager
-
The DNS resolution mode for TaskManager's IP address.
- TaskManagerLogFileHandler - Class in org.apache.flink.runtime.rest.handler.taskmanager
-
Rest handler which serves the log files from
TaskExecutor. - TaskManagerLogFileHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, UntypedResponseMessageHeaders<EmptyRequestBody, TaskManagerMessageParameters>, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, Duration) - Constructor for class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerLogFileHandler
- TaskManagerLogFileHeaders - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
Headers for the
TaskManagerLogFileHandler. - TaskManagerLogListHandler - Class in org.apache.flink.runtime.rest.handler.taskmanager
-
Handler which serves detailed TaskManager log list information.
- TaskManagerLogListHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, LogListInfo, TaskManagerMessageParameters>, GatewayRetriever<ResourceManagerGateway>) - Constructor for class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerLogListHandler
- TaskManagerLogsHeaders - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
Headers for the
TaskManagerLogListHandler. - TaskManagerLogUrlHeaders - Class in org.apache.flink.runtime.rest.messages
-
Headers for the log url retriever of TaskManager.
- TaskManagerMessageParameters - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
Message parameter for a TaskManager specific handler.
- TaskManagerMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMessageParameters
- TaskManagerMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
Special
MetricGrouprepresenting a TaskManager. - TaskManagerMetricsHandler - Class in org.apache.flink.runtime.rest.handler.job.metrics
-
Handler that returns TaskManager metrics.
- TaskManagerMetricsHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.TaskManagerMetricsHandler
- TaskManagerMetricsHeaders - Class in org.apache.flink.runtime.rest.messages.job.metrics
- TaskManagerMetricsInfo - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
Contains information about the TaskManager metrics.
- TaskManagerMetricsInfo(long, long, long, long, long, long, long, long, long, long, long, long, long, long, long, long, long, long, List<TaskManagerMetricsInfo.GarbageCollectorInfo>) - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
- TaskManagerMetricsInfo.GarbageCollectorInfo - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
Information about the garbage collector metrics.
- TaskManagerMetricsMessageParameters - Class in org.apache.flink.runtime.rest.messages.job.metrics
- TaskManagerMetricsMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsMessageParameters
- TaskManagerProfilingFileHandler - Class in org.apache.flink.runtime.rest.handler.taskmanager
-
Rest handler which serves the profiling result file of the
TaskExecutor. - TaskManagerProfilingFileHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, UntypedResponseMessageHeaders<EmptyRequestBody, TaskManagerProfilingFileMessageParameters>, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, Duration) - Constructor for class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerProfilingFileHandler
- TaskManagerProfilingFileHeaders - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
Headers for the
TaskManagerProfilingFileHandler. - TaskManagerProfilingFileHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingFileHeaders
- TaskManagerProfilingFileMessageParameters - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
Parameters for
TaskManagerProfilingFileHandler. - TaskManagerProfilingFileMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerProfilingFileMessageParameters
- TaskManagerProfilingHandler - Class in org.apache.flink.runtime.rest.handler.taskmanager
-
Rest handler which serves the profiling service from a
TaskExecutor. - TaskManagerProfilingHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<ProfilingRequestBody, ProfilingInfo, TaskManagerMessageParameters>, GatewayRetriever<ResourceManagerGateway>, Configuration) - Constructor for class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerProfilingHandler
- TaskManagerProfilingHeaders - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
Headers for the
TaskManagerProfilingHandler. - TaskManagerProfilingListHandler - Class in org.apache.flink.runtime.rest.handler.taskmanager
-
Handler which serves detailed TaskManager profiling list information.
- TaskManagerProfilingListHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, ProfilingInfoList, TaskManagerMessageParameters>, GatewayRetriever<ResourceManagerGateway>) - Constructor for class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerProfilingListHandler
- TaskManagerProfilingListHeaders - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
Headers for the
TaskManagerProfilingListHandler. - TaskManagerQueryScopeInfo(String) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskManagerQueryScopeInfo
- TaskManagerQueryScopeInfo(String, String) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskManagerQueryScopeInfo
- TaskManagerRegistrationInformation - Class in org.apache.flink.runtime.jobmaster
-
DTO for TaskManager registration information.
- TaskManagerRunner - Class in org.apache.flink.runtime.taskexecutor
-
This class is the executable entry point for the task manager in yarn or standalone mode.
- TaskManagerRunner(Configuration, PluginManager, TaskManagerRunner.TaskExecutorServiceFactory) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
- TaskManagerRunner.Result - Enum in org.apache.flink.runtime.taskexecutor
- TaskManagerRunner.TaskExecutorService - Interface in org.apache.flink.runtime.taskexecutor
- TaskManagerRunner.TaskExecutorServiceFactory - Interface in org.apache.flink.runtime.taskexecutor
-
Factory for
TaskExecutor. - TaskManagerRuntimeInfo - Interface in org.apache.flink.runtime.taskmanager
-
Interface to access
TaskExecutorinformation. - TaskManagerScopeFormat - Class in org.apache.flink.runtime.metrics.scope
-
The scope format for the
TaskManagerMetricGroup. - TaskManagerScopeFormat(String) - Constructor for class org.apache.flink.runtime.metrics.scope.TaskManagerScopeFormat
- TaskManagerServices - Class in org.apache.flink.runtime.taskexecutor
- TaskManagerServicesConfiguration - Class in org.apache.flink.runtime.taskexecutor
-
Configuration for the task manager services such as the memory manager, the io manager and the metric registry.
- TaskManagersFilterQueryParameter - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
MessageQueryParameterfor selecting task managers when aggregating metrics. - TaskManagersHandler - Class in org.apache.flink.runtime.rest.handler.taskmanager
-
Returns an overview over all registered TaskManagers of the cluster.
- TaskManagersHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, TaskManagersInfo, EmptyMessageParameters>, GatewayRetriever<ResourceManagerGateway>) - Constructor for class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagersHandler
- TaskManagersHeaders - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
Message headers for the
TaskManagersHandler. - TaskManagersInfo - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
Class containing a collection of
TaskManagerInfo. - TaskManagersInfo(String, ExecutionState, long, long, long, IOMetricsInfo, Map<ExecutionState, Integer>, String, AggregatedTaskDetailsInfo) - Constructor for class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
- TaskManagersInfo(Collection<TaskManagerInfo>) - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersInfo
- TaskManagerSlotInformation - Interface in org.apache.flink.runtime.resourcemanager.slotmanager
-
Basic information about a TaskManager slot.
- TaskManagerStdoutFileHandler - Class in org.apache.flink.runtime.rest.handler.taskmanager
-
Rest handler which serves the stdout file of the
TaskExecutor. - TaskManagerStdoutFileHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, UntypedResponseMessageHeaders<EmptyRequestBody, TaskManagerMessageParameters>, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, Duration) - Constructor for class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerStdoutFileHandler
- TaskManagerStdoutFileHeaders - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
Headers for the
TaskManagerStdoutFileHandler. - TaskManagerThreadDumpHandler - Class in org.apache.flink.runtime.rest.handler.taskmanager
-
Rest handler which serves the thread dump info from a
TaskExecutor. - TaskManagerThreadDumpHandler(GatewayRetriever<? extends RestfulGateway>, Duration, Map<String, String>, MessageHeaders<EmptyRequestBody, ThreadDumpInfo, TaskManagerMessageParameters>, GatewayRetriever<ResourceManagerGateway>) - Constructor for class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerThreadDumpHandler
- TaskManagerThreadDumpHeaders - Class in org.apache.flink.runtime.rest.messages.taskmanager
-
Headers for the
TaskManagerThreadDumpHandler. - TaskMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
Special
MetricGrouprepresenting a Flink runtime Task. - taskName - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
- taskName() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
- TaskNotRunningException - Exception in org.apache.flink.runtime.operators.coordination
-
An exception indicating that a target task is not running.
- TaskNotRunningException(String) - Constructor for exception org.apache.flink.runtime.operators.coordination.TaskNotRunningException
- TaskNotRunningException(String, ExecutionState) - Constructor for exception org.apache.flink.runtime.operators.coordination.TaskNotRunningException
- TaskOperatorEventGateway - Interface in org.apache.flink.runtime.jobgraph.tasks
-
Gateway to send an
OperatorEventorCoordinationRequestfrom a Task to theOperatorCoordinatorJobManager side. - taskOwnedStateDir - Variable in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
- taskOwnedStateDirectory - Variable in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageAccess
- TaskQueryScopeInfo(String, String, int, int) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
- TaskQueryScopeInfo(String, String, int, int, String) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
- TaskScopeFormat - Class in org.apache.flink.runtime.metrics.scope
-
The scope format for the
TaskMetricGroup. - TaskScopeFormat(String, TaskManagerJobScopeFormat) - Constructor for class org.apache.flink.runtime.metrics.scope.TaskScopeFormat
- TaskSlot<T extends TaskSlotPayload> - Class in org.apache.flink.runtime.taskexecutor.slot
-
Container for multiple
tasksbelonging to the same slot. - TaskSlot(int, ResourceProfile, int, JobID, AllocationID, Executor) - Constructor for class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
- TaskSlotPayload - Interface in org.apache.flink.runtime.taskexecutor.slot
-
Payload interface for
TaskSlot. - TaskSlotTable<T extends TaskSlotPayload> - Interface in org.apache.flink.runtime.taskexecutor.slot
-
Container for multiple
TaskSlotinstances. - TaskSlotTableImpl<T extends TaskSlotPayload> - Class in org.apache.flink.runtime.taskexecutor.slot
-
Default implementation of
TaskSlotTable. - TaskSlotTableImpl(int, ResourceProfile, ResourceProfile, int, TimerService<AllocationID>, Executor) - Constructor for class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- TaskState - Class in org.apache.flink.runtime.checkpoint
-
Deprecated.Internal class for savepoint backwards compatibility. Don't use for other purposes.
- TaskState(JobVertexID, int, int, int) - Constructor for class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- TaskStateManager - Interface in org.apache.flink.runtime.state
-
This interface provides methods to report and retrieve state for a task.
- TaskStateManagerImpl - Class in org.apache.flink.runtime.state
-
This class is the default implementation of
TaskStateManagerand collaborates with the job manager throughCheckpointResponder) as well as a task-manager-local state store. - TaskStateManagerImpl(JobID, ExecutionAttemptID, TaskLocalStateStore, FileMergingSnapshotManagerClosableWrapper, StateChangelogStorage<?>, TaskExecutorStateChangelogStoragesManager, JobManagerTaskRestore, CheckpointResponder) - Constructor for class org.apache.flink.runtime.state.TaskStateManagerImpl
- TaskStateManagerImpl(JobID, ExecutionAttemptID, TaskLocalStateStore, FileMergingSnapshotManagerClosableWrapper, StateChangelogStorage<?>, TaskExecutorStateChangelogStoragesManager, JobManagerTaskRestore, CheckpointResponder, SequentialChannelStateReaderImpl) - Constructor for class org.apache.flink.runtime.state.TaskStateManagerImpl
- TaskStateSnapshot - Class in org.apache.flink.runtime.checkpoint
-
This class encapsulates state handles to the snapshots of all operator instances executed within one task.
- TaskStateSnapshot() - Constructor for class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
- TaskStateSnapshot(int, boolean) - Constructor for class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
- TaskStateSnapshot(Map<OperatorID, OperatorSubtaskState>) - Constructor for class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
- TaskStateStats - Class in org.apache.flink.runtime.checkpoint
-
Statistics for a single task/operator that gathers all statistics of its subtasks and provides summary statistics about all subtasks.
- TaskStateStats.TaskStateStatsSummary - Class in org.apache.flink.runtime.checkpoint
-
Summary of the subtask stats of a single task/operator.
- TaskStateStatsSummary() - Constructor for class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
- TaskStatsRequestCoordinator<T,V> - Class in org.apache.flink.runtime.webmonitor.stats
-
Encapsulates the common functionality for requesting statistics from tasks and combining their responses.
- TaskStatsRequestCoordinator(Executor, Duration) - Constructor for class org.apache.flink.runtime.webmonitor.stats.TaskStatsRequestCoordinator
-
Creates a new coordinator for the cluster.
- TaskStatsRequestCoordinator.PendingStatsRequest<T,V> - Class in org.apache.flink.runtime.webmonitor.stats
-
A pending task stats request, which collects samples from individual tasks and completes the response future upon gathering all of of them.
- TaskSubmissionException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
-
Exception indicating a problem with the
Tasksubmission at theTaskException. - TaskSubmissionException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskSubmissionException
- TaskSubmissionException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskSubmissionException
- TaskSubmissionException(Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskSubmissionException
- TaskThreadInfoResponse - Class in org.apache.flink.runtime.messages
-
Response to the request to collect thread details samples.
- TaskThreadInfoResponse(Map<ExecutionAttemptID, Collection<ThreadInfoSample>>) - Constructor for class org.apache.flink.runtime.messages.TaskThreadInfoResponse
-
Creates a response to the request to collect thread details samples.
- teardown() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
- teardown() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
- teardown() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
- teardown() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
- teardown() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
- teardown() - Method in interface org.apache.flink.runtime.operators.ResettableDriver
- TempBarrier<T> - Class in org.apache.flink.runtime.operators
-
This class facilitates JVM-local exchange between stages of a batch job.
- TempBarrier(AbstractInvokable, MutableObjectIterator<T>, TypeSerializerFactory<T>, MemoryManager, IOManager, int, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.TempBarrier
- tempBarriers - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The optional temp barriers on the inputs for dead-lock breaking.
- tempFileCounter - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
-
Counter to generate unique names for temporary files.
- temporary(File) - Static method in class org.apache.flink.runtime.state.SnapshotDirectory
-
Creates a local temporary snapshot directory for the given path.
- Terminable - Interface in org.apache.flink.runtime.iterative.task
-
Models the functionality that the termination of an iterative task can be requested from outside.
- terminate() - Method in class org.apache.flink.runtime.resourcemanager.active.ActiveResourceManager
- terminate() - Method in interface org.apache.flink.runtime.resourcemanager.active.ResourceManagerDriver
-
Terminate the deployment specific components.
- terminate() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
Terminates the framework specific components.
- terminate() - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
- terminate(SavepointFormatType) - Static method in class org.apache.flink.runtime.checkpoint.SavepointType
- TERMINATE - org.apache.flink.runtime.checkpoint.SavepointType.PostCheckpointAction
- TERMINATE_WITH_SAVEPOINT - org.apache.flink.runtime.dispatcher.TriggerSavepointMode
- terminated() - Static method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexFlameGraph
- TERMINATED_PAYLOAD - Static variable in interface org.apache.flink.runtime.jobmaster.LogicalSlot
- terminateTaskManager(int) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
Terminates a TaskManager with the given index.
- TerminationEvent - Class in org.apache.flink.runtime.iterative.event
-
Signals that the iteration is completely executed, participating tasks must terminate now.
- TerminationEvent() - Constructor for class org.apache.flink.runtime.iterative.event.TerminationEvent
- TerminationModeQueryParameter - Class in org.apache.flink.runtime.rest.messages
-
Termination mode query parameter.
- TerminationModeQueryParameter() - Constructor for class org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter
- TerminationModeQueryParameter.TerminationMode - Enum in org.apache.flink.runtime.rest.messages
-
Termination mode.
- terminationRequested() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
- terminationRequested() - Method in class org.apache.flink.runtime.iterative.task.IterationSynchronizationSinkTask
- terminationRequested() - Method in interface org.apache.flink.runtime.iterative.task.Terminable
- terminationSignaled() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
- test() - Method in interface org.apache.flink.streaming.api.operators.InternalTimeServiceManager.ShouldStopAdvancingFn
- TestableKeyedStateBackend<K> - Interface in org.apache.flink.runtime.state
-
A keyed state backend interface for internal testing purpose.
- testHash(int) - Method in class org.apache.flink.runtime.operators.util.BloomFilter
- ThreadDumpInfo - Class in org.apache.flink.runtime.rest.messages
-
Class containing thread dump information.
- ThreadDumpInfo.ThreadInfo - Class in org.apache.flink.runtime.rest.messages
-
Class containing information about a thread.
- ThreadInfoRequestCoordinator - Class in org.apache.flink.runtime.webmonitor.threadinfo
-
A coordinator for triggering and collecting thread info stats of running job vertex subtasks.
- ThreadInfoRequestCoordinator(Executor, Duration) - Constructor for class org.apache.flink.runtime.webmonitor.threadinfo.ThreadInfoRequestCoordinator
-
Creates a new coordinator for the job.
- ThreadInfoSample - Class in org.apache.flink.runtime.messages
-
A serializable wrapper container for transferring parts of the
ThreadInfo. - ThreadInfoSamplesRequest - Class in org.apache.flink.runtime.webmonitor.threadinfo
-
A wrapper for parameters of a thread info sampling request.
- ThreadInfoSamplesRequest(int, int, Duration, int) - Constructor for class org.apache.flink.runtime.webmonitor.threadinfo.ThreadInfoSamplesRequest
- ThresholdExceedException(String) - Constructor for exception org.apache.flink.runtime.metrics.ThresholdMeter.ThresholdExceedException
- ThresholdMeter - Class in org.apache.flink.runtime.metrics
-
A timestamp queue based threshold meter.
- ThresholdMeter(double, Duration) - Constructor for class org.apache.flink.runtime.metrics.ThresholdMeter
- ThresholdMeter(double, Duration, Clock) - Constructor for class org.apache.flink.runtime.metrics.ThresholdMeter
- ThresholdMeter.ThresholdExceedException - Exception in org.apache.flink.runtime.metrics
-
Exception thrown when a threshold exceeds.
- ThroughputCalculator - Class in org.apache.flink.runtime.throughput
-
Class for measuring the throughput based on incoming data size and measurement period.
- ThroughputCalculator(Clock) - Constructor for class org.apache.flink.runtime.throughput.ThroughputCalculator
- ThrowableAnnotation - Annotation Type in org.apache.flink.runtime.throwable
-
Annotation to classify subclasses of
Throwableinto categories w.r.t. recovery. - ThrowableClassifier - Class in org.apache.flink.runtime.throwable
-
Helper class, given a exception do the classification.
- ThrowableClassifier() - Constructor for class org.apache.flink.runtime.throwable.ThrowableClassifier
- ThrowableType - Enum in org.apache.flink.runtime.throwable
-
Enum for the classification of
Throwableobjects into failure/recovery classes. - ThrowingIterator<E> - Interface in org.apache.flink.runtime.state.restore
-
Modified
Iteratorinterface that lets the implementation throw anIOException. - ThrowingJobGraphWriter - Enum in org.apache.flink.runtime.jobmanager
-
JobGraphWriterimplementation which does not allow to storeJobGraph. - ticketCacheEntry() - Static method in class org.apache.flink.runtime.security.KerberosUtils
- TierConsumerAgent - Interface in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier
-
The
TierConsumerAgentis the consumer agent of each tier in tiered store, which could read data from responding tier. - TieredInternalShuffleMaster - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle
-
A wrapper internal shuffle master class for tiered storage.
- TieredInternalShuffleMaster(ShuffleMasterContext) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredInternalShuffleMaster
- TieredResultPartition - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle
-
TieredResultPartitionappends records and events to the tiered storage, which supports the upstream dynamically switches storage tier for writing shuffle data, and the downstream will read data from the relevant tier. - TieredResultPartition(String, int, ResultPartitionID, ResultPartitionType, int, int, ResultPartitionManager, BufferCompressor, SupplierWithException<BufferPool, IOException>, TieredStorageProducerClient, TieredStorageResourceRegistry, TieredStorageNettyServiceImpl, List<TieredStorageMemorySpec>, TieredStorageMemoryManager) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartition
- TieredResultPartitionFactory - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle
-
TieredResultPartitionFactorycontains the components to set up tiered storage. - TieredResultPartitionFactory(TieredStorageConfiguration, TieredStorageNettyServiceImpl, TieredStorageResourceRegistry) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredResultPartitionFactory
- TieredStorageBytesBasedDataIdentifier - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.common
-
The bytes based unique identification for the Tiered Storage.
- TieredStorageBytesBasedDataIdentifier(byte[]) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageBytesBasedDataIdentifier
- TieredStorageConfiguration - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.common
-
Configurations for the Tiered Storage.
- TieredStorageConsumerClient - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage
-
TieredStorageConsumerClientis used to read buffer from tiered store. - TieredStorageConsumerClient(List<TierFactory>, List<TieredStorageConsumerSpec>, List<List<TierShuffleDescriptor>>, TieredStorageNettyService) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageConsumerClient
- TieredStorageConsumerSpec - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage
-
Describe the different data sources in
TieredStorageConsumerClient. - TieredStorageConsumerSpec(int, TieredStoragePartitionId, TieredStorageInputChannelId, ResultSubpartitionIndexSet) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageConsumerSpec
- TieredStorageDataIdentifier - Interface in org.apache.flink.runtime.io.network.partition.hybrid.tiered.common
-
Identifier interface in the Tiered Storage.
- TieredStorageIdMappingUtils - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.common
-
Utils to convert the Ids to Tiered Storage Ids, or vice versa.
- TieredStorageIdMappingUtils() - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageIdMappingUtils
- TieredStorageInputChannelId - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.common
-
Identifier of an InputChannel.
- TieredStorageInputChannelId(int) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageInputChannelId
- TieredStorageMasterClient - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage
-
Client of the Tiered Storage used by the master.
- TieredStorageMasterClient(List<TierMasterAgent>) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMasterClient
- TieredStorageMemoryManager - Interface in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage
-
The
TieredStorageMemoryManageris to request or recycle buffers fromLocalBufferPoolfor different memory owners, for example, the tiers, the buffer accumulator, etc. - TieredStorageMemoryManagerImpl - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage
-
The implementation for
TieredStorageMemoryManager. - TieredStorageMemoryManagerImpl(float, boolean) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemoryManagerImpl
-
The constructor of the
TieredStorageMemoryManagerImpl. - TieredStorageMemorySpec - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage
-
The memory specs for a memory owner, including the owner itself, the number of guaranteed buffers of the memory owner, etc.
- TieredStorageMemorySpec(Object, int) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemorySpec
- TieredStorageMemorySpec(Object, int, boolean) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemorySpec
- TieredStorageNettyService - Interface in org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty
-
TieredStorageNettyServiceis used to create writers and readers to netty. - TieredStorageNettyServiceImpl - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty
-
The default implementation of
TieredStorageNettyService. - TieredStorageNettyServiceImpl(TieredStorageResourceRegistry) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.TieredStorageNettyServiceImpl
- TieredStoragePartitionId - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.common
-
Identifier of a partition.
- TieredStoragePartitionId(ResultPartitionID) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStoragePartitionId
- TieredStorageProducerClient - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage
-
Client of the Tiered Storage used by the producer.
- TieredStorageProducerClient(int, boolean, BufferAccumulator, BufferCompressor, List<TierProducerAgent>) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageProducerClient
- TieredStorageProducerMetricUpdate - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage
-
The metric statistics for the tiered storage producer.
- TieredStorageResource - Interface in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage
-
The resource (e.g., local files, remote storage files, etc.) for the Tiered Storage.
- TieredStorageResourceRegistry - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage
-
A registry that maintains local or remote resources that correspond to a certain set of data in the Tiered Storage.
- TieredStorageResourceRegistry() - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageResourceRegistry
- TieredStorageResultSubpartitionView - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty
-
The
TieredStorageResultSubpartitionViewis the implementation ofResultSubpartitionViewofTieredResultPartition. - TieredStorageResultSubpartitionView(BufferAvailabilityListener, List<NettyPayloadManager>, List<NettyConnectionId>, List<NettyServiceProducer>) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.TieredStorageResultSubpartitionView
- TieredStorageSortBuffer - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage
-
When getting buffers, The
SortBasedDataBufferneed not recycle the read target buffer.. - TieredStorageSortBuffer(LinkedList<MemorySegment>, BufferRecycler, int, int, int, boolean) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageSortBuffer
- TieredStorageSubpartitionId - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.common
-
Identifier of a subpartition.
- TieredStorageSubpartitionId(int) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageSubpartitionId
- TieredStorageTopicId - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.common
-
Identifier of a topic.
- TieredStorageTopicId(byte[]) - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageTopicId
- TieredStorageUtils - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.common
-
Utils for reading from or writing to tiered storage.
- TieredStorageUtils() - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageUtils
- TierFactory - Interface in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier
-
A factory that creates all the components of a tier.
- TierFactoryInitializer - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle
-
A class responsible for initializing and returning a list of
TierFactoryinstances based on the providedTieredStorageConfiguration. - TierFactoryInitializer() - Constructor for class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TierFactoryInitializer
- TierMasterAgent - Interface in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier
-
The master-side agent of a Tier.
- TierProducerAgent - Interface in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier
-
The producer-side agent of a Tier.
- TierShuffleDescriptor - Interface in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier
-
The
TierShuffleDescriptorinterface is the shuffle descriptor for a single tier. - TierShuffleHandler - Interface in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier
-
A handler to process the call back result from each tier, the callbacks can be some events, some errors, some exceptions, etc.
- timeDomain() - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction.OnTimerContext
-
The
TimeDomainof the firing timer. - timeDomain() - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.OnTimerContext
-
The
TimeDomainof the firing timer, i.e. if it is event or processing time timer. - timeDomain() - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.OnTimerContext
-
The
TimeDomainof the firing timer. - timeDomain() - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction.OnTimerContext
-
The
TimeDomainof the firing timer. - timeDomain() - Method in class org.apache.flink.streaming.api.functions.ProcessFunction.OnTimerContext
-
The
TimeDomainof the firing timer. - TimeDomain - Enum in org.apache.flink.streaming.api
-
TimeDomainspecifies whether a firing timer is based on event time or processing time. - timeout - Variable in class org.apache.flink.runtime.rest.handler.LeaderRetrievalHandler
- TIMEOUTABLE_ALIGNED_CHECKPOINT_BARRIER - org.apache.flink.runtime.io.network.buffer.Buffer.DataType
-
Buffer.DataType.TIMEOUTABLE_ALIGNED_CHECKPOINT_BARRIERindicates that this buffer represents a serialized checkpoint barrier of aligned exactly-once checkpoint mode, that can be time-out'ed to an unaligned checkpoint barrier. - TimeoutListener<K> - Interface in org.apache.flink.runtime.taskexecutor.slot
-
Listener for timeout events by the
TimerService. - timeoutSlot(AllocationID, UUID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.SlotActions
-
Timeout the task slot for the given allocation id.
- Timer(long, K, W) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
- TIMER_COMPARATOR - Static variable in interface org.apache.flink.streaming.api.operators.InternalTimer
-
Function to compare instances of
InternalTimer. - TimerException - Exception in org.apache.flink.streaming.runtime.tasks
-
RuntimeExceptionfor wrapping exceptions that are thrown in the timer callback of the timer service inStreamTask. - TimerException(Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.TimerException
- TimerGauge - Class in org.apache.flink.runtime.metrics
-
TimerGaugemeasures how much time is spent in a given state, with entry into that state being signaled byTimerGauge.markStart(). - TimerGauge() - Constructor for class org.apache.flink.runtime.metrics.TimerGauge
- TimerGauge(int) - Constructor for class org.apache.flink.runtime.metrics.TimerGauge
- TimerGauge(Clock) - Constructor for class org.apache.flink.runtime.metrics.TimerGauge
- TimerGauge(Clock, int) - Constructor for class org.apache.flink.runtime.metrics.TimerGauge
- TimerGauge.StartStopListener - Interface in org.apache.flink.runtime.metrics
-
Listens for
TimerGauge.markStart()andTimerGauge.markEnd()events. - TimerHeapInternalTimer<K,N> - Class in org.apache.flink.streaming.api.operators
-
Implementation of
InternalTimerto use with aHeapPriorityQueueSet. - TimerHeapInternalTimer(long, K, N) - Constructor for class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
- TimerSerializer<K,N> - Class in org.apache.flink.streaming.api.operators
-
A serializer for
TimerHeapInternalTimerobjects that produces a serialization format that is lexicographically aligned the priority of the timers. - TimerSerializer(TypeSerializer<K>, TypeSerializer<N>) - Constructor for class org.apache.flink.streaming.api.operators.TimerSerializer
- TimerSerializerSnapshot<K,N> - Class in org.apache.flink.streaming.api.operators
-
Snapshot class for the
TimerSerializer. - TimerSerializerSnapshot() - Constructor for class org.apache.flink.streaming.api.operators.TimerSerializerSnapshot
- TimerSerializerSnapshot(TimerSerializer<K, N>) - Constructor for class org.apache.flink.streaming.api.operators.TimerSerializerSnapshot
- timerService - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
The internal
TimerServiceused to define the current processing time (default =System.currentTimeMillis()) and register timers for tasks to be executed in the future. - timerService() - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context
-
A
TimerServicefor querying time and registering timers. - timerService() - Method in class org.apache.flink.streaming.api.functions.co.KeyedBroadcastProcessFunction.ReadOnlyContext
-
A
TimerServicefor querying time and registering timers. - timerService() - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.Context
-
A
TimerServicefor querying time and registering timers. - timerService() - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
-
A
TimerServicefor querying time and registering timers. - timerService() - Method in class org.apache.flink.streaming.api.functions.ProcessFunction.Context
-
A
TimerServicefor querying time and registering timers. - TimerService<K> - Interface in org.apache.flink.runtime.taskexecutor.slot
-
Service to register timeouts for a given key.
- TimerService - Interface in org.apache.flink.streaming.api
-
Interface for working with time and timers.
- TimerService - Interface in org.apache.flink.streaming.runtime.tasks
-
A common timer service interface with life cycle methods.
- timeServiceManager - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
- timeServiceManager - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
- timestamp - Variable in class org.apache.flink.streaming.api.watermark.Watermark
-
The timestamp of the watermark in milliseconds.
- timestamp - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
- timestamp() - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context
-
Timestamp of the element currently being processed or timestamp of a firing timer.
- timestamp() - Method in class org.apache.flink.streaming.api.functions.co.KeyedCoProcessFunction.Context
-
Timestamp of the element currently being processed or timestamp of a firing timer.
- timestamp() - Method in class org.apache.flink.streaming.api.functions.KeyedProcessFunction.Context
-
Timestamp of the element currently being processed or timestamp of a firing timer.
- timestamp() - Method in class org.apache.flink.streaming.api.functions.ProcessFunction.Context
-
Timestamp of the element currently being processed or timestamp of a firing timer.
- timestamp() - Method in interface org.apache.flink.streaming.api.functions.sink.legacy.SinkFunction.Context
-
Deprecated.Returns the timestamp of the current input record or
nullif the element does not have an assigned timestamp. - timestampedCollector - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
This is given to the
InternalWindowFunctionfor emitting elements with a given timestamp. - TimestampedCollector<T> - Class in org.apache.flink.streaming.api.operators
- TimestampedCollector(Output<StreamRecord<T>>) - Constructor for class org.apache.flink.streaming.api.operators.TimestampedCollector
-
Creates a new
TimestampedCollectorthat wraps the givenOutput. - TimestampedFileInputSplit - Class in org.apache.flink.streaming.api.functions.source
-
A
FileInputSplitwithTimestampedInputSplit. - TimestampedFileInputSplit(long, int, Path, long, long, String[]) - Constructor for class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
-
Creates a
TimestampedFileInputSplitbased on the file modification time and the rest of the information of theFileInputSplit, as returned by the underlying filesystem. - TimestampedInputSplit - Interface in org.apache.flink.streaming.api.functions.source
-
An extended
InputSplitthat also includes information about: The modification time of the file this split belongs to. - TimestampedValue<T> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
Stores the value and the timestamp of the record.
- TimestampedValue(T) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
-
Creates a new TimestampedValue.
- TimestampedValue(T, long) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
-
Creates a new TimestampedValue wrapping the given value.
- TimestampsAndWatermarks<T> - Interface in org.apache.flink.streaming.api.operators.source
-
Basic interface for the timestamp extraction and watermark generation logic for the
SourceReader. - TimestampsAndWatermarks.TimestampsAndWatermarksContextProvider - Class in org.apache.flink.streaming.api.operators.source
- TimestampsAndWatermarks.WatermarkUpdateListener - Interface in org.apache.flink.streaming.api.operators.source
-
Lets the owner/creator of the output know about latest emitted watermark.
- TimestampsAndWatermarksContext - Class in org.apache.flink.streaming.api.operators.source
-
A simple implementation of a context that is both
TimestampAssignerSupplier.ContextandWatermarkGeneratorSupplier.Context. - TimestampsAndWatermarksContext(MetricGroup, RelativeClock) - Constructor for class org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarksContext
- TimestampsAndWatermarksContextProvider(MetricGroup) - Constructor for class org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks.TimestampsAndWatermarksContextProvider
- TimestampsAndWatermarksOperator<T> - Class in org.apache.flink.streaming.runtime.operators
-
A stream operator that may do one or both of the following: extract timestamps from events and generate watermarks.
- TimestampsAndWatermarksOperator(StreamOperatorParameters<T>, WatermarkStrategy<T>, boolean) - Constructor for class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator
- TimestampsAndWatermarksOperator.WatermarkEmitter - Class in org.apache.flink.streaming.runtime.operators
-
Implementation of the
WatermarkEmitter, based on the components that are available inside a stream operator. - TimestampsAndWatermarksOperatorFactory<T> - Class in org.apache.flink.streaming.runtime.operators
- TimestampsAndWatermarksOperatorFactory(WatermarkStrategy<T>, boolean) - Constructor for class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperatorFactory
- TimestampsAndWatermarksTransformation<IN> - Class in org.apache.flink.streaming.api.transformations
- TimestampsAndWatermarksTransformation(String, int, Transformation<IN>, WatermarkStrategy<IN>, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.TimestampsAndWatermarksTransformation
-
Creates a new
Transformationwith the given name, output type and parallelism. - TimestampsAndWatermarksTransformationTranslator<IN> - Class in org.apache.flink.streaming.runtime.translators
- TimestampsAndWatermarksTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.TimestampsAndWatermarksTransformationTranslator
- TimeToConsumeGauge - Class in org.apache.flink.runtime.io.network.metrics
-
Gauge metric measuring the maximal time to consume all buffers of all input gates.
- TimeToConsumeGauge(SingleInputGate[]) - Constructor for class org.apache.flink.runtime.io.network.metrics.TimeToConsumeGauge
- TimeWindow - Class in org.apache.flink.streaming.api.windowing.windows
- TimeWindow(long, long) - Constructor for class org.apache.flink.streaming.api.windowing.windows.TimeWindow
- TimeWindow.Serializer - Class in org.apache.flink.streaming.api.windowing.windows
-
The serializer used to write the TimeWindow type.
- TimeWindow.Serializer.TimeWindowSerializerSnapshot - Class in org.apache.flink.streaming.api.windowing.windows
-
Serializer configuration snapshot for compatibility and format evolution.
- TimeWindowSerializerSnapshot() - Constructor for class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer.TimeWindowSerializerSnapshot
- to() - Method in class org.apache.flink.runtime.state.changelog.SequenceNumberRange.GenericSequenceNumberRange
- to() - Method in interface org.apache.flink.runtime.state.changelog.SequenceNumberRange
-
Exclusive.
- toArray() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- toArray() - Method in class org.apache.flink.runtime.util.BooleanArrayList
- toArray() - Method in class org.apache.flink.runtime.util.IntArrayList
- toArray() - Method in class org.apache.flink.runtime.util.LongArrayList
- toArray(O[]) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
- toArray(T1[]) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- toArrayList() - Method in class org.apache.flink.runtime.util.BoundedFIFOQueue
- toAsyncSnapshotFutureTask(CloseableRegistry) - Method in class org.apache.flink.runtime.state.AsyncSnapshotCallable
-
Creates a future task from this and registers it with the given
CloseableRegistry. - toBuffer(AbstractEvent, boolean) - Static method in class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
- toBufferConsumer(AbstractEvent, boolean) - Static method in class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
- toBuilder() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
- toBytes() - Method in class org.apache.flink.runtime.operators.util.BitSet
-
Serializing
MemorySegmentto bytes, note that only heap memory is currently supported. - toBytes(BloomFilter) - Static method in class org.apache.flink.runtime.operators.util.BloomFilter
-
Serializing to bytes, note that only heap memory is currently supported.
- toConfiguration() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
- toConfiguration(SavepointRestoreSettings, Configuration) - Static method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
- toDebugString(boolean) - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
- toDebugString(boolean) - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
- toFileMergingStorage(FileMergingSnapshotManager, Environment) - Method in interface org.apache.flink.runtime.state.CheckpointStorageWorkerView
-
Return
FsMergingCheckpointStorageAccessif file merging is enabled. - toFileMergingStorage(FileMergingSnapshotManager, Environment) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageAccess
- toInputChannel() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RecoveredInputChannel
- toInputChannelInternal() - Method in class org.apache.flink.runtime.io.network.partition.consumer.LocalRecoveredInputChannel
- toInputChannelInternal() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RecoveredInputChannel
- toInputChannelInternal() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteRecoveredInputChannel
- toJobExecutionResult(ClassLoader) - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
- toJobExecutionResult(ClassLoader) - Method in class org.apache.flink.runtime.jobmaster.JobResult
-
Converts the
JobResultto aJobExecutionResult. - toKeyedStateHandleSnapshotResult(SnapshotResult<StreamStateHandle>, KeyGroupRangeOffsets, CheckpointStreamWithResultProvider.KeyedStateHandleFactory) - Static method in interface org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
-
Helper method that takes a
SnapshotResultand aKeyGroupRangeOffsetsand creates aSnapshotResultby combining the key groups offsets with all the present stream state handles. - toNonFileMerging() - Method in class org.apache.flink.runtime.state.filesystem.FsMergingCheckpointStorageLocation
- TOO_MANY_CHECKPOINT_REQUESTS - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- Topology<VID extends VertexID,RID extends ResultID,V extends Vertex<VID,RID,V,R>,R extends Result<VID,RID,V,R>,PR extends PipelinedRegion<VID,RID,V,R>> - Interface in org.apache.flink.runtime.topology
-
Extends the
BaseTopologyby pipelined regions. - toSerializedEvent(AbstractEvent) - Static method in class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
- toString() - Method in exception org.apache.flink.runtime.asyncprocessing.AsyncStateException
- toString() - Method in class org.apache.flink.runtime.asyncprocessing.EpochManager.Epoch
- toString() - Method in class org.apache.flink.runtime.asyncprocessing.RecordContext
- toString() - Method in class org.apache.flink.runtime.blob.BlobKey
- toString() - Method in class org.apache.flink.runtime.blocklist.BlockedNode
- toString() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
- toString() - Method in class org.apache.flink.runtime.checkpoint.channel.InputChannelInfo
- toString() - Method in class org.apache.flink.runtime.checkpoint.channel.ResultSubpartitionInfo
- toString() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetaData
- toString() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
- toString() - Method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
- toString() - Method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
- toString() - Method in class org.apache.flink.runtime.checkpoint.CheckpointType
- toString() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
- toString() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
- toString() - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager.SpaceStat
- toString() - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager.SubtaskKey
- toString() - Method in class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFile
- toString() - Method in class org.apache.flink.runtime.checkpoint.FinishedOperatorSubtaskState
- toString() - Method in class org.apache.flink.runtime.checkpoint.FullyFinishedOperatorState
- toString() - Method in class org.apache.flink.runtime.checkpoint.InflightDataRescalingDescriptor.InflightDataGateOrPartitionRescalingDescriptor
- toString() - Method in class org.apache.flink.runtime.checkpoint.InflightDataRescalingDescriptor
- toString() - Method in class org.apache.flink.runtime.checkpoint.JobManagerTaskRestore
- toString() - Method in class org.apache.flink.runtime.checkpoint.MasterState
- toString() - Method in class org.apache.flink.runtime.checkpoint.metadata.CheckpointMetadata
- toString() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
- toString() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
- toString() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
- toString() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
- toString() - Method in class org.apache.flink.runtime.checkpoint.RescaleMappings
- toString() - Method in class org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
- toString() - Method in class org.apache.flink.runtime.checkpoint.SavepointType
- toString() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
- toString() - Method in class org.apache.flink.runtime.checkpoint.SubTaskInitializationMetrics
- toString() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
Deprecated.
- toString() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- toString() - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
- toString() - Method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
- toString() - Method in class org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpec
- toString() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceID
- toString() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
- toString() - Method in class org.apache.flink.runtime.clusterframework.types.SlotID
- toString() - Method in class org.apache.flink.runtime.clusterframework.types.SlotProfile
- toString() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
- toString() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
- toString() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
- toString() - Method in class org.apache.flink.runtime.entrypoint.ClusterInformation
- toString() - Method in class org.apache.flink.runtime.entrypoint.DeterminismEnvelope
- toString() - Method in class org.apache.flink.runtime.entrypoint.WorkingDirectory
- toString() - Method in class org.apache.flink.runtime.executiongraph.Execution
- toString() - Method in class org.apache.flink.runtime.executiongraph.ExecutionAttemptID
- toString() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- toString() - Method in class org.apache.flink.runtime.executiongraph.failover.ExponentialDelayRestartBackoffTimeStrategy
- toString() - Method in class org.apache.flink.runtime.executiongraph.failover.FailureRateRestartBackoffTimeStrategy
- toString() - Method in class org.apache.flink.runtime.executiongraph.failover.FixedDelayRestartBackoffTimeStrategy
- toString() - Method in enum org.apache.flink.runtime.executiongraph.failover.NoRestartBackoffTimeStrategy.NoRestartBackoffTimeStrategyFactory
- toString() - Method in enum org.apache.flink.runtime.executiongraph.failover.NoRestartBackoffTimeStrategy
- toString() - Method in class org.apache.flink.runtime.executiongraph.IndexRange
- toString() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
- toString() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
- toString() - Method in class org.apache.flink.runtime.instance.HardwareDescription
- toString() - Method in class org.apache.flink.runtime.io.AvailabilityProvider.AvailabilityHelper
- toString() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
- toString() - Method in class org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
- toString() - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
- toString() - Method in class org.apache.flink.runtime.io.network.api.EndOfData
- toString() - Method in class org.apache.flink.runtime.io.network.api.EndOfPartitionEvent
- toString() - Method in class org.apache.flink.runtime.io.network.api.EndOfSegmentEvent
- toString() - Method in class org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
- toString() - Method in class org.apache.flink.runtime.io.network.api.EventAnnouncement
- toString() - Method in class org.apache.flink.runtime.io.network.api.RecoveryMetadata
- toString() - Method in class org.apache.flink.runtime.io.network.api.SubtaskConnectionDescriptor
- toString() - Method in class org.apache.flink.runtime.io.network.buffer.LocalBufferPool
- toString() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- toString() - Method in class org.apache.flink.runtime.io.network.ConnectionID
- toString() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
- toString() - Method in class org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionDirectTransferReader
- toString() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
- toString() - Method in class org.apache.flink.runtime.io.network.partition.consumer.ChannelStatePersister
- toString() - Method in class org.apache.flink.runtime.io.network.partition.consumer.EndOfChannelStateEvent
- toString() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel.BufferAndAvailability
- toString() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate.InputWithData
- toString() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGateID
- toString() - Method in class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
- toString() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- toString() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- toString() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGateFactory.ChannelStatistics
- toString() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
- toString() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageBytesBasedDataIdentifier
- toString() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageInputChannelId
- toString() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStoragePartitionId
- toString() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageSubpartitionId
- toString() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.common.TieredStorageTopicId
- toString() - Method in class org.apache.flink.runtime.io.network.partition.PartitionedFile
- toString() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedResultPartition
- toString() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartition
- toString() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartitionView
- toString() - Method in class org.apache.flink.runtime.io.network.partition.PrioritizedDeque
- toString() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
- toString() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionID
- toString() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
- toString() - Method in class org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
- toString() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
- toString() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
- toString() - Method in class org.apache.flink.runtime.jobgraph.JobResourceRequirements
- toString() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- toString() - Method in class org.apache.flink.runtime.jobgraph.JobVertexResourceRequirements.Parallelism
- toString() - Method in class org.apache.flink.runtime.jobgraph.JobVertexResourceRequirements
- toString() - Method in class org.apache.flink.runtime.jobgraph.OperatorInstanceID
- toString() - Method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
- toString() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
- toString() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
- toString() - Method in class org.apache.flink.runtime.jobgraph.topology.DefaultLogicalPipelinedRegion
- toString() - Method in class org.apache.flink.runtime.jobmanager.JobManagerProcessSpec
- toString() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
- toString() - Method in class org.apache.flink.runtime.jobmaster.AllocatedSlotInfo
- toString() - Method in class org.apache.flink.runtime.jobmaster.AllocatedSlotReport
- toString() - Method in class org.apache.flink.runtime.jobmaster.event.ExecutionJobVertexInitializedEvent
- toString() - Method in class org.apache.flink.runtime.jobmaster.event.ExecutionVertexFinishedEvent
- toString() - Method in class org.apache.flink.runtime.jobmaster.event.ExecutionVertexResetEvent
- toString() - Method in class org.apache.flink.runtime.jobmaster.JMTMRegistrationRejection
- toString() - Method in class org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess
- toString() - Method in class org.apache.flink.runtime.jobmaster.ResourceManagerAddress
- toString() - Method in enum org.apache.flink.runtime.jobmaster.slotpool.PreferredAllocationRequestSlotMatchingStrategy
- toString() - Method in enum org.apache.flink.runtime.jobmaster.slotpool.SimpleRequestSlotMatchingStrategy
- toString() - Method in class org.apache.flink.runtime.jobmaster.SlotRequestId
- toString() - Method in class org.apache.flink.runtime.leaderelection.LeaderInformation
- toString() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionDriver
- toString() - Method in class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalDriver
- toString() - Method in class org.apache.flink.runtime.memory.OpaqueMemoryResource
- toString() - Method in class org.apache.flink.runtime.messages.Acknowledge
- toString() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
- toString() - Method in class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
- toString() - Method in class org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint
- toString() - Method in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
- toString() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
- toString() - Method in class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview
- toString() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
- toString() - Method in class org.apache.flink.runtime.messages.webmonitor.JobStatusInfo
- toString() - Method in class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
- toString() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
- toString() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobsOverview
- toString() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobsWithIDsOverview
- toString() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestStatusOverview
- toString() - Method in class org.apache.flink.runtime.metrics.dump.MetricDump
- toString() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
- toString() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
- toString() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
- toString() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
- toString() - Method in class org.apache.flink.runtime.operators.util.BitSet
- toString() - Method in class org.apache.flink.runtime.operators.util.BloomFilter
- toString() - Method in class org.apache.flink.runtime.persistence.IntegerResourceVersion
- toString() - Method in class org.apache.flink.runtime.persistence.StringResourceVersion
- toString() - Method in class org.apache.flink.runtime.query.KvStateLocation
- toString() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
- toString() - Method in class org.apache.flink.runtime.registration.RegistrationResponse.Failure
- toString() - Method in class org.apache.flink.runtime.registration.RegistrationResponse.Rejection
- toString() - Method in class org.apache.flink.runtime.registration.RegistrationResponse.Success
- toString() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingTaskManager
- toString() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.ResourceDeclaration
- toString() - Method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec
- toString() - Method in class org.apache.flink.runtime.rest.handler.job.AsynchronousJobOperationKey
- toString() - Method in class org.apache.flink.runtime.rest.handler.router.MultipartRoutes
- toString() - Method in class org.apache.flink.runtime.rest.handler.router.Router
-
Returns visualized routing rules.
- toString() - Method in class org.apache.flink.runtime.rest.HttpHeader
- toString() - Method in class org.apache.flink.runtime.rest.messages.ConfigurationInfoEntry
- toString() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody.DistributedCacheFile
- toString() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody
- toString() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
- toString() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.Metric
- toString() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.ExceptionInfo
- toString() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.JobExceptionHistory
- toString() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory.RootExceptionInfo
- toString() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfoWithHistory
- toString() - Method in class org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson
- toString() - Method in class org.apache.flink.runtime.rest.messages.JobPlanInfo
- toString() - Method in enum org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureLevel
- toString() - Method in enum org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureStatus
- toString() - Method in class org.apache.flink.runtime.rest.messages.ProfilingInfo
- toString() - Method in class org.apache.flink.runtime.rest.messages.ThreadDumpInfo.ThreadInfo
- toString() - Method in class org.apache.flink.runtime.scheduler.adaptive.allocator.VertexParallelism
- toString() - Method in class org.apache.flink.runtime.scheduler.adaptive.JobSchedulingPlan.SlotAssignment
- toString() - Method in class org.apache.flink.runtime.scheduler.adaptive.JobSchedulingPlan
- toString() - Method in class org.apache.flink.runtime.scheduler.exceptionhistory.ExceptionHistoryEntry.ArchivedTaskManagerLocation
- toString() - Method in class org.apache.flink.runtime.scheduler.strategy.ExecutionVertexID
- toString() - Method in class org.apache.flink.runtime.shuffle.PartitionDescriptor
- toString() - Method in class org.apache.flink.runtime.slots.ResourceRequirement
- toString() - Method in class org.apache.flink.runtime.slots.ResourceRequirements
- toString() - Method in class org.apache.flink.runtime.source.event.AddSplitEvent
- toString() - Method in class org.apache.flink.runtime.source.event.IsProcessingBacklogEvent
- toString() - Method in class org.apache.flink.runtime.source.event.NoMoreSplitsEvent
- toString() - Method in class org.apache.flink.runtime.source.event.ReaderRegistrationEvent
- toString() - Method in class org.apache.flink.runtime.source.event.ReportedWatermarkEvent
- toString() - Method in class org.apache.flink.runtime.source.event.RequestSplitEvent
- toString() - Method in class org.apache.flink.runtime.source.event.SourceEventWrapper
- toString() - Method in class org.apache.flink.runtime.source.event.WatermarkAlignmentEvent
- toString() - Method in class org.apache.flink.runtime.state.AbstractChannelStateHandle
- toString() - Method in class org.apache.flink.runtime.state.AbstractIncrementalStateHandle
- toString() - Method in class org.apache.flink.runtime.state.BoundedInputStream
- toString() - Method in class org.apache.flink.runtime.state.changelog.ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl
- toString() - Method in class org.apache.flink.runtime.state.changelog.inmemory.InMemoryChangelogStateHandle
- toString() - Method in class org.apache.flink.runtime.state.changelog.SequenceNumber.GenericSequenceNumber
- toString() - Method in class org.apache.flink.runtime.state.changelog.SequenceNumberRange.GenericSequenceNumberRange
- toString() - Method in class org.apache.flink.runtime.state.changelog.StateChange
- toString() - Method in class org.apache.flink.runtime.state.ChangelogTaskLocalStateStore
- toString() - Method in class org.apache.flink.runtime.state.CheckpointStorageLocationReference
- toString() - Method in class org.apache.flink.runtime.state.DirectoryStateHandle
- toString() - Method in class org.apache.flink.runtime.state.filemerging.DirectoryStreamStateHandle
- toString() - Method in class org.apache.flink.runtime.state.filemerging.FileMergingOperatorStreamStateHandle
- toString() - Method in class org.apache.flink.runtime.state.filemerging.SegmentFileStateHandle
- toString() - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
- toString() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
- toString() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
- toString() - Method in class org.apache.flink.runtime.state.filesystem.FsMergingCheckpointStorageLocation
- toString() - Method in class org.apache.flink.runtime.state.filesystem.RelativeFileStateHandle
- toString() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap.StateMapEntry
- toString() - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
- toString() - Method in class org.apache.flink.runtime.state.HeapBroadcastState
- toString() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle.HandleAndLocalPath
- toString() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
- toString() - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
- toString() - Method in class org.apache.flink.runtime.state.KeyGroupRange
- toString() - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
- toString() - Method in class org.apache.flink.runtime.state.KeyGroupsSavepointStateHandle
- toString() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
- toString() - Method in class org.apache.flink.runtime.state.LocalRecoveryConfig
- toString() - Method in class org.apache.flink.runtime.state.LocalSnapshotDirectoryProviderImpl
- toString() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
- toString() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory
- toString() - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorageAccess
- toString() - Method in class org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
- toString() - Method in class org.apache.flink.runtime.state.OperatorStreamStateHandle
- toString() - Method in class org.apache.flink.runtime.state.PartitionableListState
- toString() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
- toString() - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
- toString() - Method in class org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
- toString() - Method in class org.apache.flink.runtime.state.SharedStateRegistryImpl.EmptyDiscardStateObjectForRegister
- toString() - Method in class org.apache.flink.runtime.state.SharedStateRegistryImpl
- toString() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
- toString() - Method in class org.apache.flink.runtime.state.SnapshotStrategyRunner
- toString() - Method in class org.apache.flink.runtime.state.StateObject.StateObjectSizeStatsCollector
- toString() - Method in class org.apache.flink.runtime.state.storage.JobManagerCheckpointStorage
- toString() - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
- toString() - Method in class org.apache.flink.runtime.state.v2.RegisteredKeyValueStateBackendMetaInfo
- toString() - Method in class org.apache.flink.runtime.state.v2.StateDescriptor
- toString() - Method in class org.apache.flink.runtime.state.VoidNamespace
- toString() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
- toString() - Method in class org.apache.flink.runtime.taskexecutor.ExecutionDeploymentReport
- toString() - Method in class org.apache.flink.runtime.taskexecutor.partition.ClusterPartitionReport
- toString() - Method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
- toString() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotAllocationSnapshot
- toString() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotOffer
- toString() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
- toString() - Method in class org.apache.flink.runtime.taskexecutor.SlotReport
- toString() - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
- toString() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorHeartbeatPayload
- toString() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorMemoryConfiguration
- toString() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationRejection
- toString() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
- toString() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorToJobManagerHeartbeatPayload
- toString() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
- toString() - Method in class org.apache.flink.runtime.taskmanager.Task
- toString() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
- toString() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
- toString() - Method in class org.apache.flink.runtime.util.OperatorSubtaskDescriptionText
- toString() - Method in class org.apache.flink.runtime.util.ResourceCounter
- toString() - Method in class org.apache.flink.runtime.webmonitor.history.ArchivedJson
- toString() - Method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexFlameGraph.Node
- toString() - Method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexFlameGraph
- toString() - Method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexThreadInfoStats
- toString() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
- toString() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableMessageTypeInfo
- toString() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableSummary
- toString() - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableWithLineage
- toString() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
- toString() - Method in class org.apache.flink.streaming.api.functions.sink.legacy.PrintSinkFunction
-
Deprecated.
- toString() - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
- toString() - Method in class org.apache.flink.streaming.api.graph.StreamConfig.SourceInputConfig
- toString() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
- toString() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
- toString() - Method in class org.apache.flink.streaming.api.graph.StreamNode
- toString() - Method in class org.apache.flink.streaming.api.operators.InputSelection
- toString() - Method in class org.apache.flink.streaming.api.operators.TimerHeapInternalTimer
- toString() - Method in class org.apache.flink.streaming.api.watermark.InternalWatermark
- toString() - Method in class org.apache.flink.streaming.api.watermark.Watermark
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
- toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
- toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
- toString() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow
- toString() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
- toString() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.CheckpointedInputGate
- toString() - Method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
- toString() - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
- toString() - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommittableCollector
- toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
- toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
- toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
- toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
- toString() - Method in class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
- toString() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
- toString() - Method in class org.apache.flink.streaming.runtime.streamrecord.RecordAttributes
- toString() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
- toString() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.Mail
- toString() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- toString() - Method in exception org.apache.flink.streaming.runtime.tasks.TimerException
- toString() - Method in class org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
- TOTAL_COMMITTABLES - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- touch() - Method in class org.apache.flink.runtime.rest.handler.router.RoutedRequest
- touch(Object) - Method in class org.apache.flink.runtime.rest.handler.router.RoutedRequest
- toUnaligned() - Method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
- toUUID() - Method in class org.apache.flink.runtime.dispatcher.DispatcherId
- toUUID() - Method in class org.apache.flink.runtime.jobmaster.JobMasterId
-
Creates a UUID with the bits from this JobMasterId.
- toUUID() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerId
-
Creates a UUID with the bits from this ResourceManagerId.
- traceInput(String, Buffer, String, InputChannelInfo, ChannelStatePersister, int) - Static method in class org.apache.flink.runtime.io.network.logger.NetworkActionsLogger
- traceOutput(String, Buffer, String, ResultSubpartitionInfo) - Static method in class org.apache.flink.runtime.io.network.logger.NetworkActionsLogger
- tracePersist(String, Buffer, Object, long) - Static method in class org.apache.flink.runtime.io.network.logger.NetworkActionsLogger
- traceRecover(String, BufferConsumer, String, ResultSubpartitionInfo) - Static method in class org.apache.flink.runtime.io.network.logger.NetworkActionsLogger
- traceRecover(String, Buffer, String, InputChannelInfo) - Static method in class org.apache.flink.runtime.io.network.logger.NetworkActionsLogger
- TraceReporterSetup - Class in org.apache.flink.runtime.metrics
-
Encapsulates everything needed for the instantiation and configuration of a
TraceReporter. - TraceReporterSetup(String, MetricConfig, TraceReporter, Map<String, String>) - Constructor for class org.apache.flink.runtime.metrics.TraceReporterSetup
- track(JobID, BlobKey, long) - Method in class org.apache.flink.runtime.blob.BlobCacheSizeTracker
-
Register the BLOB to the tracker.
- trackFutureWhileIncomplete(CompletableFuture<?>) - Method in class org.apache.flink.runtime.operators.coordination.util.IncompleteFuturesTracker
- transferBufferOwnership(Object, Object, Buffer) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemoryManager
-
Notify the memory manager that transferring one buffer's ownership from the old owner to the new owner.
- transferBufferOwnership(Object, Object, Buffer) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMemoryManagerImpl
- transferFile(ChannelHandlerContext, File, HttpRequest) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerUtils
- transform(String, TypeInformation<R>, OneInputStreamOperator<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Method for passing user defined operators along with the type information that will transform the DataStream.
- transform(String, TypeInformation<R>, OneInputStreamOperatorFactory<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Method for passing user defined operators created by the given factory along with the type information that will transform the DataStream.
- transform(String, TypeInformation<R>, TwoInputStreamOperator<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
- transform(String, TypeInformation<R>, TwoInputStreamOperatorFactory<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
- transform(K, N, T, StateTransformationFunction<S, T>) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
- transform(K, N, T, StateTransformationFunction<S, T>) - Method in class org.apache.flink.runtime.state.heap.StateMap
-
Applies the given
StateTransformationFunctionto the state (1st input argument), using the given value as second input argument. - transform(N, T, StateTransformationFunction<S, T>) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Applies the given
StateTransformationFunctionto the state (1st input argument), using the given value as second input argument. - transform(Transformation<?>) - Method in interface org.apache.flink.streaming.api.graph.TransformationTranslator.Context
-
Transforms the transformation and updates the current stream graph.
- TRANSFORM_ALL - org.apache.flink.runtime.state.StateSnapshotTransformer.CollectionStateSnapshotTransformer.TransformStrategy
-
Transform all entries.
- transformation - Variable in class org.apache.flink.streaming.api.datastream.DataStream
- transformations - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
- TransformationTranslator<OUT,T extends org.apache.flink.api.dag.Transformation<OUT>> - Interface in org.apache.flink.streaming.api.graph
-
A
TransformationTranslatoris responsible for translating a givenTransformationto its runtime implementation depending on the execution mode. - TransformationTranslator.Context - Interface in org.apache.flink.streaming.api.graph
-
A context giving the necessary information for the translation of a given transformation.
- TransformationWithLineage<T> - Class in org.apache.flink.streaming.api.transformations
-
A
Transformationthat contains lineage information. - transformFromV2ToV1(StateDescriptor) - Static method in class org.apache.flink.runtime.state.v2.StateDescriptorUtils
- TransientBlobCache - Class in org.apache.flink.runtime.blob
-
Provides access to transient BLOB files stored at the
BlobServer. - TransientBlobCache(Configuration, File, InetSocketAddress) - Constructor for class org.apache.flink.runtime.blob.TransientBlobCache
- TransientBlobCache(Configuration, Reference<File>, InetSocketAddress) - Constructor for class org.apache.flink.runtime.blob.TransientBlobCache
-
Instantiates a new BLOB cache.
- TransientBlobKey - Class in org.apache.flink.runtime.blob
-
BLOB key referencing transient BLOB files.
- TransientBlobKey() - Constructor for class org.apache.flink.runtime.blob.TransientBlobKey
-
Constructs a new BLOB key.
- TransientBlobService - Interface in org.apache.flink.runtime.blob
-
A service to retrieve transient binary large objects (BLOBs) which are deleted on the
BlobServerwhen they are retrieved. - transitionExecutionGraphState(JobStatus, JobStatus) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- transitionState(JobStatus, JobStatus) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- transitionState(JobStatus, JobStatus) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- transitionState(ExecutionState) - Method in class org.apache.flink.runtime.executiongraph.Execution
- transitionToRunning() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- transitionToRunning() - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- transitionToRunning() - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- transitionToScheduled(List<ExecutionVertexID>) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- transitionToSubsequentState() - Method in interface org.apache.flink.runtime.scheduler.adaptive.StateTransitionManager.Context
-
Triggers the transition to the subsequent state of the
AdaptiveScheduler. - translateForBatch(SinkTransformation<Input, Output>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.SinkTransformationTranslator
- translateForBatch(T, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.api.graph.SimpleTransformationTranslator
- translateForBatch(T, TransformationTranslator.Context) - Method in interface org.apache.flink.streaming.api.graph.TransformationTranslator
-
Translates a given
Transformationto its runtime implementation for BATCH-style execution. - translateForBatchInternal(AbstractMultipleInputTransformation<OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.MultiInputTransformationTranslator
- translateForBatchInternal(BroadcastStateTransformation<IN1, IN2, OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.BroadcastStateTransformationTranslator
- translateForBatchInternal(KeyedBroadcastStateTransformation<KEY, IN1, IN2, OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.KeyedBroadcastStateTransformationTranslator
- translateForBatchInternal(LegacySinkTransformation<IN>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.LegacySinkTransformationTranslator
- translateForBatchInternal(LegacySourceTransformation<OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.LegacySourceTransformationTranslator
- translateForBatchInternal(OneInputTransformation<IN, OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.OneInputTransformationTranslator
- translateForBatchInternal(PartitionTransformation<OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.PartitionTransformationTranslator
- translateForBatchInternal(ReduceTransformation<IN, KEY>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.ReduceTransformationTranslator
- translateForBatchInternal(SideOutputTransformation<OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.SideOutputTransformationTranslator
- translateForBatchInternal(SourceTransformation<OUT, SplitT, EnumChkT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.SourceTransformationTranslator
- translateForBatchInternal(TimestampsAndWatermarksTransformation<IN>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.TimestampsAndWatermarksTransformationTranslator
- translateForBatchInternal(TwoInputTransformation<IN1, IN2, OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.TwoInputTransformationTranslator
- translateForBatchInternal(UnionTransformation<OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.UnionTransformationTranslator
- translateForBatchInternal(T, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.api.graph.SimpleTransformationTranslator
-
Translates a given
Transformationto its runtime implementation for BATCH-style execution. - translateForBatchInternal(T, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator
- translateForStreaming(SinkTransformation<Input, Output>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.SinkTransformationTranslator
- translateForStreaming(T, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.api.graph.SimpleTransformationTranslator
- translateForStreaming(T, TransformationTranslator.Context) - Method in interface org.apache.flink.streaming.api.graph.TransformationTranslator
-
Translates a given
Transformationto its runtime implementation for STREAMING-style execution. - translateForStreamingInternal(AbstractMultipleInputTransformation<OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.MultiInputTransformationTranslator
- translateForStreamingInternal(BroadcastStateTransformation<IN1, IN2, OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.BroadcastStateTransformationTranslator
- translateForStreamingInternal(KeyedBroadcastStateTransformation<KEY, IN1, IN2, OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.KeyedBroadcastStateTransformationTranslator
- translateForStreamingInternal(LegacySinkTransformation<IN>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.LegacySinkTransformationTranslator
- translateForStreamingInternal(LegacySourceTransformation<OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.LegacySourceTransformationTranslator
- translateForStreamingInternal(OneInputTransformation<IN, OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.OneInputTransformationTranslator
- translateForStreamingInternal(PartitionTransformation<OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.PartitionTransformationTranslator
- translateForStreamingInternal(ReduceTransformation<IN, KEY>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.ReduceTransformationTranslator
- translateForStreamingInternal(SideOutputTransformation<OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.SideOutputTransformationTranslator
- translateForStreamingInternal(SourceTransformation<OUT, SplitT, EnumChkT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.SourceTransformationTranslator
- translateForStreamingInternal(TimestampsAndWatermarksTransformation<IN>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.TimestampsAndWatermarksTransformationTranslator
- translateForStreamingInternal(TwoInputTransformation<IN1, IN2, OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.TwoInputTransformationTranslator
- translateForStreamingInternal(UnionTransformation<OUT>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.UnionTransformationTranslator
- translateForStreamingInternal(T, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.api.graph.SimpleTransformationTranslator
-
Translates a given
Transformationto its runtime implementation for STREAMING-style execution. - translateForStreamingInternal(T, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.CacheTransformationTranslator
- translateInternal(Transformation<OUT>, Transformation<IN1>, Transformation<IN2>, StreamOperatorFactory<OUT>, TypeInformation<?>, KeySelector<IN1, ?>, KeySelector<IN2, ?>, TransformationTranslator.Context) - Method in class org.apache.flink.streaming.runtime.translators.AbstractTwoInputTransformationTranslator
- TransportException - Exception in org.apache.flink.runtime.io.network.netty.exception
- TransportException(String, SocketAddress) - Constructor for exception org.apache.flink.runtime.io.network.netty.exception.TransportException
- TransportException(String, SocketAddress, Throwable) - Constructor for exception org.apache.flink.runtime.io.network.netty.exception.TransportException
- traverseStreamGraphAndGenerateHashes(StreamGraph) - Method in interface org.apache.flink.streaming.api.graph.StreamGraphHasher
-
Returns a map with a hash for each
StreamNodeof theStreamGraph. - traverseStreamGraphAndGenerateHashes(StreamGraph) - Method in class org.apache.flink.streaming.api.graph.StreamGraphHasherV2
-
Returns a map with a hash for each
StreamNodeof theStreamGraph. - traverseStreamGraphAndGenerateHashes(StreamGraph) - Method in class org.apache.flink.streaming.api.graph.StreamGraphUserHashHasher
- trigger - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorFactory
- trigger(Trigger<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
-
Sets the
Triggerthat should be used to trigger window emission. - trigger(Trigger<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
-
Sets the
Triggerthat should be used to trigger window emission. - trigger(Trigger<? super T, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
-
Sets the
Triggerthat should be used to trigger window emission. - trigger(Trigger<? super T, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
-
Sets the
Triggerthat should be used to trigger window emission. - trigger(Trigger<? super T, ? super W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
- Trigger<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
-
A
Triggerdetermines when a pane of a window should be evaluated to emit the results for that part of the window. - Trigger() - Constructor for class org.apache.flink.streaming.api.windowing.triggers.Trigger
- TRIGGER_CHECKPOINT_FAILURE - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- TRIGGER_THREAD_GROUP - Static variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
-
The thread group that holds all trigger timer threads.
- Trigger.OnMergeContext - Interface in org.apache.flink.streaming.api.windowing.triggers
-
Extension of
Trigger.TriggerContextthat is given toTrigger.onMerge(Window, OnMergeContext). - Trigger.TriggerContext - Interface in org.apache.flink.streaming.api.windowing.triggers
-
A context object that is given to
Triggermethods to allow them to register timer callbacks and deal with state. - Triggerable<K,N> - Interface in org.apache.flink.streaming.api.operators
-
Interface for things that can be called by
InternalTimerService. - triggerCheckpoint(boolean) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Triggers a new standard checkpoint and uses the given timestamp as the checkpoint timestamp.
- triggerCheckpoint(long) - Method in interface org.apache.flink.streaming.api.checkpoint.ExternallyInducedSource.CheckpointTrigger
-
Deprecated.Triggers a checkpoint.
- triggerCheckpoint(long, long, Executor) - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
-
This method is called by the checkpoint coordinator prior when triggering a checkpoint, prior to sending the "trigger checkpoint" messages to the source tasks.
- triggerCheckpoint(long, long, CheckpointOptions) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Trigger a new checkpoint on the task of this execution.
- triggerCheckpoint(Duration) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Triggers taking a checkpoint of the executed job.
- triggerCheckpoint(JobID) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- triggerCheckpoint(JobID, Duration) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- triggerCheckpoint(JobID, Duration) - Method in interface org.apache.flink.runtime.dispatcher.DispatcherGateway
- triggerCheckpoint(JobID, CheckpointType) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- triggerCheckpoint(CheckpointType) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Triggers one new checkpoint with the given checkpointType.
- triggerCheckpoint(CheckpointType) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- triggerCheckpoint(CheckpointType) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- triggerCheckpoint(CheckpointType) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
- triggerCheckpoint(CheckpointType, Duration) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- triggerCheckpoint(CheckpointType, Duration) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Triggers taking a checkpoint of the executed job.
- triggerCheckpoint(ExecutionAttemptID, long, long, CheckpointOptions) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- triggerCheckpoint(ExecutionAttemptID, long, long, CheckpointOptions) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Trigger the checkpoint for the given task.
- triggerCheckpoint(ExecutionAttemptID, long, long, CheckpointOptions) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- triggerCheckpoint(ExecutionAttemptID, JobID, long, long, CheckpointOptions) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Trigger for the given task a checkpoint.
- triggerCheckpoint(ExecutionAttemptID, JobID, long, long, CheckpointOptions) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
- triggerCheckpoint(AsynchronousJobOperationKey, CheckpointType, Duration) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- triggerCheckpoint(AsynchronousJobOperationKey, CheckpointType, Duration) - Method in class org.apache.flink.runtime.dispatcher.DispatcherCachedOperationsHandler
- triggerCheckpoint(AsynchronousJobOperationKey, CheckpointType, Duration) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Triggers a checkpoint with the given savepoint directory as a target.
- triggerCheckpointAndGetCheckpointID(JobID, CheckpointType, Duration) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- triggerCheckpointAndGetCheckpointID(JobID, CheckpointType, Duration) - Method in interface org.apache.flink.runtime.dispatcher.DispatcherGateway
-
Triggers a checkpoint, returning a future that completes with the checkpoint id when it is complete.
- triggerCheckpointAsync(CheckpointMetaData, CheckpointOptions) - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
- triggerCheckpointAsync(CheckpointMetaData, CheckpointOptions) - Method in interface org.apache.flink.runtime.jobgraph.tasks.CheckpointableTask
-
This method is called to trigger a checkpoint, asynchronously by the checkpoint coordinator.
- triggerCheckpointAsync(CheckpointMetaData, CheckpointOptions) - Method in class org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
- triggerCheckpointAsync(CheckpointMetaData, CheckpointOptions) - Method in class org.apache.flink.streaming.runtime.tasks.SourceOperatorStreamTask
- triggerCheckpointAsync(CheckpointMetaData, CheckpointOptions) - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
-
Deprecated.
- triggerCheckpointAsync(CheckpointMetaData, CheckpointOptions) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- triggerCheckpointBarrier(long, long, CheckpointOptions) - Method in class org.apache.flink.runtime.taskmanager.Task
-
Calls the invokable to trigger a checkpoint.
- TriggerCheckpointFunction - Interface in org.apache.flink.runtime.dispatcher
-
Wrapper interface for functions triggering checkpoints.
- triggerCheckpointOnBarrier(CheckpointMetaData, CheckpointOptions, CheckpointMetricsBuilder) - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
- triggerCheckpointOnBarrier(CheckpointMetaData, CheckpointOptions, CheckpointMetricsBuilder) - Method in interface org.apache.flink.runtime.jobgraph.tasks.CheckpointableTask
-
This method is called when a checkpoint is triggered as a result of receiving checkpoint barriers on all input streams.
- triggerCheckpointOnBarrier(CheckpointMetaData, CheckpointOptions, CheckpointMetricsBuilder) - Method in class org.apache.flink.streaming.runtime.tasks.MultipleInputStreamTask
- triggerCheckpointOnBarrier(CheckpointMetaData, CheckpointOptions, CheckpointMetricsBuilder) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
- triggerContext - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
- triggerDebloating() - Method in class org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate
- triggerDebloating() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- triggerDebloating() - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
- triggerDetachedSavepoint(JobID, String, boolean, SavepointFormatType) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- TriggerHandler(GatewayRetriever<? extends T>, Duration, Map<String, String>, MessageHeaders<B, TriggerResponse, M>) - Constructor for class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.TriggerHandler
- triggerHook(MasterTriggerRestoreHook<T>, long, long, Executor) - Static method in class org.apache.flink.runtime.checkpoint.hooks.MasterHooks
-
Trigger master hook and return a completable future with state.
- TriggerId - Class in org.apache.flink.runtime.rest.messages
-
Identifies a savepoint trigger request.
- TriggerId() - Constructor for class org.apache.flink.runtime.rest.messages.TriggerId
- TriggerId.TriggerIdDeserializer - Class in org.apache.flink.runtime.rest.messages
-
JSON deserializer for
TriggerId. - TriggerId.TriggerIdSerializer - Class in org.apache.flink.runtime.rest.messages
-
JSON serializer for
TriggerId. - TriggerIdDeserializer() - Constructor for class org.apache.flink.runtime.rest.messages.TriggerId.TriggerIdDeserializer
- triggerIdPathParameter - Variable in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusMessageParameters
- triggerIdPathParameter - Variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatusMessageParameters
- triggerIdPathParameter - Variable in class org.apache.flink.runtime.rest.messages.dataset.ClusterDataSetDeleteStatusMessageParameters
- triggerIdPathParameter - Variable in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusMessageParameters
- triggerIdPathParameter - Variable in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusMessageParameters
- TriggerIdPathParameter - Class in org.apache.flink.runtime.rest.messages
-
MessagePathParameterfor the trigger id of an asynchronous operation. - TriggerIdPathParameter() - Constructor for class org.apache.flink.runtime.rest.messages.TriggerIdPathParameter
- TriggerIdSerializer() - Constructor for class org.apache.flink.runtime.rest.messages.TriggerId.TriggerIdSerializer
- triggerIfNeeded(boolean) - Method in class org.apache.flink.runtime.asyncprocessing.AsyncExecutionController
-
Trigger a batch of requests.
- triggerNextSuperstep() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
- triggerOperation(HandlerRequest<B>, T) - Method in class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.TriggerHandler
-
Trigger the asynchronous operation and return its future result.
- triggerOperation(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.dataset.ClusterDataSetDeleteHandlers.ClusterDataSetDeleteTriggerHandler
- triggerOperation(HandlerRequest<EmptyRequestBody>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingTriggerHandler
- triggerOperation(HandlerRequest<SavepointDisposalRequest>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalTriggerHandler
- triggerOperation(HandlerRequest<SavepointTriggerRequestBody>, AsynchronousJobOperationKey, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointTriggerHandler
- triggerOperation(HandlerRequest<StopWithSavepointRequestBody>, AsynchronousJobOperationKey, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.StopWithSavepointHandler
- triggerResourceRequirementsCheck() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedSlotManager
- triggerResourceRequirementsCheck() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Trigger the resource requirement check.
- TriggerResponse - Class in org.apache.flink.runtime.rest.handler.async
-
Response to the triggering of an asynchronous operation.
- TriggerResponse(TriggerId) - Constructor for class org.apache.flink.runtime.rest.handler.async.TriggerResponse
- TriggerResult - Enum in org.apache.flink.streaming.api.windowing.triggers
-
Result type for trigger methods.
- triggerSavepoint(String, boolean, SavepointFormatType) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- triggerSavepoint(String, boolean, SavepointFormatType) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- triggerSavepoint(String, boolean, SavepointFormatType) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
- triggerSavepoint(String, boolean, SavepointFormatType, Duration) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- triggerSavepoint(String, boolean, SavepointFormatType, Duration) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Triggers taking a savepoint of the executed job.
- triggerSavepoint(String, SavepointFormatType) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Triggers a savepoint with the given savepoint directory as a target.
- triggerSavepoint(String, SavepointFormatType) - Method in class org.apache.flink.runtime.minicluster.MiniClusterJobClient
- triggerSavepoint(JobID, String, boolean, SavepointFormatType) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- triggerSavepoint(AsynchronousJobOperationKey, String, SavepointFormatType, TriggerSavepointMode, Duration) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- triggerSavepoint(AsynchronousJobOperationKey, String, SavepointFormatType, TriggerSavepointMode, Duration) - Method in class org.apache.flink.runtime.dispatcher.DispatcherCachedOperationsHandler
- triggerSavepoint(AsynchronousJobOperationKey, String, SavepointFormatType, TriggerSavepointMode, Duration) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Triggers a savepoint with the given savepoint directory as a target, returning a future that completes when the operation is started.
- triggerSavepointAndGetLocation(JobID, String, SavepointFormatType, TriggerSavepointMode, Duration) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- triggerSavepointAndGetLocation(JobID, String, SavepointFormatType, TriggerSavepointMode, Duration) - Method in interface org.apache.flink.runtime.dispatcher.DispatcherGateway
-
Triggers a savepoint with the given savepoint directory as a target, returning a future that completes with the savepoint location when it is complete.
- TriggerSavepointFunction - Interface in org.apache.flink.runtime.dispatcher
-
Wrapper interface for functions triggering savepoints.
- TriggerSavepointMode - Enum in org.apache.flink.runtime.dispatcher
-
Describes the context of taking a savepoint: Whether it is a savepoint for a running job or whether the job is cancelled, suspended or terminated with a savepoint.
- triggerSerializationAndReturnFuture(Executor) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
-
Trigger the object config serialization and return the completable future.
- triggerSynchronousSavepoint(boolean, String, SavepointFormatType) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Triggers a synchronous savepoint with the given savepoint directory as a target.
- triggerSynchronousSavepoint(long, long, CheckpointOptions) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Trigger a new checkpoint on the task of this execution.
- triggerTarget - Variable in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
- triggerThreadInfoRequest(Map<ImmutableSet<ExecutionAttemptID>, CompletableFuture<TaskExecutorThreadInfoGateway>>, int, Duration, int) - Method in class org.apache.flink.runtime.webmonitor.threadinfo.ThreadInfoRequestCoordinator
-
Triggers collection of thread info stats of a job vertex by combining thread info responses from given subtasks.
- trim(int) - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
The result capacity can not be greater than allocated memorySegment.
- trimStartingSlash(String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
- truncate(SequenceNumber) - Method in interface org.apache.flink.runtime.state.changelog.StateChangelogWriter
-
Truncate this state changelog to free up the resources and collect any garbage.
- truncateAndClose(SequenceNumber) - Method in interface org.apache.flink.runtime.state.changelog.StateChangelogWriter
-
Truncate the tail of log and close it.
- tryAdd(AbstractCheckpointStats) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointStatsCache
-
Try to add the checkpoint to the cache.
- tryAdvanceWatermark(long, InternalTimeServiceManager.ShouldStopAdvancingFn) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceImpl
- tryAdvanceWatermark(Watermark, InternalTimeServiceManager.ShouldStopAdvancingFn) - Method in interface org.apache.flink.streaming.api.operators.InternalTimeServiceManager
-
Try to
InternalTimeServiceManager.advanceWatermark(Watermark), but ifInternalTimeServiceManager.ShouldStopAdvancingFnreturnstrue, stop the advancement and return as soon as possible. - tryAdvanceWatermark(Watermark, InternalTimeServiceManager.ShouldStopAdvancingFn) - Method in class org.apache.flink.streaming.api.operators.InternalTimeServiceManagerImpl
- tryAdvanceWatermark(Watermark, InternalTimeServiceManager.ShouldStopAdvancingFn) - Method in class org.apache.flink.streaming.api.operators.sorted.state.BatchExecutionInternalTimeServiceManager
- tryAssignPayload(LogicalSlot.Payload) - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Tries to assign a payload to this slot.
- tryAssignPayload(LogicalSlot.Payload) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
- tryAssignPayload(PhysicalSlot.Payload) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlot
-
Tries to assign the given payload to this allocated slot.
- tryAssignResource(LogicalSlot) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Tries to assign the given slot to the execution.
- tryAssignResource(LogicalSlot) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
- tryAssignResource(LogicalSlot) - Method in class org.apache.flink.runtime.executiongraph.SpeculativeExecutionVertex
- tryCancel(boolean) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.Mail
- tryEnrichClusterEntryPointError(Throwable) - Static method in class org.apache.flink.runtime.entrypoint.ClusterEntryPointExceptionUtils
-
Tries to enrich the passed exception or its causes with additional information.
- tryFindUserLibDirectory() - Static method in class org.apache.flink.runtime.entrypoint.ClusterEntrypointUtils
-
Tries to find the user library directory.
- tryFulfillRequirements(Map<JobID, Collection<ResourceRequirement>>, TaskManagerResourceInfoProvider, BlockedTaskManagerChecker) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.DefaultResourceAllocationStrategy
- tryFulfillRequirements(Map<JobID, Collection<ResourceRequirement>>, TaskManagerResourceInfoProvider, BlockedTaskManagerChecker) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ResourceAllocationStrategy
-
Try to make an allocation decision to fulfill the resource requirements.
- tryGet(long) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointStatsCache
-
Try to look up a checkpoint by it's ID in the cache.
- tryLoadAndDeserializeShuffleDescriptors(PermanentBlobService, JobID, GroupCache<JobID, PermanentBlobKey, TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup>) - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
- tryLoadWebContent(GatewayRetriever<? extends T>, Duration, File) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
-
Checks whether the flink-runtime-web dependency is available and if so returns a StaticFileServerHandler which can serve the static file contents.
- tryMarkSlotActive(JobID, AllocationID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Try to mark the specified slot as active if it has been allocated by the given job.
- tryMarkSlotActive(JobID, AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl
- tryOffload(SerializedValue<T>, JobID, BlobWriter) - Static method in interface org.apache.flink.runtime.blob.BlobWriter
- tryPutFile(FileMergingSnapshotManager.SubtaskKey, PhysicalFile) - Method in class org.apache.flink.runtime.checkpoint.filemerging.BlockingPhysicalFilePool
- tryPutFile(FileMergingSnapshotManager.SubtaskKey, PhysicalFile) - Method in class org.apache.flink.runtime.checkpoint.filemerging.NonBlockingPhysicalFilePool
- tryPutFile(FileMergingSnapshotManager.SubtaskKey, PhysicalFile) - Method in class org.apache.flink.runtime.checkpoint.filemerging.PhysicalFilePool
-
Try to put a physical file into file pool.
- tryReconcileClusterResources(TaskManagerResourceInfoProvider) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.DefaultResourceAllocationStrategy
- tryReconcileClusterResources(TaskManagerResourceInfoProvider) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ResourceAllocationStrategy
-
Try to make a decision to reconcile the cluster resources.
- tryReconnect() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
Tries to reconnect to the
RegisteredRpcConnection.targetAddressby cancelling the pending registration and starting a new pending registration. - tryReserveResources(JobSchedulingPlan) - Method in interface org.apache.flink.runtime.scheduler.adaptive.allocator.SlotAllocator
-
Reserves slots according to the given assignment if possible.
- tryReserveResources(JobSchedulingPlan) - Method in class org.apache.flink.runtime.scheduler.adaptive.allocator.SlotSharingSlotAllocator
- tryRetain() - Method in class org.apache.flink.runtime.asyncprocessing.ReferenceCounted
-
Try to retain this object.
- trySetCount(ZooKeeperVersionedValue<Integer>, int) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
- tryShutdownExecutorElegantly(ExecutorService, Duration) - Static method in class org.apache.flink.runtime.operators.coordination.ComponentClosingUtils
-
A util method that tries to shut down an
ExecutorServiceelegantly within the given timeout. - tryStartNewSegment(TieredStorageSubpartitionId, int, int) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskTierProducerAgent
- tryStartNewSegment(TieredStorageSubpartitionId, int, int) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory.MemoryTierProducerAgent
- tryStartNewSegment(TieredStorageSubpartitionId, int, int) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierProducerAgent
- tryStartNewSegment(TieredStorageSubpartitionId, int, int) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierProducerAgent
-
Try to start a new segment in the Tier.
- tryTake(int) - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
Returns an optional with either the oldest mail from the mailbox (head of queue) if the mailbox is not empty or an empty optional otherwise.
- tryTake(int) - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
- tryTakeFromBatch() - Method in interface org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox
-
Returns an optional with either the oldest mail from the batch (head of queue) if the batch is not empty or an empty optional otherwise.
- tryTakeFromBatch() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailboxImpl
- tryToAssignSlots(CreatingExecutionGraph.ExecutionGraphWithVertexParallelism) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- tryWrite(TieredStorageSubpartitionId, Buffer, Object, int) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskTierProducerAgent
- tryWrite(TieredStorageSubpartitionId, Buffer, Object, int) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory.MemoryTierProducerAgent
- tryWrite(TieredStorageSubpartitionId, Buffer, Object, int) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierProducerAgent
- tryWrite(TieredStorageSubpartitionId, Buffer, Object, int) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierProducerAgent
-
Writes the finished
Bufferto the consumer. - tryYield() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
- TtlSerializer(CompositeSerializer.PrecomputedParameters, TypeSerializer<?>...) - Constructor for class org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
- TtlSerializer(TypeSerializer<Long>, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
- TtlSerializerSnapshot() - Constructor for class org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializerSnapshot
- TtlStateFactory<K,N,SV,TTLSV,S extends org.apache.flink.api.common.state.State,IS extends S> - Class in org.apache.flink.runtime.state.ttl
-
This state factory wraps state objects, produced by backends, with TTL logic.
- TtlStateFactory.TtlSerializer<T> - Class in org.apache.flink.runtime.state.ttl
-
Serializer for user state value with TTL.
- TtlStateFactory.TtlSerializerSnapshot<T> - Class in org.apache.flink.runtime.state.ttl
-
A
TypeSerializerSnapshotfor TtlSerializer. - ttlTimeProvider - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- ttlTimeProvider - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
- TtlTimeProvider - Interface in org.apache.flink.runtime.state.ttl
-
Provides time to TTL logic to judge about state expiration.
- TtlUtils - Class in org.apache.flink.runtime.state.ttl
-
Common functions related to State TTL.
- TtlUtils() - Constructor for class org.apache.flink.runtime.state.ttl.TtlUtils
- TtlValue<T> - Class in org.apache.flink.runtime.state.ttl
-
This class wraps user value of state with TTL.
- TtlValue(T, long) - Constructor for class org.apache.flink.runtime.state.ttl.TtlValue
- TumblingEventTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssignerthat windows elements into windows based on the timestamp of the elements. - TumblingEventTimeWindows(long, long, WindowStagger) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
- TumblingProcessingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssignerthat windows elements into windows based on the current system time of the machine the operation is running on. - two(T2) - Static method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
- TwoInputStreamOperator<IN1,IN2,OUT> - Interface in org.apache.flink.streaming.api.operators
-
Interface for stream operators with two inputs.
- TwoInputStreamOperatorFactory<IN1,IN2,OUT> - Interface in org.apache.flink.streaming.api.operators
-
A factory to create
TwoInputStreamOperator. - TwoInputStreamTask<IN1,IN2,OUT> - Class in org.apache.flink.streaming.runtime.tasks
-
A
StreamTaskfor executing aTwoInputStreamOperatorand supporting theTwoInputStreamOperatorto select input for reading. - TwoInputStreamTask(Environment) - Constructor for class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
- TwoInputTransformation<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.transformations
-
This Transformation represents the application of a
TwoInputStreamOperatorto two inputTransformations. - TwoInputTransformation(Transformation<IN1>, Transformation<IN2>, String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.TwoInputTransformation
- TwoInputTransformation(Transformation<IN1>, Transformation<IN2>, String, StreamOperatorFactory<OUT>, TypeInformation<OUT>, int, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Creates a new
TwoInputTransformationfrom the given inputs and operator. - TwoInputTransformation(Transformation<IN1>, Transformation<IN2>, String, TwoInputStreamOperator<IN1, IN2, OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.TwoInputTransformation
-
Creates a new
TwoInputTransformationfrom the given inputs and operator. - TwoInputTransformation(Transformation<IN1>, Transformation<IN2>, String, TwoInputStreamOperator<IN1, IN2, OUT>, TypeInformation<OUT>, int, boolean) - Constructor for class org.apache.flink.streaming.api.transformations.TwoInputTransformation
- TwoInputTransformationTranslator<IN1,IN2,OUT> - Class in org.apache.flink.streaming.runtime.translators
-
A
TransformationTranslatorfor theTwoInputTransformation. - TwoInputTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.TwoInputTransformationTranslator
- TYPE - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
U
- UdfStreamOperatorFactory<OUT> - Interface in org.apache.flink.streaming.api.operators
-
Udf stream operator factory.
- uid(String) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
-
Sets an ID for this operator.
- uid(String) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
-
Sets an ID for this operator.
- unaligned(String, CheckpointableTask, SubtaskCheckpointCoordinator, Clock, int, BarrierAlignmentUtil.DelayableTimer, boolean, CheckpointableInput...) - Static method in class org.apache.flink.streaming.runtime.io.checkpointing.SingleCheckpointBarrierHandler
- unaligned(SnapshotType, CheckpointStorageLocationReference) - Static method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
- UNALIGNED - org.apache.flink.runtime.checkpoint.CheckpointOptions.AlignmentType
- UNARY_NO_OP - org.apache.flink.runtime.operators.DriverStrategy
- UNASSIGNED_SPLITS - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- UnavailableDispatcherOperationException - Exception in org.apache.flink.runtime.dispatcher
-
Exception indicating that a Dispatcher operation is temporarily unavailable.
- UnavailableDispatcherOperationException(String) - Constructor for exception org.apache.flink.runtime.dispatcher.UnavailableDispatcherOperationException
- unblockResources(Collection<BlockedNode>) - Method in interface org.apache.flink.runtime.blocklist.BlocklistContext
-
Unblock resources on the nodes.
- UNBOUNDED_POOL_SIZE - Static variable in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
- uncaughtException(Thread, Throwable) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
- uncaughtException(Thread, Throwable) - Method in class org.apache.flink.runtime.source.coordinator.SourceCoordinatorProvider.CoordinatorExecutorThreadFactory
- uncaughtException(Thread, Throwable) - Method in class org.apache.flink.runtime.util.ClusterUncaughtExceptionHandler
- UncheckpointedCollectResultBuffer<T> - Class in org.apache.flink.streaming.api.operators.collect
-
A buffer which encapsulates the logic of dealing with the response from the
CollectSinkFunction. - UncheckpointedCollectResultBuffer(TypeSerializer<T>, boolean) - Constructor for class org.apache.flink.streaming.api.operators.collect.UncheckpointedCollectResultBuffer
- UncompressedStreamCompressionDecorator - Class in org.apache.flink.runtime.state
-
This implementation does not decorate the stream with any compression.
- UncompressedStreamCompressionDecorator() - Constructor for class org.apache.flink.runtime.state.UncompressedStreamCompressionDecorator
- UNCONSTRAINED - org.apache.flink.runtime.jobmanager.scheduler.Locality
-
No constraint existed on the task placement.
- UNDEFINED - org.apache.flink.streaming.api.transformations.StreamExchangeMode
-
The exchange mode is undefined.
- UNDEFINED - Static variable in class org.apache.flink.runtime.metrics.groups.InternalSourceReaderMetricGroup
- unexpectedStateHandleException(Class<? extends StateObject>[], Class<? extends StateObject>) - Static method in class org.apache.flink.runtime.state.StateUtil
-
Creates a
RuntimeExceptionthat signals that an operation did not get the type ofStateObjectthat was expected. - unexpectedStateHandleException(Class<? extends StateObject>, Class<? extends StateObject>) - Static method in class org.apache.flink.runtime.state.StateUtil
-
Creates an
RuntimeExceptionthat signals that an operation did not get the type ofStateObjectthat was expected. - UnfulfillableSlotRequestException - Exception in org.apache.flink.runtime.resourcemanager.exceptions
-
Exception denoting that a slot request can not be fulfilled by any slot in the cluster.
- UnfulfillableSlotRequestException(AllocationID, ResourceProfile) - Constructor for exception org.apache.flink.runtime.resourcemanager.exceptions.UnfulfillableSlotRequestException
- UNINITIALIZED - Static variable in class org.apache.flink.runtime.metrics.groups.InternalCacheMetricGroup
- UNINITIALIZED - Static variable in class org.apache.flink.streaming.api.watermark.Watermark
-
The watermark that signifies is used before any actual watermark has been generated.
- uninstall() - Method in class org.apache.flink.runtime.security.modules.HadoopModule
- uninstall() - Method in class org.apache.flink.runtime.security.modules.JaasModule
- uninstall() - Method in interface org.apache.flink.runtime.security.modules.SecurityModule
-
Uninstall the security module.
- uninstall() - Method in class org.apache.flink.runtime.security.modules.ZooKeeperModule
- union(DataStream<T>...) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Creates a new
DataStreamby mergingDataStreamoutputs of the same type with each other. - UNION - org.apache.flink.runtime.operators.DriverStrategy
- UNION - org.apache.flink.runtime.state.OperatorStateHandle.Mode
- UNION_WITH_CACHED - org.apache.flink.runtime.operators.DriverStrategy
- UnionInputGate - Class in org.apache.flink.runtime.io.network.partition.consumer
-
Input gate wrapper to union the input from multiple input gates.
- UnionInputGate(IndexedInputGate...) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
- UnionResultSubpartitionView - Class in org.apache.flink.runtime.io.network.partition
-
A wrapper to union the output from multiple
ResultSubpartitionViews. - UnionResultSubpartitionView(BufferAvailabilityListener, int) - Constructor for class org.apache.flink.runtime.io.network.partition.UnionResultSubpartitionView
- UnionSerializer(TypeSerializer<T1>, TypeSerializer<T2>) - Constructor for class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializer
- UnionSerializerSnapshot() - Constructor for class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerSnapshot
- UnionTransformation<T> - Class in org.apache.flink.streaming.api.transformations
-
This transformation represents a union of several input
Transformations. - UnionTransformation(List<Transformation<T>>) - Constructor for class org.apache.flink.streaming.api.transformations.UnionTransformation
-
Creates a new
UnionTransformationfrom the given inputTransformations. - UnionTransformationTranslator<OUT> - Class in org.apache.flink.streaming.runtime.translators
-
A
TransformationTranslatorfor theUnionTransformation. - UnionTransformationTranslator() - Constructor for class org.apache.flink.streaming.runtime.translators.UnionTransformationTranslator
- UnionWithTempOperator<T> - Class in org.apache.flink.runtime.operators
- UnionWithTempOperator() - Constructor for class org.apache.flink.runtime.operators.UnionWithTempOperator
- uniqueVertexGroups(Map<V, Set<V>>) - Static method in class org.apache.flink.runtime.executiongraph.VertexGroupComputeUtil
- UNKNOWN - org.apache.flink.runtime.checkpoint.PendingCheckpoint.TaskAcknowledgeResult
- UNKNOWN - org.apache.flink.runtime.clusterframework.ApplicationStatus
-
Application status is not known.
- UNKNOWN - org.apache.flink.runtime.jobmanager.scheduler.Locality
-
No locality information was provided, it is unknown if the locality was respected
- UNKNOWN - org.apache.flink.runtime.state.StateObject.StateObjectLocation
- UNKNOWN - Static variable in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
A ResourceProfile that indicates an unknown resource requirement.
- UNKNOWN - Static variable in class org.apache.flink.runtime.util.EnvironmentInformation
- UNKNOWN_CHECKPOINTED_SIZE - Static variable in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
- UNKNOWN_COMMIT_ID - Static variable in class org.apache.flink.runtime.util.EnvironmentInformation
- UNKNOWN_COMMIT_ID_ABBREV - Static variable in class org.apache.flink.runtime.util.EnvironmentInformation
- UNKNOWN_TASK_CHECKPOINT_NOTIFICATION_FAILURE - org.apache.flink.runtime.checkpoint.CheckpointFailureReason
- UnknownKvStateLocation - Exception in org.apache.flink.runtime.query
-
Thrown if there is no
KvStateLocationfound for the requested registration name. - UnknownKvStateLocation(String) - Constructor for exception org.apache.flink.runtime.query.UnknownKvStateLocation
- UnknownOperationKeyException - Exception in org.apache.flink.runtime.dispatcher
-
Exception that indicates that there is no ongoing or completed savepoint for a given
JobIDandTriggerIdpair. - UnknownOperationKeyException(Object) - Constructor for exception org.apache.flink.runtime.dispatcher.UnknownOperationKeyException
- UnknownShuffleDescriptor - Class in org.apache.flink.runtime.shuffle
-
Unknown
ShuffleDescriptorfor which the producer has not been deployed yet. - UnknownShuffleDescriptor(ResultPartitionID) - Constructor for class org.apache.flink.runtime.shuffle.UnknownShuffleDescriptor
- UnknownTaskExecutorException - Exception in org.apache.flink.runtime.resourcemanager.exceptions
-
Exception denoting that a requested
TaskExecutorcould not be found. - UnknownTaskExecutorException(ResourceID) - Constructor for exception org.apache.flink.runtime.resourcemanager.exceptions.UnknownTaskExecutorException
- UnknownTierShuffleDescriptor - Class in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier
-
This is a placeholder when the tier shuffle descriptor should be unknown because the netty shuffle descriptor is unknown.
- UNLIMITED_TOLERABLE_FAILURE_NUMBER - Static variable in class org.apache.flink.runtime.checkpoint.CheckpointFailureManager
- unmonitorTarget(ResourceID) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatManager
-
Stops monitoring the heartbeat target with the associated resource ID.
- unmonitorTarget(ResourceID) - Method in class org.apache.flink.runtime.heartbeat.NoOpHeartbeatManager
- unPause() - Method in class org.apache.flink.streaming.api.operators.util.PausableRelativeClock
- unrecoverable(Execution, Throwable, long, CompletableFuture<Map<String, String>>, boolean, boolean) - Static method in class org.apache.flink.runtime.executiongraph.failover.FailureHandlingResult
-
Creates a result that the failure is not recoverable and no restarting should be conducted.
- unregister(JobID) - Method in class org.apache.flink.runtime.dispatcher.DefaultJobManagerRunnerRegistry
- unregister(JobID) - Method in interface org.apache.flink.runtime.dispatcher.JobManagerRunnerRegistry
-
Unregistered the
JobManagerRunnerwith the givenJobID. - unregister(JobID) - Method in class org.apache.flink.runtime.dispatcher.OnMainThreadJobManagerRunnerRegistry
- unregister(Metric, String, AbstractMetricGroup) - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
-
Un-registers the given
Metricwith this registry. - unregister(Metric, String, AbstractMetricGroup) - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
- unregister(Metric, String, AbstractMetricGroup) - Method in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
- unregisterAll() - Method in class org.apache.flink.runtime.query.TaskKvStateRegistry
-
Unregisters all registered KvState instances from the KvStateRegistry.
- unregisterAllTimeouts() - Method in class org.apache.flink.runtime.taskexecutor.slot.DefaultTimerService
-
Unregister all timeouts.
- unregisterBackPressureListener(TimerGauge.StartStopListener) - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
- UnregisteredJobManagerJobMetricGroup() - Constructor for class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredJobManagerJobMetricGroup
- UnregisteredJobManagerJobMetricGroupFactory - Enum in org.apache.flink.runtime.jobmaster.factories
-
JobManagerJobMetricGroupFactorywhich returns an unregisteredJobManagerJobMetricGroup. - UnregisteredJobMangerOperatorMetricGroup() - Constructor for class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredJobMangerOperatorMetricGroup
- UnregisteredMetricGroups - Class in org.apache.flink.runtime.metrics.groups
-
A collection of safe drop-in replacements for existing
ComponentMetricGroups. - UnregisteredMetricGroups.UnregisteredJobManagerJobMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
A safe drop-in replacement for
JobManagerJobMetricGroups. - UnregisteredMetricGroups.UnregisteredJobManagerMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
A safe drop-in replacement for
JobManagerMetricGroups. - UnregisteredMetricGroups.UnregisteredJobMangerOperatorMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
A safe drop-in replacement for
JobManagerOperatorMetricGroups. - UnregisteredMetricGroups.UnregisteredOperatorMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
A safe drop-in replacement for
InternalOperatorMetricGroups. - UnregisteredMetricGroups.UnregisteredProcessMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
A safe drop-in replacement for
ProcessMetricGroups. - UnregisteredMetricGroups.UnregisteredResourceManagerMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
A safe drop-in replacement for
ResourceManagerMetricGroups. - UnregisteredMetricGroups.UnregisteredSlotManagerMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
A safe drop-in replacement for
SlotManagerMetricGroups. - UnregisteredMetricGroups.UnregisteredTaskManagerJobMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
A safe drop-in replacement for
TaskManagerJobMetricGroups. - UnregisteredMetricGroups.UnregisteredTaskManagerMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
A safe drop-in replacement for
TaskManagerMetricGroups. - UnregisteredMetricGroups.UnregisteredTaskMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
A safe drop-in replacement for
TaskMetricGroups. - UnregisteredOperatorMetricGroup() - Constructor for class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredOperatorMetricGroup
- UnregisteredProcessMetricGroup() - Constructor for class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredProcessMetricGroup
- UnregisteredTaskManagerJobMetricGroup() - Constructor for class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredTaskManagerJobMetricGroup
- UnregisteredTaskManagerMetricGroup() - Constructor for class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredTaskManagerMetricGroup
- UnregisteredTaskMetricGroup() - Constructor for class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredTaskMetricGroup
- unregisterJob(JobID) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle.TieredInternalShuffleMaster
-
Unregisters the target job from this shuffle master, which means the corresponding job has reached a global termination state and all the allocated resources except for the cluster partitions can be cleared.
- unregisterJob(JobID) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageMasterClient
- unregisterJob(JobID) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.NoOpMasterAgent
- unregisterJob(JobID) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierMasterAgent
- unregisterJob(JobID) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierMasterAgent
-
Unregister a job id.
- unregisterJob(JobID) - Method in class org.apache.flink.runtime.shuffle.NettyShuffleMaster
- unregisterJob(JobID) - Method in interface org.apache.flink.runtime.shuffle.ShuffleMaster
-
Unregisters the target job from this shuffle master, which means the corresponding job has reached a global termination state and all the allocated resources except for the cluster partitions can be cleared.
- unregisterKvState(JobID, JobVertexID, KeyGroupRange, String, KvStateID) - Method in class org.apache.flink.runtime.query.KvStateRegistry
-
Unregisters the KvState instance identified by the given KvStateID.
- unregisterListener(JobID) - Method in class org.apache.flink.runtime.query.KvStateRegistry
-
Unregisters the listener with the registry.
- unregisterListener(TimerGauge.StartStopListener) - Method in class org.apache.flink.runtime.metrics.TimerGauge
- unregisterPartition(ResultPartitionID) - Method in class org.apache.flink.runtime.io.network.TaskEventDispatcher
-
Removes the given partition from listening to incoming task events, thus forbidding calls to
TaskEventDispatcher.subscribeToEvent(ResultPartitionID, EventListener, Class). - unregisterRequester(Object) - Method in class org.apache.flink.runtime.io.disk.BatchShuffleReadBufferPool
- unregisterSubtask(FileMergingSnapshotManager.SubtaskKey) - Method in interface org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManager
-
Unregister a subtask.
- unregisterSubtask(FileMergingSnapshotManager.SubtaskKey) - Method in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
- unregisterTaskManager(InstanceID, Exception) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.FineGrainedSlotManager
- unregisterTaskManager(InstanceID, Exception) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Unregisters the task manager identified by the given instance id and its associated slots from the slot manager.
- unregisterTimeout(K) - Method in class org.apache.flink.runtime.taskexecutor.slot.DefaultTimerService
- unregisterTimeout(K) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TimerService
-
Unregister the timeout for the given key.
- unregisterUnusedState(long) - Method in interface org.apache.flink.runtime.state.SharedStateRegistry
-
Unregister state that is not referenced by the given checkpoint ID or any newer.
- unregisterUnusedState(long) - Method in class org.apache.flink.runtime.state.SharedStateRegistryImpl
- unregisterUnusedState(Deque<CompletedCheckpoint>) - Method in class org.apache.flink.runtime.checkpoint.AbstractCompleteCheckpointStore
-
Unregister shared states that are no longer in use.
- UnresolvedTaskManagerLocation - Class in org.apache.flink.runtime.taskmanager
-
This class encapsulates the connection information of a TaskManager, without resolving the hostname.
- UnresolvedTaskManagerLocation(ResourceID, String, int, String) - Constructor for class org.apache.flink.runtime.taskmanager.UnresolvedTaskManagerLocation
- UNSET - Static variable in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
- UNSET - Static variable in class org.apache.flink.runtime.checkpoint.SubTaskInitializationMetrics
- UNSPECIFIED - Static variable in interface org.apache.flink.streaming.runtime.io.StreamTaskInput
- UNSUPPORTED - org.apache.flink.runtime.io.network.api.writer.SubtaskStateMapper
- UNSUPPORTED_DELETE_TIMER_MSG - Static variable in interface org.apache.flink.streaming.api.TimerService
-
Error string for
UnsupportedOperationExceptionon deleting timers. - UNSUPPORTED_REGISTER_TIMER_MSG - Static variable in interface org.apache.flink.streaming.api.TimerService
-
Error string for
UnsupportedOperationExceptionon registering timers. - UnsupportedOperationExecutor - Enum in org.apache.flink.runtime.concurrent
-
Executorimplementation which fails whenUnsupportedOperationExecutor.execute(Runnable)is called. - UnsupportedTimeCharacteristicException - Exception in org.apache.flink.streaming.api.datastream
-
An exception that indicates that a time characteristic was used that is not supported in the current operation.
- UnsupportedTimeCharacteristicException(String) - Constructor for exception org.apache.flink.streaming.api.datastream.UnsupportedTimeCharacteristicException
- unsynchronizedGetExclusiveBuffersUsed() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- unsynchronizedGetFloatingBuffersAvailable() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- unsynchronizedGetNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionDirectTransferReader
- unsynchronizedGetNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
- unsynchronizedGetNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
- unsynchronizedGetNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- unsynchronizedGetNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.TieredStorageResultSubpartitionView
- unsynchronizedGetNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.NoOpResultSubpartitionView
- unsynchronizedGetNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartition
- unsynchronizedGetNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.PipelinedSubpartitionView
- unsynchronizedGetNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
Makes a best effort to get the current size of the queue.
- unsynchronizedGetNumberOfQueuedBuffers() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
- unsynchronizedGetNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.UnionResultSubpartitionView
- unsynchronizedGetSizeOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
- unsynchronizedGetSizeOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
- untrack(Tuple2<JobID, BlobKey>) - Method in class org.apache.flink.runtime.blob.BlobCacheSizeTracker
-
Remove the BLOB from the tracker.
- untrackAll(JobID) - Method in class org.apache.flink.runtime.blob.BlobCacheSizeTracker
-
Unregister all the tracked BLOBs related to the given job.
- UntypedResponseMessageHeaders<R extends RequestBody,M extends MessageParameters> - Interface in org.apache.flink.runtime.rest.messages
-
Message headers for a web handler request.
- unwrap() - Method in class org.apache.flink.runtime.entrypoint.DeterminismEnvelope
- unwrap() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- unwrap() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
- unwrap() - Method in class org.apache.flink.runtime.messages.checkpoint.SerializedCheckpointException
- update() - Method in class org.apache.flink.runtime.metrics.TimerGauge
- update() - Method in interface org.apache.flink.runtime.rest.handler.legacy.metrics.MetricFetcher
-
Trigger fetching of metrics.
- update() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricFetcherImpl
-
This method can be used to signal this MetricFetcher that the metrics are still in use and should be updated.
- update() - Method in enum org.apache.flink.runtime.rest.handler.legacy.metrics.VoidMetricFetcher
- update(long) - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogram
- update(List<S>) - Method in class org.apache.flink.runtime.state.PartitionableListState
- update(List<T>) - Method in interface org.apache.flink.runtime.state.internal.InternalListState
-
Updates the operator state accessible by
AppendingState.get()by updating existing values to the given list of values. - update(List<T>) - Method in class org.apache.flink.streaming.api.operators.util.SimpleVersionedListState
- update(List<V>) - Method in class org.apache.flink.runtime.state.v2.AbstractListState
- update(List<V>) - Method in class org.apache.flink.runtime.state.v2.adaptor.ListStateAdaptor
- update(JobID, BlobKey) - Method in class org.apache.flink.runtime.blob.BlobCacheSizeTracker
-
Update the least used index for the BLOBs so that the tracker can easily find out the least recently used BLOBs.
- update(StateEntry<K, N, V>, V) - Method in interface org.apache.flink.runtime.state.internal.InternalKvState.StateIncrementalVisitor
-
Update the value of the last returned entry from the
next()method. - update(V) - Method in class org.apache.flink.runtime.state.v2.AbstractValueState
- update(V) - Method in class org.apache.flink.runtime.state.v2.adaptor.ValueStateAdaptor
- UPDATE_AND_GET_FLINK_CONFIGURATION - org.apache.flink.runtime.util.bash.BashJavaUtils.Command
-
Update and get configuration from conf file and dynamic configs of the FLINK cluster.
- updateAccumulators(AccumulatorSnapshot) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- updateAccumulators(AccumulatorSnapshot) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Updates the accumulators during the runtime of a job.
- updateAccumulators(AccumulatorSnapshot) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- updateAccumulators(AccumulatorSnapshot) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- updateAccumulators(AccumulatorSnapshot) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
- updateAndRetryLater(CommT) - Method in class org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestImpl
- updateCoLocationGroup(CoLocationGroupImpl) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
- updateCurrentEffectiveWatermark(long) - Method in interface org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks.WatermarkUpdateListener
-
Update the effective watermark.
- updateCurrentEffectiveWatermark(long) - Method in class org.apache.flink.streaming.api.operators.SourceOperator
- updateCurrentExecutionAttempts(Collection<JobDetails>) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
- updateCurrentSplitWatermark(String, long) - Method in interface org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks.WatermarkUpdateListener
-
Notifies about changes to per split watermarks.
- updateCurrentSplitWatermark(String, long) - Method in class org.apache.flink.streaming.api.operators.SourceOperator
- updateDelegationTokens(ResourceManagerId, byte[]) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- updateDelegationTokens(ResourceManagerId, byte[]) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Sends new delegation tokens to this TaskManager.
- updateDelegationTokens(ResourceManagerId, byte[]) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- updateElementSerializer(TypeSerializer<T>) - Method in class org.apache.flink.runtime.state.RegisteredPriorityQueueStateBackendMetaInfo
- updateGlobalAggregate(String, Object, byte[]) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- updateGlobalAggregate(String, Object, byte[]) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Update the aggregate and return the new value.
- updateGlobalAggregate(String, Object, AggregateFunction<IN, ACC, OUT>) - Method in interface org.apache.flink.runtime.taskexecutor.GlobalAggregateManager
-
Update the global aggregate and return the new value.
- updateGlobalAggregate(String, Object, AggregateFunction<IN, ACC, OUT>) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcGlobalAggregateManager
- updateGlobalAggregatesAndReset(String[], Value[]) - Method in class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
- updateIdle(boolean) - Method in interface org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks.WatermarkUpdateListener
-
It should be called once the idle is changed.
- updateIdle(boolean) - Method in class org.apache.flink.streaming.api.operators.SourceOperator
- updateInputChannel(ResourceID, NettyShuffleDescriptor) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
- updateInternal(SV) - Method in interface org.apache.flink.runtime.state.internal.InternalAppendingState
-
Update internally stored value.
- updateJobResourceRequirements(JobID, JobResourceRequirements) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
- updateJobResourceRequirements(JobID, JobResourceRequirements) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Update
job resource requirementsfor a given job. - updateJobResourceRequirements(JobResourceRequirements) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
- updateJobResourceRequirements(JobResourceRequirements) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Update
job resource requirements. - updateJobResourceRequirements(JobResourceRequirements) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- updateJobResourceRequirements(JobResourceRequirements) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
-
Update
job resource requirements. - updateKeySerializer(TypeSerializer<K>) - Method in class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
- updateKvStateLocationOracle(JobID, KvStateLocationOracle) - Method in interface org.apache.flink.runtime.query.KvStateClientProxy
-
Updates the active
Job Managerin case of change. - updateMatch(BT) - Method in class org.apache.flink.runtime.operators.hash.AbstractHashTableProber
- updateMatch(T) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable.HashTableProber
- updateMatch(T) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
-
This method can be called after getMatchFor returned a match.
- updateMaxDesiredWatermark(long) - Method in class org.apache.flink.runtime.metrics.groups.InternalSourceReaderMetricGroup
- updateNamespaceSerializer(TypeSerializer<N>) - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
- updatePartitionInfo(ExecutionAttemptID, PartitionInfo) - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
- updatePartitionInfo(ExecutionAttemptID, PartitionInfo) - Method in interface org.apache.flink.runtime.shuffle.ShuffleEnvironment
-
Update a gate with the newly available partition information, previously unknown.
- updatePartitions(ExecutionAttemptID, Iterable<PartitionInfo>, Duration) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Update the task where the given partitions can be found.
- updatePartitions(ExecutionAttemptID, Iterable<PartitionInfo>, Duration) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
- updatePartitions(ExecutionAttemptID, Iterable<PartitionInfo>, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
- updatePartitions(ExecutionAttemptID, Iterable<PartitionInfo>, Duration) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Update the task where the given partitions can be found.
- updatePartitions(ExecutionAttemptID, Iterable<PartitionInfo>, Duration) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorGatewayDecoratorBase
- updatePartitionStateSerializer(TypeSerializer<S>) - Method in class org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
- updateReadSubpartitionAndIndexEntryAddress() - Method in class org.apache.flink.runtime.io.network.partition.SortBuffer
- updateResultPartitionBytesMetrics(Map<IntermediateResultPartitionID, ResultPartitionBytes>) - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.BatchJobRecoveryContext
-
Updates the metrics related to the result partition sizes.
- UpdateSchedulerNgOnInternalFailuresListener - Class in org.apache.flink.runtime.scheduler
-
Calls
SchedulerNG.updateTaskExecutionState(TaskExecutionStateTransition)on task failure. - UpdateSchedulerNgOnInternalFailuresListener(SchedulerNG) - Constructor for class org.apache.flink.runtime.scheduler.UpdateSchedulerNgOnInternalFailuresListener
- updateSnapshotTransformFactory(StateSnapshotTransformer.StateSnapshotTransformFactory<S>) - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
- updateState(TaskExecutionStateTransition) - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- updateState(TaskExecutionStateTransition) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Updates the state of one of the ExecutionVertex's Execution attempts.
- updateStateSerializer(TypeSerializer<S>) - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
- updateStateSerializer(TypeSerializer<S>) - Method in class org.apache.flink.runtime.state.v2.RegisteredKeyValueStateBackendMetaInfo
- updateStatusAndSelection(DataInputStatus, int) - Method in class org.apache.flink.streaming.runtime.io.MultipleInputSelectionHandler
- updateTableEntryWithReduce(T) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.ReduceFacade
-
Looks up the table entry that has the same key as the given record, and updates it by performing a reduce step.
- updateTaskExecutionState(TaskExecutionStateTransition) - Method in class org.apache.flink.runtime.scheduler.adaptive.AdaptiveScheduler
- updateTaskExecutionState(TaskExecutionStateTransition) - Method in class org.apache.flink.runtime.scheduler.SchedulerBase
- updateTaskExecutionState(TaskExecutionStateTransition) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
- updateTaskExecutionState(TaskExecutionState) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
Updates the task execution state for a given task.
- updateTaskExecutionState(TaskExecutionState) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Updates the task execution state for a given task.
- updateTaskExecutionState(TaskExecutionState) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
- updateTaskExecutionState(TaskExecutionState) - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerActions
-
Notifies the task manager about the task execution state update.
- updateTierShuffleDescriptor(TieredStoragePartitionId, TieredStorageInputChannelId, TieredStorageSubpartitionId, TierShuffleDescriptor) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk.DiskTierConsumerAgent
- updateTierShuffleDescriptor(TieredStoragePartitionId, TieredStorageInputChannelId, TieredStorageSubpartitionId, TierShuffleDescriptor) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory.MemoryTierConsumerAgent
- updateTierShuffleDescriptor(TieredStoragePartitionId, TieredStorageInputChannelId, TieredStorageSubpartitionId, TierShuffleDescriptor) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteTierConsumerAgent
- updateTierShuffleDescriptor(TieredStoragePartitionId, TieredStorageInputChannelId, TieredStorageSubpartitionId, TierShuffleDescriptor) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.TierConsumerAgent
-
Update the
TierShuffleDescriptorfor the consumer agent. - updateTierShuffleDescriptors(TieredStoragePartitionId, TieredStorageInputChannelId, TieredStorageSubpartitionId, List<TierShuffleDescriptor>) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageConsumerClient
- updateTmpDirectoriesInConfiguration(Configuration, String) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Set temporary configuration directories if necessary.
- updateTopology(List<ExecutionJobVertex>) - Method in interface org.apache.flink.runtime.scheduler.adaptivebatch.BatchJobRecoveryContext
-
Updates the job topology with new job vertices that were initialized.
- updateValueSerializer(TypeSerializer<V>) - Method in class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
- uploadDir - Variable in class org.apache.flink.runtime.rest.RestServerEndpoint
- uploadedStates - Variable in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
- uploadFile(JobID, Path) - Method in class org.apache.flink.runtime.blob.BlobClient
-
Uploads a single file to the
PermanentBlobServiceof the givenBlobServer. - uploadFiles(InetSocketAddress, Configuration, JobID, List<Path>) - Static method in class org.apache.flink.runtime.blob.BlobClient
-
Uploads the JAR files to the
PermanentBlobServiceof theBlobServerat the given address with HA as configured. - uploadJobGraphFiles(JobGraph, Collection<Path>, Collection<Tuple2<String, Path>>, SupplierWithException<BlobClient, IOException>) - Static method in enum org.apache.flink.runtime.client.ClientUtils
-
Uploads the given jars and artifacts required for the execution of the given
JobGraphusing theBlobClientfrom the givenSupplier. - UPPER_BOUND_MAX_PARALLELISM - Static variable in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
-
The (inclusive) upper bound for max parallelism.
- upperBoundExclusive() - Method in class org.apache.flink.streaming.api.datastream.KeyedStream.IntervalJoined
-
Set the upper bound to be exclusive.
- UpperLimitExceptionParameter - Class in org.apache.flink.runtime.rest.messages.job
-
Specifies the upper limit of exceptions to return for JobExceptionsHandler.
- UpperLimitExceptionParameter() - Constructor for class org.apache.flink.runtime.rest.messages.job.UpperLimitExceptionParameter
- UpstreamRecoveryTracker - Interface in org.apache.flink.streaming.runtime.io.checkpointing
-
Tracks status of upstream channels while they recover.
- UpTimeGauge - Class in org.apache.flink.runtime.executiongraph.metrics
-
A gauge that returns (in milliseconds) how long a job has been running.
- UpTimeGauge(JobStatusProvider) - Constructor for class org.apache.flink.runtime.executiongraph.metrics.UpTimeGauge
- uri() - Method in class org.apache.flink.runtime.rest.handler.router.RouteResult
-
Returns the original request URI.
- URL - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
- URL - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
- URL - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
- URL - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
- URL - Static variable in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
- URL - Static variable in class org.apache.flink.runtime.rest.messages.job.coordination.ClientCoordinationHeaders
- URL - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
- URL - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
- URL - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
- URL - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
- URL - Static variable in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
- URL - Static variable in class org.apache.flink.runtime.rest.messages.JobCancellationHeaders
- URL - Static variable in class org.apache.flink.runtime.rest.messages.JobClientHeartbeatHeaders
- URL - Static variable in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
- URL - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
- URL - Static variable in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
- URL - Static variable in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
- URL - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
- URL - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
- URL - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
- URL - Static variable in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
- URL - Static variable in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
- URL - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
- URL - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
- USE_IP_ONLY - org.apache.flink.runtime.taskmanager.TaskManagerLocation.ResolutionMode
- useLocalCommunication() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
- useManagedMemory() - Method in class org.apache.flink.runtime.state.AbstractManagedMemoryStateBackend
- useManagedMemory() - Method in interface org.apache.flink.runtime.state.StateBackend
-
Whether the state backend uses Flink's managed memory.
- useNamespaceAndEnsurePath(CuratorFramework, String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Returns a facade of the client that uses the specified namespace, and ensures that all nodes in the path exist.
- UserAccumulator - Class in org.apache.flink.runtime.rest.messages.job
-
User accumulator info.
- UserAccumulator(String, String, String) - Constructor for class org.apache.flink.runtime.rest.messages.job.UserAccumulator
- userClassloader - Variable in class org.apache.flink.runtime.state.DefaultOperatorStateBackendBuilder
-
The user code classloader.
- userCodeClassLoader - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
- userCodeClassLoader - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
- userCodeClassLoader - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
- userFunction - Variable in class org.apache.flink.runtime.asyncprocessing.operators.AbstractAsyncStateUdfStreamOperator
-
The user function.
- userFunction - Variable in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
-
The user function.
- UserFunctionProvider<F extends org.apache.flink.api.common.functions.Function> - Interface in org.apache.flink.streaming.api.operators
-
The interface with user function.
- UserTaskAccumulator(String, String, String) - Constructor for class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
- usesConvergenceCriterion() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- usesImplicitConvergenceCriterion() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
- useSplittableTimers() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
-
Can be overridden to disable splittable timers for this particular operator even if config option is enabled.
- useSplittableTimers() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorV2
-
Can be overridden to disable splittable timers for this particular operator even if config option is enabled.
- useTicketCache() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
V
- V0 - org.apache.flink.runtime.rest.versioning.RuntimeRestAPIVersion
- V1 - org.apache.flink.runtime.rest.versioning.RuntimeRestAPIVersion
- validate(String, int) - Static method in class org.apache.flink.streaming.util.RemoteEnvironmentConfigUtils
- validate(JobResourceRequirements, Map<JobVertexID, Integer>) - Static method in class org.apache.flink.runtime.jobgraph.JobResourceRequirements
-
This method validates that: The requested boundaries are less or equal than the max parallelism.
- validateLength(int, int) - Static method in class org.apache.flink.runtime.io.compression.CompressorUtils
- validateOperatorsFinishedState() - Method in class org.apache.flink.runtime.checkpoint.VertexFinishedStateChecker
- validateTransformationUid(StreamGraph, Transformation<?>) - Static method in class org.apache.flink.streaming.util.graph.StreamGraphUtils
-
Throw
IllegalStateExceptionif thePhysicalTransformation's uid or hash is not set when auto generate uid is disabled. - validateUseCaseWeightsNotConflict(Map<ManagedMemoryUseCase, Integer>, Map<ManagedMemoryUseCase, Integer>) - Static method in enum org.apache.flink.runtime.util.config.memory.ManagedMemoryUtils
- value - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.GaugeDump
- value() - Method in class org.apache.flink.runtime.state.heap.HeapKeyValueStateIterator
- value() - Method in interface org.apache.flink.runtime.state.KeyValueStateIterator
- value() - Method in class org.apache.flink.runtime.state.v2.AbstractValueState
- value() - Method in class org.apache.flink.runtime.state.v2.adaptor.ValueStateAdaptor
- value() - Method in annotation type org.apache.flink.runtime.throwable.ThrowableAnnotation
-
Returns the type if the
Throwable. - VALUE - org.apache.flink.runtime.metrics.groups.AbstractMetricGroup.ChildType
- VALUE - org.apache.flink.runtime.state.v2.StateDescriptor.Type
- VALUE_GET - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Get value from current partition,
ValueState.asyncValue(). - VALUE_SERIALIZER - org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.CommonSerializerKeys
- VALUE_UPDATE - org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Update value to current partition,
ValueState.asyncUpdate(Object). - valueOf(int) - Static method in class org.apache.flink.runtime.persistence.IntegerResourceVersion
-
Create a
IntegerResourceVersionwith given integer value. - valueOf(String) - Static method in enum org.apache.flink.runtime.asyncprocessing.EpochManager.ParallelMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointFailureReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointOptions.AlignmentType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointRetentionPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.DeactivatedCheckpointCompletedCheckpointStore
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.DeactivatedCheckpointIDCounter
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.filemerging.FileMergingType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.filemerging.PhysicalFilePool.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.InflightDataRescalingDescriptor.InflightDataGateOrPartitionRescalingDescriptor.MappingType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.InitializationStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.NoOpCheckpointStatsTracker
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.PendingCheckpoint.TaskAcknowledgeResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.SavepointType.PostCheckpointAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.SnapshotType.SharingFilesStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointStoreUtil
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.client.ClientUtils
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.clusterframework.ApplicationStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.concurrent.UnsupportedOperationExecutor
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory.PartitionLocationConstraint
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.dispatcher.cleanup.CheckpointResourcesCleanupRunnerFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.dispatcher.cleanup.CleanupRetryStrategyFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.dispatcher.Dispatcher.ExecutionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.dispatcher.JobDispatcherFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.dispatcher.JobMasterServiceLeadershipRunnerFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.dispatcher.runner.StoppedDispatcherLeaderProcess
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.dispatcher.SessionDispatcherFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.dispatcher.TriggerSavepointMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.dispatcher.VoidHistoryServerArchivist
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.entrypoint.ClusterEntrypoint.ExecutionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.entrypoint.ClusterEntrypoint.ShutdownBehaviour
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.execution.ExecutionState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.executiongraph.failover.NoRestartBackoffTimeStrategy.NoRestartBackoffTimeStrategyFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.executiongraph.failover.NoRestartBackoffTimeStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.executiongraph.NoOpExecutionDeploymentListener
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.io.network.api.StopMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.io.network.api.writer.SubtaskStateMapper
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.io.network.buffer.Buffer.DataType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.io.PullingAsyncDataInput.EndOfDataStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobgraph.DistributionPattern
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobgraph.JobGraphUtils
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobgraph.JobType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmanager.HighAvailabilityMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmanager.NoOpJobGraphStoreWatcher
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmanager.scheduler.Locality
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmanager.scheduler.LocationPreferenceConstraint
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmanager.ThrowingJobGraphWriter
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmanager.ZooKeeperJobGraphStoreUtil
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmaster.ExecutionDeploymentState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmaster.factories.UnregisteredJobManagerJobMetricGroupFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmaster.JobMasterServiceProcess.WaitingForLeadership
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPool.NoOpNewSlotsListener
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmaster.slotpool.NoOpDeclareResourceRequirementServiceConnectionManager
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmaster.slotpool.PreferredAllocationRequestSlotMatchingStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmaster.slotpool.SimpleRequestSlotMatchingStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalDriver.LeaderInformationClearancePolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.metrics.groups.AbstractMetricGroup.ChildType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.minicluster.MiniCluster.HaServices
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.minicluster.MiniClusterJobClient.JobFinalizationBehavior
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.minicluster.RpcServiceSharing
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.operators.DamBehavior
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.operators.DriverStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.operators.shipping.ShipStrategyType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.operators.sort.StageRunner.SortStage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.operators.util.LocalStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in class org.apache.flink.runtime.persistence.StringResourceVersion
- valueOf(String) - Static method in enum org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager.RegistrationResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.handler.async.OperationResultStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.handler.legacy.metrics.VoidMetricFetcher
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.handler.RestHandlerException.LoggingBehavior
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.HttpMethodWrapper
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.JobRestEndpointFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.FlameGraphTypeQueryParameter.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter.AggregationMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.MessageParameter.MessageParameterRequisiteness
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.ProfilingInfo.ProfilingMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.ProfilingInfo.ProfilingStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.queue.QueueStatus.Id
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter.TerminationMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.SessionRestEndpointFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.util.RestConstants
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.versioning.RuntimeRestAPIVersion
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.scheduler.strategy.ResultPartitionState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.shuffle.NettyShuffleDescriptor.LocalExecutionPartitionConnectionInfo
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.shuffle.ShuffleServiceLoader
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.state.CheckpointedStateScope
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.BackendStateType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.CommonOptionsKeys
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.CommonSerializerKeys
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.state.OperatorStateHandle.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.state.SnapshotExecutionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.state.StateObject.StateObjectLocation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.state.StateSnapshotTransformer.CollectionStateSnapshotTransformer.TransformStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.state.v2.StateDescriptor.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.taskexecutor.FileType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.taskexecutor.slot.NoOpSlotAllocationSnapshotPersistenceService
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.taskexecutor.TaskManagerRunner.Result
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.taskmanager.Task.NotifyCheckpointOperation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.taskmanager.TaskManagerLocation.ResolutionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.throwable.ThrowableType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.util.bash.BashJavaUtils.Command
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.util.config.memory.ManagedMemoryUtils
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.util.ZooKeeperUtils.ZkClientACLMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.webmonitor.history.HistoryServerUtils
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.webmonitor.WebMonitorExtension.EmptyWebMonitorExtension
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.CheckpointingMode
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.functions.aggregation.AggregationFunction.AggregationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.functions.source.FileProcessingMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.functions.source.legacy.FileMonitoringFunction.WatchType
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.graph.GlobalStreamExchangeMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.graph.StreamConfig.InputRequirement
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.operators.ChainingStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.TimeDomain
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.transformations.StreamExchangeMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.windowing.assigners.WindowStagger
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.runtime.io.DataInputStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.runtime.operators.asyncprocessing.ElementOrder
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.streaming.util.LatencyStats.Granularity
-
Returns the enum constant of this type with the specified name.
- valueOf(StatsSummary) - Static method in class org.apache.flink.runtime.rest.messages.checkpoints.StatsSummaryDto
- valueOf(StatsSummarySnapshot) - Static method in class org.apache.flink.runtime.rest.messages.checkpoints.StatsSummaryDto
- valueOrNull(Object) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
- values() - Static method in enum org.apache.flink.runtime.asyncprocessing.EpochManager.ParallelMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.asyncprocessing.StateRequestType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointFailureReason
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointOptions.AlignmentType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointRetentionPolicy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.checkpoint.DeactivatedCheckpointCompletedCheckpointStore
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.checkpoint.DeactivatedCheckpointIDCounter
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.checkpoint.filemerging.FileMergingType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.checkpoint.filemerging.PhysicalFilePool.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.runtime.checkpoint.InflightDataRescalingDescriptor.InflightDataGateOrPartitionRescalingDescriptor.MappingType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.checkpoint.InitializationStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.checkpoint.NoOpCheckpointStatsTracker
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.checkpoint.PendingCheckpoint.TaskAcknowledgeResult
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.checkpoint.SavepointType.PostCheckpointAction
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.checkpoint.SnapshotType.SharingFilesStrategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointStoreUtil
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.client.ClientUtils
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.clusterframework.ApplicationStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.concurrent.UnsupportedOperationExecutor
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory.PartitionLocationConstraint
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.dispatcher.cleanup.CheckpointResourcesCleanupRunnerFactory
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.dispatcher.cleanup.CleanupRetryStrategyFactory
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.dispatcher.Dispatcher.ExecutionType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.dispatcher.JobDispatcherFactory
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.dispatcher.JobMasterServiceLeadershipRunnerFactory
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.dispatcher.runner.AbstractDispatcherLeaderProcess.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.dispatcher.runner.StoppedDispatcherLeaderProcess
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.dispatcher.SessionDispatcherFactory
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.dispatcher.TriggerSavepointMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.dispatcher.VoidHistoryServerArchivist
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.entrypoint.ClusterEntrypoint.ExecutionMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.entrypoint.ClusterEntrypoint.ShutdownBehaviour
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.execution.ExecutionState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.executiongraph.failover.NoRestartBackoffTimeStrategy.NoRestartBackoffTimeStrategyFactory
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.executiongraph.failover.NoRestartBackoffTimeStrategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.executiongraph.NoOpExecutionDeploymentListener
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.io.network.api.StopMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.io.network.api.writer.SubtaskStateMapper
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.io.network.buffer.Buffer.DataType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.apache.flink.runtime.io.network.partition.DeduplicatedQueue
- values() - Static method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartitionIndexSet
- values() - Static method in enum org.apache.flink.runtime.io.PullingAsyncDataInput.EndOfDataStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobgraph.DistributionPattern
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobgraph.JobGraphUtils
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobgraph.JobType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmanager.HighAvailabilityMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmanager.NoOpJobGraphStoreWatcher
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmanager.scheduler.Locality
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmanager.scheduler.LocationPreferenceConstraint
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmanager.ThrowingJobGraphWriter
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmanager.ZooKeeperJobGraphStoreUtil
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmaster.ExecutionDeploymentState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmaster.factories.UnregisteredJobManagerJobMetricGroupFactory
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmaster.JobMasterServiceProcess.WaitingForLeadership
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmaster.slotpool.DeclarativeSlotPool.NoOpNewSlotsListener
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmaster.slotpool.NoOpDeclareResourceRequirementServiceConnectionManager
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmaster.slotpool.PreferredAllocationRequestSlotMatchingStrategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmaster.slotpool.SimpleRequestSlotMatchingStrategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalDriver.LeaderInformationClearancePolicy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.metrics.groups.AbstractMetricGroup.ChildType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.minicluster.MiniCluster.HaServices
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.minicluster.MiniClusterJobClient.JobFinalizationBehavior
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.minicluster.RpcServiceSharing
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.operators.DamBehavior
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.operators.DriverStrategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.operators.shipping.ShipStrategyType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.operators.sort.StageRunner.SortStage
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.operators.util.LocalStrategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager.RegistrationResult
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.handler.async.OperationResultStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.handler.legacy.metrics.VoidMetricFetcher
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.handler.RestHandlerException.LoggingBehavior
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.HttpMethodWrapper
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.JobRestEndpointFactory
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.messages.FlameGraphTypeQueryParameter.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.runtime.rest.messages.job.metrics.MetricsAggregationParameter.AggregationMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureLevel
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.messages.MessageParameter.MessageParameterRequisiteness
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.messages.ProfilingInfo.ProfilingMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.messages.ProfilingInfo.ProfilingStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.messages.queue.QueueStatus.Id
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter.TerminationMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.SessionRestEndpointFactory
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.util.RestConstants
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.versioning.RuntimeRestAPIVersion
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.scheduler.strategy.ResultPartitionState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.shuffle.NettyShuffleDescriptor.LocalExecutionPartitionConnectionInfo
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.shuffle.ShuffleServiceLoader
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.state.CheckpointedStateScope
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.BackendStateType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.CommonOptionsKeys
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.CommonSerializerKeys
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.state.OperatorStateHandle.Mode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.state.SnapshotExecutionType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.state.StateObject.StateObjectLocation
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.state.StateSnapshotTransformer.CollectionStateSnapshotTransformer.TransformStrategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.apache.flink.runtime.state.v2.AbstractMapState
- values() - Method in class org.apache.flink.runtime.state.v2.adaptor.MapStateAdaptor
- values() - Static method in enum org.apache.flink.runtime.state.v2.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.runtime.taskexecutor.FileType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.taskexecutor.slot.NoOpSlotAllocationSnapshotPersistenceService
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.taskexecutor.TaskManagerRunner.Result
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.taskmanager.Task.NotifyCheckpointOperation
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.taskmanager.TaskManagerLocation.ResolutionMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.throwable.ThrowableType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.util.bash.BashJavaUtils.Command
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.util.config.memory.ManagedMemoryUtils
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.apache.flink.runtime.util.DualKeyLinkedMap
- values() - Static method in enum org.apache.flink.runtime.util.ZooKeeperUtils.ZkClientACLMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.webmonitor.history.HistoryServerUtils
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.webmonitor.WebMonitorExtension.EmptyWebMonitorExtension
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.CheckpointingMode
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.functions.aggregation.AggregationFunction.AggregationType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.functions.source.FileProcessingMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.functions.source.legacy.FileMonitoringFunction.WatchType
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.graph.GlobalStreamExchangeMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.graph.StreamConfig.InputRequirement
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.operators.ChainingStrategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.TimeDomain
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.transformations.StreamExchangeMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.windowing.assigners.WindowStagger
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.runtime.io.DataInputStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.runtime.operators.asyncprocessing.ElementOrder
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.runtime.operators.sink.committables.CommitRequestState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.runtime.tasks.mailbox.TaskMailbox.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.streaming.util.LatencyStats.Granularity
-
Returns an array containing the constants of this enum type, in the order they are declared.
- valueSerializer - Variable in class org.apache.flink.runtime.state.heap.AbstractHeapState
- ValueStateAdaptor<K,N,V> - Class in org.apache.flink.runtime.state.v2.adaptor
-
An adaptor that transforms
InternalValueStateintoInternalValueState. - ValueStateAdaptor(InternalValueState<K, N, V>) - Constructor for class org.apache.flink.runtime.state.v2.adaptor.ValueStateAdaptor
- ValueStateDescriptor<T> - Class in org.apache.flink.runtime.state.v2
-
StateDescriptorforValueState. - ValueStateDescriptor(String, TypeInformation<T>) - Constructor for class org.apache.flink.runtime.state.v2.ValueStateDescriptor
-
Creates a new
ValueStateDescriptorwith the given stateId and type. - ValueStateDescriptor(String, TypeInformation<T>, SerializerConfig) - Constructor for class org.apache.flink.runtime.state.v2.ValueStateDescriptor
-
Creates a new
ValueStateDescriptorwith the given stateId and type. - VariableLengthByteKeyAndValueComparator<INPUT> - Class in org.apache.flink.streaming.api.operators.sortpartition
-
The
VariableLengthByteKeyAndValueComparatoris used byKeyedSortPartitionOperatorto compare records according to both the record key and record value. - VariableLengthByteKeyAndValueComparator(TypeComparator<INPUT>) - Constructor for class org.apache.flink.streaming.api.operators.sortpartition.VariableLengthByteKeyAndValueComparator
- variables - Variable in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
The map containing all variables and their associated values, lazily computed.
- verifyEmpty() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Checks if the memory manager's memory is completely available (nothing allocated at the moment).
- verifyEndOfSuperstepState() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
- version() - Method in class org.apache.flink.runtime.checkpoint.MasterState
- VERSION - Static variable in class org.apache.flink.runtime.checkpoint.metadata.MetadataV1Serializer
-
The savepoint version.
- VERSION - Static variable in class org.apache.flink.runtime.checkpoint.metadata.MetadataV2Serializer
-
The metadata format version.
- VERSION - Static variable in class org.apache.flink.runtime.checkpoint.metadata.MetadataV3Serializer
-
The metadata format version.
- VERSION - Static variable in class org.apache.flink.runtime.checkpoint.metadata.MetadataV4Serializer
- VERSION - Static variable in class org.apache.flink.runtime.checkpoint.metadata.MetadataV5Serializer
- VERSION - Static variable in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
- VERSION - Static variable in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
- VERSION - Static variable in class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
- VERSION_0 - Static variable in class org.apache.flink.runtime.source.coordinator.SourceCoordinatorSerdeUtils
- VERSION_1 - Static variable in class org.apache.flink.runtime.source.coordinator.SourceCoordinatorSerdeUtils
- VERSION_PLACEHOLDER - Static variable in class org.apache.flink.runtime.rest.RestClient
- Vertex<VID extends VertexID,RID extends ResultID,V extends Vertex<VID,RID,V,R>,R extends Result<VID,RID,V,R>> - Interface in org.apache.flink.runtime.topology
-
Represents a logical or execution task.
- VERTEX_TASK_FIELD_ID - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo
- VERTEX_TASK_FIELD_NAME - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo
- VERTEX_TASK_FIELD_NOW - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo
- VERTEX_TASK_FIELD_TASK_MANAGERS - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo
- VertexAllocationInformation(AllocationID, JobVertexID, KeyGroupRange, long) - Constructor for class org.apache.flink.runtime.scheduler.adaptive.allocator.JobAllocationsInformation.VertexAllocationInformation
- VertexAttemptNumberStore - Interface in org.apache.flink.runtime.executiongraph
-
Contains the attempt numbers per vertex.
- VertexEndOfDataListener - Class in org.apache.flink.runtime.scheduler
-
Records the end of data event of each task, and allows for checking whether all tasks of a
JobGraphhave reached the end of data. - VertexEndOfDataListener(ExecutionGraph) - Constructor for class org.apache.flink.runtime.scheduler.VertexEndOfDataListener
- vertexFinished(ExecutionVertexID) - Method in class org.apache.flink.runtime.executiongraph.failover.partitionrelease.NotReleasingPartitionGroupReleaseStrategy
- vertexFinished(ExecutionVertexID) - Method in interface org.apache.flink.runtime.executiongraph.failover.partitionrelease.PartitionGroupReleaseStrategy
-
Calling this method informs the strategy that a vertex finished.
- vertexFinished(ExecutionVertexID) - Method in class org.apache.flink.runtime.executiongraph.failover.partitionrelease.RegionPartitionGroupReleaseStrategy
- VertexFinishedStateChecker - Class in org.apache.flink.runtime.checkpoint
-
This class encapsulates the operation that checks if there are illegal modification to the JobGraph when restoring from a checkpoint with partially or fully finished operator states.
- VertexFinishedStateChecker(Set<ExecutionJobVertex>, Map<OperatorID, OperatorState>) - Constructor for class org.apache.flink.runtime.checkpoint.VertexFinishedStateChecker
- VertexFlameGraph - Class in org.apache.flink.runtime.webmonitor.threadinfo
-
Flame Graph representation for a job vertex or an execution vertex.
- VertexFlameGraph(long, VertexFlameGraph.Node) - Constructor for class org.apache.flink.runtime.webmonitor.threadinfo.VertexFlameGraph
- VertexFlameGraph.Node - Class in org.apache.flink.runtime.webmonitor.threadinfo
-
Graph node.
- VertexFlameGraphFactory - Class in org.apache.flink.runtime.webmonitor.threadinfo
-
Factory class for creating Flame Graph representations.
- VertexFlameGraphFactory() - Constructor for class org.apache.flink.runtime.webmonitor.threadinfo.VertexFlameGraphFactory
- VertexGroupComputeUtil - Class in org.apache.flink.runtime.executiongraph
-
Common utils for processing vertex groups.
- vertexId - Variable in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
- vertexId() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
- vertexID - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobManagerOperatorQueryScopeInfo
- vertexID - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
- vertexID - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
- VertexID - Interface in org.apache.flink.runtime.topology
-
ID of a
Vertex. - vertexIDtoBrokerID - Variable in class org.apache.flink.streaming.api.graph.StreamGraph
- vertexIDtoLoopTimeout - Variable in class org.apache.flink.streaming.api.graph.StreamGraph
- VertexInputInfoComputationUtils - Class in org.apache.flink.runtime.executiongraph
-
Util to compute
JobVertexInputInfos for execution job vertex. - VertexInputInfoStore - Class in org.apache.flink.runtime.executiongraph
-
A store contains all the
JobVertexInputInfos. - VertexInputInfoStore() - Constructor for class org.apache.flink.runtime.executiongraph.VertexInputInfoStore
- VertexParallelism - Class in org.apache.flink.runtime.scheduler.adaptive.allocator
-
Core result of
SlotAllocator.determineParallelism(JobInformation, Collection)among withslotAssignments, describing the parallelism each vertex could be scheduled with. - VertexParallelism(Map<JobVertexID, Integer>) - Constructor for class org.apache.flink.runtime.scheduler.adaptive.allocator.VertexParallelism
- VertexParallelismAndInputInfosDecider - Interface in org.apache.flink.runtime.scheduler.adaptivebatch
-
VertexParallelismAndInputInfosDecideris responsible for deciding the parallelism andJobVertexInputInfos of a job vertex, based on the information of the consumed blocking results. - VertexParallelismInformation - Interface in org.apache.flink.runtime.scheduler
-
Manages the parallelism properties for a vertex in the execution graph, as well as how they can change during runtime.
- VertexParallelismStore - Interface in org.apache.flink.runtime.scheduler
-
Contains the max parallelism per vertex, along with metadata about how these maxes were calculated.
- VertexStatsTracker<T extends Statistics> - Interface in org.apache.flink.runtime.webmonitor.stats
-
Interface for a tracker of statistics for
AccessExecutionJobVertex. - VertexThreadInfoStats - Class in org.apache.flink.runtime.webmonitor.threadinfo
-
Thread info statistics of single JobVertex or ExecutionVertex.
- VertexThreadInfoStats(int, long, long, Map<ExecutionAttemptID, Collection<ThreadInfoSample>>) - Constructor for class org.apache.flink.runtime.webmonitor.threadinfo.VertexThreadInfoStats
-
Creates a thread details sample.
- VertexThreadInfoTracker - Class in org.apache.flink.runtime.webmonitor.threadinfo
-
Tracker of thread infos for
ExecutionJobVertex. - VertexThreadInfoTrackerBuilder - Class in org.apache.flink.runtime.webmonitor.threadinfo
-
Builder for
VertexThreadInfoTracker. - vertexUnfinished(ExecutionVertexID) - Method in class org.apache.flink.runtime.executiongraph.failover.partitionrelease.NotReleasingPartitionGroupReleaseStrategy
- vertexUnfinished(ExecutionVertexID) - Method in interface org.apache.flink.runtime.executiongraph.failover.partitionrelease.PartitionGroupReleaseStrategy
-
Calling this method informs the strategy that a vertex is no longer in finished state, e.g., when a vertex is re-executed.
- vertexUnfinished(ExecutionVertexID) - Method in class org.apache.flink.runtime.executiongraph.failover.partitionrelease.RegionPartitionGroupReleaseStrategy
- VertexwiseSchedulingStrategy - Class in org.apache.flink.runtime.scheduler.strategy
-
SchedulingStrategyinstance which schedules tasks in granularity of vertex (which indicates this strategy only supports batch jobs). - VertexwiseSchedulingStrategy(SchedulerOperations, SchedulingTopology, InputConsumableDecider.Factory) - Constructor for class org.apache.flink.runtime.scheduler.strategy.VertexwiseSchedulingStrategy
- VertexwiseSchedulingStrategy.Factory - Class in org.apache.flink.runtime.scheduler.strategy
-
The factory for creating
VertexwiseSchedulingStrategy. - ViewUpdater - Class in org.apache.flink.runtime.metrics
-
The ViewUpdater is responsible for updating all metrics that implement the
Viewinterface. - ViewUpdater(ScheduledExecutorService) - Constructor for class org.apache.flink.runtime.metrics.ViewUpdater
- VoidBlobStore - Class in org.apache.flink.runtime.blob
-
A blob store doing nothing.
- VoidBlobStore() - Constructor for class org.apache.flink.runtime.blob.VoidBlobStore
- VoidBlobWriter - Class in org.apache.flink.runtime.blob
-
BlobWriter which does not support writing BLOBs to a store.
- VoidBlobWriter() - Constructor for class org.apache.flink.runtime.blob.VoidBlobWriter
- VoidHistoryServerArchivist - Enum in org.apache.flink.runtime.dispatcher
-
No-op implementation of the
HistoryServerArchivist. - VoidMetricFetcher - Enum in org.apache.flink.runtime.rest.handler.legacy.metrics
-
No-op implementation of the
MetricFetcher. - VoidNamespace - Class in org.apache.flink.runtime.state
-
Singleton placeholder class for state without a namespace.
- VoidNamespaceSerializer - Class in org.apache.flink.runtime.state
-
Serializer for
VoidNamespace. - VoidNamespaceSerializer() - Constructor for class org.apache.flink.runtime.state.VoidNamespaceSerializer
- VoidNamespaceSerializer.VoidNamespaceSerializerSnapshot - Class in org.apache.flink.runtime.state
-
Serializer configuration snapshot for compatibility and format evolution.
- VoidNamespaceSerializerSnapshot() - Constructor for class org.apache.flink.runtime.state.VoidNamespaceSerializer.VoidNamespaceSerializerSnapshot
- VoidNamespaceTypeInfo - Class in org.apache.flink.runtime.state
-
TypeInformationforVoidNamespace. - VoidNamespaceTypeInfo() - Constructor for class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
W
- waitForDone() - Method in class org.apache.flink.runtime.checkpoint.channel.ChannelStateWriter.ChannelStateWriteResult
- waitForFirstBlock() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
- waitForOtherWorkers() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
-
Wait on the barrier.
- waitForPendingCheckpoints() - Method in interface org.apache.flink.streaming.runtime.tasks.SubtaskCheckpointCoordinator
-
Waits for all the pending checkpoints to finish their asynchronous step.
- waitForSolutionSetUpdate() - Method in class org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrier
-
Waits (blocking) on barrier.
- waiting() - Static method in class org.apache.flink.runtime.webmonitor.threadinfo.VertexFlameGraph
- waitingForLeadership() - Static method in interface org.apache.flink.runtime.jobmaster.JobMasterServiceProcess
- waitUntilTerminal() - Method in class org.apache.flink.runtime.executiongraph.DefaultExecutionGraph
- waitUntilTerminal() - Method in interface org.apache.flink.runtime.executiongraph.ExecutionGraph
- WALL - org.apache.flink.runtime.rest.messages.ProfilingInfo.ProfilingMode
- wasFree(AllocationID) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotPool.AllocatedSlotsAndReservationStatus
- watchSegment(TieredStoragePartitionId, TieredStorageSubpartitionId, int) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote.RemoteStorageScanner
-
Watch the segment for a specific subpartition in the
RemoteStorageScanner. - watermark - Variable in class org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve.SubpartitionStatus
- Watermark - Class in org.apache.flink.streaming.api.watermark
-
A Watermark tells operators that no elements with a timestamp older or equal to the watermark timestamp should arrive at the operator.
- Watermark(long) - Constructor for class org.apache.flink.streaming.api.watermark.Watermark
-
Creates a new watermark with the given timestamp in milliseconds.
- WATERMARK_ALIGNMENT_DRIFT - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- WATERMARK_LAG - Static variable in class org.apache.flink.runtime.metrics.MetricNames
- WatermarkAlignmentEvent - Class in org.apache.flink.runtime.source.event
-
Signals source operators the maximum watermark that emitted records can have.
- WatermarkAlignmentEvent(long) - Constructor for class org.apache.flink.runtime.source.event.WatermarkAlignmentEvent
- WatermarkElement(Watermark) - Constructor for class org.apache.flink.runtime.source.coordinator.SourceCoordinator.WatermarkElement
- watermarkEmitted(long) - Method in class org.apache.flink.runtime.metrics.groups.InternalSourceReaderMetricGroup
-
Called when a watermark was emitted.
- WatermarkEmitter(Output<?>) - Constructor for class org.apache.flink.streaming.runtime.operators.TimestampsAndWatermarksOperator.WatermarkEmitter
- WatermarkGauge - Class in org.apache.flink.streaming.runtime.metrics
-
A
Gaugefor exposing the current input/output watermark. - WatermarkGauge() - Constructor for class org.apache.flink.streaming.runtime.metrics.WatermarkGauge
- WatermarkGaugeExposingOutput<T> - Interface in org.apache.flink.streaming.runtime.tasks
-
An
Outputthat measures the last emitted watermark with aWatermarkGauge. - watermarkStatus - Variable in class org.apache.flink.streaming.runtime.watermarkstatus.StatusWatermarkValve.SubpartitionStatus
- WatermarkStatus - Class in org.apache.flink.streaming.runtime.watermarkstatus
-
A Watermark Status element informs stream tasks whether or not they should continue to expect watermarks from the input stream that sent them.
- WatermarkStatus(int) - Constructor for class org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus
- WatermarkStrategyWithPeriodicWatermarks<T> - Interface in org.apache.flink.streaming.runtime.operators.util
-
The
WatermarkStrategyWithPeriodicWatermarksassigns event time timestamps to elements, and generates low watermarks that signal event time progress within the stream. - WatermarkStrategyWithPunctuatedWatermarks<T> - Interface in org.apache.flink.streaming.runtime.operators.util
-
The
AssignerWithPunctuatedWatermarksassigns event time timestamps to elements, and generates low watermarks that signal event time progress within the stream. - WatermarkToDataOutput - Class in org.apache.flink.streaming.api.operators.source
-
An adapter that exposes a
WatermarkOutputbased on aPushingAsyncDataInput.DataOutput. - WatermarkToDataOutput(PushingAsyncDataInput.DataOutput<?>) - Constructor for class org.apache.flink.streaming.api.operators.source.WatermarkToDataOutput
- WatermarkToDataOutput(PushingAsyncDataInput.DataOutput<?>, TimestampsAndWatermarks.WatermarkUpdateListener) - Constructor for class org.apache.flink.streaming.api.operators.source.WatermarkToDataOutput
-
Creates a new WatermarkOutput against the given DataOutput.
- WebContentHandlerSpecification - Class in org.apache.flink.runtime.rest.handler.legacy.files
-
Rest handler specification for the web content handler.
- WebMonitorEndpoint<T extends RestfulGateway> - Class in org.apache.flink.runtime.webmonitor
-
Rest endpoint which serves the web frontend REST calls.
- WebMonitorEndpoint(GatewayRetriever<? extends T>, Configuration, RestHandlerConfiguration, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, ScheduledExecutorService, MetricFetcher, LeaderElection, ExecutionGraphCache, FatalErrorHandler) - Constructor for class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
- WebMonitorExtension - Interface in org.apache.flink.runtime.webmonitor
-
Interface for
WebMonitorEndpointextensions. - WebMonitorExtension.EmptyWebMonitorExtension - Enum in org.apache.flink.runtime.webmonitor
-
Empty web monitor extension which can be used as a null object.
- WebMonitorUtils - Class in org.apache.flink.runtime.webmonitor
-
Utilities for the web runtime monitor.
- WebMonitorUtils.LogFileLocation - Class in org.apache.flink.runtime.webmonitor
-
Singleton to hold the log file, the stdout file, the log directory.
- where(KeySelector<T1, KEY>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams
-
Specifies a
KeySelectorfor elements from the first input. - where(KeySelector<T1, KEY>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams
-
Specifies a
KeySelectorfor elements from the first input. - where(KeySelector<T1, KEY>, TypeInformation<KEY>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams
-
Specifies a
KeySelectorfor elements from the first input with explicit type information. - where(KeySelector<T1, KEY>, TypeInformation<KEY>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams
-
Specifies a
KeySelectorfor elements from the first input with explicit type information for the key type. - willBeOccupiedIndefinitely() - Method in interface org.apache.flink.runtime.jobmaster.SlotInfo
-
Returns whether the slot will be occupied indefinitely.
- willOccupySlotIndefinitely() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlot.Payload
-
Returns whether the payload will occupy a physical slot indefinitely.
- willOccupySlotIndefinitely() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
- willSlotBeOccupiedIndefinitely() - Method in class org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlotRequest
- window - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.AbstractPerWindowStateStore
- window - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
- window - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
- window - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
- window() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyAllWindowContext
- window() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
- window() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
- window() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
-
Returns the window that is being evaluated.
- window() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessAllWindowContext
- window() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
- window(WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1, T2>, W>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.Where.EqualTo
-
Specifies the window on which the co-group operation works.
- window(WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1, T2>, W>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.Where.EqualTo
-
Specifies the window on which the join operation works.
- window(WindowAssigner<? super T, W>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
-
Windows this data stream to a
WindowedStream, which evaluates windows over a key grouped stream. - Window - Class in org.apache.flink.streaming.api.windowing.windows
-
A
Windowis a grouping of elements into finite buckets. - Window() - Constructor for class org.apache.flink.streaming.api.windowing.windows.Window
- windowAll(WindowAssigner<? super T, W>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Windows this data stream to a
AllWindowedStream, which evaluates windows over a non key grouped stream. - windowAssigner - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
- windowAssigner - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorFactory
- WindowAssigner<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowAssignerassigns zero or moreWindowsto an element. - WindowAssigner() - Constructor for class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
- WindowAssigner.WindowAssignerContext - Class in org.apache.flink.streaming.api.windowing.assigners
-
A context provided to the
WindowAssignerthat allows it to query the current processing time. - windowAssignerContext - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
- WindowAssignerContext() - Constructor for class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner.WindowAssignerContext
- WindowContext(W) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
- WindowedStream<T,K,W extends Window> - Class in org.apache.flink.streaming.api.datastream
-
A
WindowedStreamrepresents a data stream where elements are grouped by key, and for each key, the stream of elements is split into windows based on aWindowAssigner. - WindowedStream(KeyedStream<T, K>, WindowAssigner<? super T, W>) - Constructor for class org.apache.flink.streaming.api.datastream.WindowedStream
- windowFunction - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorFactory
- WindowFunction<IN,OUT,KEY,W extends Window> - Interface in org.apache.flink.streaming.api.functions.windowing
-
Base interface for functions that are evaluated over keyed (grouped) windows.
- WindowOperator<K,IN,ACC,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
An operator that implements the logic for windowing based on a
WindowAssignerandTrigger. - WindowOperator(WindowAssigner<? super IN, W>, TypeSerializer<W>, KeySelector<IN, K>, TypeSerializer<K>, StateDescriptor<? extends AppendingState<IN, ACC>, ?>, InternalWindowFunction<ACC, OUT, K, W>, Trigger<? super IN, ? super W>, long, OutputTag<IN>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
Creates a new
WindowOperatorbased on the given policies and user functions. - WindowOperator.AbstractPerWindowStateStore - Class in org.apache.flink.streaming.runtime.operators.windowing
-
Base class for per-window
KeyedStateStores. - WindowOperator.Context - Class in org.apache.flink.streaming.runtime.operators.windowing
-
Contextis a utility for handlingTriggerinvocations. - WindowOperator.MergingWindowStateStore - Class in org.apache.flink.streaming.runtime.operators.windowing
-
Special
WindowOperator.AbstractPerWindowStateStorethat doesn't allow access to per-window state. - WindowOperator.PerWindowStateStore - Class in org.apache.flink.streaming.runtime.operators.windowing
-
Regular per-window state store for use with
ProcessWindowFunction. - WindowOperator.Timer<K,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
Internal class for keeping track of in-flight timers.
- WindowOperator.WindowContext - Class in org.apache.flink.streaming.runtime.operators.windowing
-
A utility class for handling
ProcessWindowFunctioninvocations. - WindowOperatorBuilder<T,K,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
-
A builder for creating
WindowOperators. - WindowOperatorBuilder(WindowAssigner<? super T, W>, Trigger<? super T, ? super W>, ExecutionConfig, TypeInformation<T>, KeySelector<T, K>, TypeInformation<K>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorBuilder
- WindowOperatorFactory<K,IN,ACC,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
- WindowOperatorFactory(WindowAssigner<? super IN, W>, TypeSerializer<W>, KeySelector<IN, K>, TypeSerializer<K>, StateDescriptor<? extends AppendingState<IN, ACC>, ?>, InternalWindowFunction<ACC, OUT, K, W>, Trigger<? super IN, ? super W>, long, OutputTag<IN>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorFactory
- windowSerializer - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
-
For serializing the window in checkpoints.
- windowSerializer - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorFactory
- WindowStagger - Enum in org.apache.flink.streaming.api.windowing.assigners
-
A
WindowStaggerstaggers offset in runtime for each window assignment. - windowState - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
- windowState() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyAllWindowContext
- windowState() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
- windowState() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
-
State accessor for per-key and per-window state.
- windowState() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
-
State accessor for per-key and per-window state.
- windowState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessAllWindowContext
- windowState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
- windowState() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
- windowState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
- windowStateDescriptor - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorFactory
- WITH_LEADERSHIP_CONTROL - org.apache.flink.runtime.minicluster.MiniCluster.HaServices
-
Enables or disables
HaLeadershipControlinMiniCluster.getHaLeadershipControl(). - WithBoundedness - Interface in org.apache.flink.streaming.api.transformations
-
An interface to be implemented by transformations that have explicitly set
Boundedness. - withCombiner(GroupCombineFunction<T, T>) - Method in class org.apache.flink.runtime.operators.sort.ExternalSorterBuilder
- withCombiner(GroupCombineFunction<T, T>, Configuration) - Method in class org.apache.flink.runtime.operators.sort.ExternalSorterBuilder
- withCpuCores(double) - Method in class org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpecBuilder
- withCpuCores(CPUResource) - Method in class org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpecBuilder
- withDataAdded(long, long) - Method in class org.apache.flink.runtime.state.AbstractChannelStateHandle.StateContentMetaInfo
- WithinCheckpointFileMergingSnapshotManager - Class in org.apache.flink.runtime.checkpoint.filemerging
-
A
FileMergingSnapshotManagerthat merging files within a checkpoint. - WithinCheckpointFileMergingSnapshotManager(String, long, PhysicalFilePool.Type, float, Executor, MetricGroup) - Constructor for class org.apache.flink.runtime.checkpoint.filemerging.WithinCheckpointFileMergingSnapshotManager
- withLocalState(T, T) - Static method in class org.apache.flink.runtime.state.SnapshotResult
- WithMasterCheckpointHook<E> - Interface in org.apache.flink.streaming.api.checkpoint
-
This interface can be implemented by streaming functions that need to trigger a "global action" on the master (in the checkpoint coordinator) as part of every checkpoint and restore operation.
- withNumRegisteredPartitions(int, int) - Static method in class org.apache.flink.runtime.io.network.partition.DataSetMetaInfo
- withOptions(CheckpointOptions) - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
- withoutCheckpointStoreRecovery(IntFunction<T>) - Static method in class org.apache.flink.runtime.checkpoint.PerJobCheckpointRecoveryFactory
- withoutStackTrace(String) - Static method in exception org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
- withPrioritizedCleanup(String, T) - Method in class org.apache.flink.runtime.dispatcher.cleanup.DefaultResourceCleaner.Builder
-
Prioritized cleanups run before their regular counterparts.
- withProperties(CheckpointProperties) - Method in class org.apache.flink.runtime.checkpoint.metadata.CheckpointMetadata
- withRandomPorts() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
- withRegularCleanup(String, T) - Method in class org.apache.flink.runtime.dispatcher.cleanup.DefaultResourceCleaner.Builder
-
Regular cleanups are resources for which the cleanup is triggered after all prioritized cleanups succeeded.
- withResource(ResourceProfile, int) - Static method in class org.apache.flink.runtime.util.ResourceCounter
-
Creates a resource counter with the given resourceProfile and its count.
- withResources(Map<ResourceProfile, Integer>) - Static method in class org.apache.flink.runtime.util.ResourceCounter
-
Creates a resource counter with the specified set of resources.
- withSerializerUpgradesAllowed() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
- withSerializerUpgradesAllowed() - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
- withSerializerUpgradesAllowed() - Method in class org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
- withSerializerUpgradesAllowed() - Method in class org.apache.flink.runtime.state.RegisteredPriorityQueueStateBackendMetaInfo
- withSerializerUpgradesAllowed() - Method in class org.apache.flink.runtime.state.RegisteredStateMetaInfoBase
-
create a new metadata object with Lazy serializer provider using existing one as a snapshot.
- withSerializerUpgradesAllowed() - Method in class org.apache.flink.runtime.state.v2.RegisteredKeyValueStateBackendMetaInfo
- withSubtaskId(int) - Method in class org.apache.flink.streaming.api.connector.sink2.CommittableWithLineage
-
Creates a shallow copy with the given subtaskId.
- withTotalProcessMemory(MemorySize) - Method in class org.apache.flink.runtime.clusterframework.TaskExecutorProcessSpecBuilder
- withUnalignedSupported() - Method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
- withUnalignedUnsupported() - Method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
- withUncaughtExceptionHandler(Runnable, Thread.UncaughtExceptionHandler) - Static method in class org.apache.flink.runtime.util.Runnables
-
Guard
Runnablewith uncaughtException handler, becauseScheduledExecutorServicedoes not respect the one assigned to executingThreadinstance. - WithWindow(DataStream<T1>, DataStream<T2>, KeySelector<T1, KEY>, KeySelector<T2, KEY>, TypeInformation<KEY>, WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1, T2>, W>, Trigger<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>, Evictor<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>, Duration) - Constructor for class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
- WithWindow(DataStream<T1>, DataStream<T2>, KeySelector<T1, KEY>, KeySelector<T2, KEY>, TypeInformation<KEY>, WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1, T2>, W>, Trigger<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>, Evictor<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>, Duration) - Constructor for class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
- WorkerDoneEvent - Class in org.apache.flink.runtime.iterative.event
-
Completion event sent from each
IterationHeadto theIterationSynchronizationSinkTask. - WorkerDoneEvent() - Constructor for class org.apache.flink.runtime.iterative.event.WorkerDoneEvent
- WorkerDoneEvent(int, String, Value) - Constructor for class org.apache.flink.runtime.iterative.event.WorkerDoneEvent
- WorkerDoneEvent(int, Map<String, Aggregator<?>>) - Constructor for class org.apache.flink.runtime.iterative.event.WorkerDoneEvent
- WorkerRegistration<WorkerType extends ResourceIDRetrievable> - Class in org.apache.flink.runtime.resourcemanager.registration
-
This class extends the
TaskExecutorConnection, adding the worker information. - WorkerRegistration(TaskExecutorGateway, WorkerType, int, int, HardwareDescription, TaskExecutorMemoryConfiguration, ResourceProfile, ResourceProfile, String) - Constructor for class org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
- WorkerResourceSpec - Class in org.apache.flink.runtime.resourcemanager
-
Resource specification of a worker, mainly used by SlotManager requesting from ResourceManager.
- WorkerResourceSpec.Builder - Class in org.apache.flink.runtime.resourcemanager
-
Builder for
WorkerResourceSpec. - WorkerResourceSpecFactory - Class in org.apache.flink.runtime.resourcemanager
-
Factory for creating deployment specific default
WorkerResourceSpec. - WorkerResourceSpecFactory() - Constructor for class org.apache.flink.runtime.resourcemanager.WorkerResourceSpecFactory
- workerResourceSpecFromConfigAndCpu(Configuration, CPUResource) - Method in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpecFactory
- WorkingDirectory - Class in org.apache.flink.runtime.entrypoint
-
Class that manages a working directory for a process/instance.
- worksetAggregator - Variable in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
- worksetBackChannel - Variable in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
- WorksetEmptyConvergenceCriterion - Class in org.apache.flink.runtime.iterative.convergence
-
A workset iteration is by definition converged if no records have been updated in the solutionset.
- WorksetEmptyConvergenceCriterion() - Constructor for class org.apache.flink.runtime.iterative.convergence.WorksetEmptyConvergenceCriterion
- WorksetUpdateOutputCollector<T> - Class in org.apache.flink.runtime.iterative.io
-
A
Collectorto update the iteration workset (partial solution for bulk iterations). - WorksetUpdateOutputCollector(DataOutputView, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
- WorksetUpdateOutputCollector(DataOutputView, TypeSerializer<T>, Collector<T>) - Constructor for class org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
- wrap(OperatorMetricGroup) - Static method in class org.apache.flink.runtime.metrics.groups.InternalSinkCommitterMetricGroup
- wrap(OperatorMetricGroup) - Static method in class org.apache.flink.runtime.metrics.groups.InternalSinkWriterMetricGroup
- wrap(OperatorMetricGroup) - Static method in class org.apache.flink.runtime.metrics.groups.InternalSourceReaderMetricGroup
- wrapHook(MasterTriggerRestoreHook<T>, ClassLoader) - Static method in class org.apache.flink.runtime.checkpoint.hooks.MasterHooks
-
Wraps a hook such that the user-code classloader is applied when the hook is invoked.
- wrapInputs(TaskInvokable, StreamTaskInput<Object>[], KeySelector<Object, K>[], TypeSerializer<Object>[], TypeSerializer<K>, StreamTaskInput<Object>[], MemoryManager, IOManager, boolean, double, Configuration, ExecutionConfig) - Static method in class org.apache.flink.streaming.api.operators.sort.MultiInputSortingDataInput
- wrapSingleHandle(T) - Static method in class org.apache.flink.runtime.state.ChainedStateHandle
- write(byte[]) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
- write(byte[]) - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
- write(byte[]) - Method in class org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
- write(byte[]) - Method in class org.apache.flink.runtime.util.ForwardingOutputStream
- write(byte[], int, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
- write(byte[], int, int) - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
- write(byte[], int, int) - Method in class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
- write(byte[], int, int) - Method in class org.apache.flink.runtime.state.filesystem.FileMergingCheckpointStateOutputStream
- write(byte[], int, int) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
- write(byte[], int, int) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
- write(byte[], int, int) - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
- write(byte[], int, int) - Method in class org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
- write(byte[], int, int) - Method in class org.apache.flink.runtime.util.ForwardingOutputStream
- write(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
- write(int) - Method in class org.apache.flink.runtime.state.CompressibleFSDataOutputStream
- write(int) - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
- write(int) - Method in class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
- write(int) - Method in class org.apache.flink.runtime.state.filesystem.FileMergingCheckpointStateOutputStream
- write(int) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
- write(int) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
- write(int) - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
- write(int) - Method in class org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
- write(int) - Method in class org.apache.flink.runtime.util.ForwardingOutputStream
- write(ByteBuffer, TieredStorageSubpartitionId, Buffer.DataType, boolean) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage.TieredStorageProducerClient
-
Write records to the producer client.
- write(FSDataOutputStream) - Method in interface org.apache.flink.runtime.state.BackendWritableBroadcastState
- write(FSDataOutputStream) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
- write(FSDataOutputStream) - Method in class org.apache.flink.runtime.state.PartitionableListState
- write(DataInputView, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
- write(DataOutputView) - Method in class org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
- write(DataOutputView) - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
- write(DataOutputView) - Method in class org.apache.flink.runtime.io.network.api.EndOfData
- write(DataOutputView) - Method in class org.apache.flink.runtime.io.network.api.EndOfPartitionEvent
- write(DataOutputView) - Method in class org.apache.flink.runtime.io.network.api.EndOfSegmentEvent
- write(DataOutputView) - Method in class org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
- write(DataOutputView) - Method in class org.apache.flink.runtime.io.network.api.EventAnnouncement
- write(DataOutputView) - Method in class org.apache.flink.runtime.io.network.api.RecoveryMetadata
- write(DataOutputView) - Method in class org.apache.flink.runtime.io.network.api.SubtaskConnectionDescriptor
- write(DataOutputView) - Method in class org.apache.flink.runtime.io.network.partition.consumer.EndOfChannelStateEvent
- write(DataOutputView) - Method in class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
- write(DataOutputView) - Method in class org.apache.flink.runtime.iterative.event.TerminationEvent
- write(DataOutputView) - Method in class org.apache.flink.runtime.iterative.event.WorkerDoneEvent
- write(DataOutputView) - Method in class org.apache.flink.runtime.plugable.NonReusingDeserializationDelegate
- write(DataOutputView) - Method in class org.apache.flink.runtime.plugable.ReusingDeserializationDelegate
- write(DataOutputView) - Method in class org.apache.flink.runtime.plugable.SerializationDelegate
- write(DataOutputView) - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
- write(DataOutputView) - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
- write(DataOutputView) - Method in class org.apache.flink.streaming.api.operators.InternalTimerServiceSerializationProxy
- write(MemorySegment, int, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
- write(TieredStoragePartitionId, List<PartitionFileWriter.SubpartitionBufferContext>) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.PartitionFileWriter
-
Write the buffers to the partition file.
- write(TieredStoragePartitionId, List<PartitionFileWriter.SubpartitionBufferContext>) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.ProducerMergedPartitionFileWriter
- write(TieredStoragePartitionId, List<PartitionFileWriter.SubpartitionBufferContext>) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.SegmentPartitionFileWriter
- write(TaskConfig) - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
- write(T) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
Writes a given record to this sort buffer.
- write(T) - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Writes a given record to this sort buffer.
- write(T) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
Writes a given record to this sort buffer.
- writeBack(BT) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.HashBucketIterator
- writeBehindBuffers - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The queue of buffers that can be used for write-behind.
- writeBehindBuffersAvailable - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The number of buffers in the write behind queue that are actually not write behind buffers, but regular buffers that only have not yet returned.
- writeBlock(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockWriterWithCallback
-
Issues a asynchronous write request to the writer.
- writeBlock(Buffer) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileWriter
-
Writes the given block asynchronously.
- writeBlock(T) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelWriterWithCallback
-
Writes the given block.
- writeBoolean(boolean) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
- writeBuffers(FileChannel, long, ByteBuffer...) - Static method in class org.apache.flink.runtime.io.network.partition.BufferReaderWriterUtil
- writeBuffers(WritableByteChannel, long, ByteBuffer[]) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.SegmentPartitionFile
- writeBuffers(List<BufferWithSubpartition>) - Method in class org.apache.flink.runtime.io.network.partition.PartitionedFileWriter
-
Writes a list of
Buffers to thisPartitionedFile. - writeBufferSize - Variable in class org.apache.flink.runtime.checkpoint.filemerging.FileMergingSnapshotManagerBase
-
The buffer size for writing files to the file system.
- writeBufferSize - Variable in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageAccess
- writeByte(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
- writeBytes(String) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
- writeChar(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
- writeChars(String) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
- writeConfiguration(Configuration, File) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Writes a Flink YAML config file from a Flink Configuration object.
- writeDouble(double) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
- writeElement(T, DataOutputView) - Method in interface org.apache.flink.runtime.state.KeyGroupPartitioner.ElementWriterFunction
-
This method defines how to write a single element to the output.
- writeEvent(JobEvent, boolean) - Method in class org.apache.flink.runtime.jobmaster.event.FileSystemJobEventStore
- writeEvent(JobEvent, boolean) - Method in class org.apache.flink.runtime.jobmaster.event.JobEventManager
-
Write a job event asynchronously.
- writeEvent(JobEvent, boolean) - Method in interface org.apache.flink.runtime.jobmaster.event.JobEventStore
-
Write a job event.
- writeEventRunnable(JobEvent, boolean) - Method in class org.apache.flink.runtime.jobmaster.event.FileSystemJobEventStore
- writeFixedSizeRegionToFile(FileChannel, ByteBuffer, FileDataIndexRegionHelper.Region) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.index.FileRegionWriteReadUtils
- writeFloat(float) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
- writeInt(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
- writeIntLE(int, byte[], int) - Static method in class org.apache.flink.runtime.io.compression.CompressorUtils
- writeKey(K, TypeSerializer<K>, DataOutputSerializer, boolean) - Static method in class org.apache.flink.runtime.state.CompositeKeySerializationUtils
- writeKeyGroup(int, int, DataOutputView) - Static method in class org.apache.flink.runtime.state.CompositeKeySerializationUtils
- writeLeaderInformationToZooKeeper(LeaderInformation, CuratorFramework, BooleanSupplier, String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
- writeLong(long) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
- writeNameSpace(N, TypeSerializer<N>, DataOutputSerializer, boolean) - Static method in class org.apache.flink.runtime.state.CompositeKeySerializationUtils
- writeNettyPayload(NettyPayload) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyConnectionWriter
-
Write a buffer to netty connection.
- writeNettyPayload(NettyPayload) - Method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.netty.NettyConnectionWriterImpl
- writeRecord(E) - Method in interface org.apache.flink.runtime.operators.sort.PushSorter
-
Writers a new record to the sorter.
- writeRegionToFile(FileChannel, T) - Method in interface org.apache.flink.runtime.io.network.partition.hybrid.index.FileDataIndexRegionHelper
-
Write the region to the file.
- writeSegmentFinishFile(String, TieredStoragePartitionId, int, int) - Static method in class org.apache.flink.runtime.io.network.partition.hybrid.tiered.file.SegmentPartitionFile
- writeShort(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
- writeState(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<S>, DataOutputView, StateSnapshotTransformer<S>) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMapSnapshot
- writeState(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<S>, DataOutputView, StateSnapshotTransformer<S>) - Method in class org.apache.flink.runtime.state.heap.StateMapSnapshot
-
Writes the state in this snapshot to output.
- writeStateInKeyGroup(DataOutputView, int) - Method in interface org.apache.flink.runtime.state.StateSnapshot.StateKeyGroupWriter
-
Writes the data for the specified key-group to the output.
- writeStateMetaInfoSnapshot(StateMetaInfoSnapshot, DataOutputView) - Method in interface org.apache.flink.runtime.state.metainfo.StateMetaInfoWriter
-
Writes the given snapshot to the output view.
- writeTimersSnapshot(DataOutputView) - Method in interface org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.InternalTimersSnapshotWriter
-
Writes the timers snapshot to the output view.
- writeTo(ByteBuf) - Method in class org.apache.flink.runtime.executiongraph.ExecutionAttemptID
- writeTo(ByteBuf) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraphID
- writeTo(ByteBuf) - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
- writeTo(ByteBuf) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartitionIndexSet
- writeTo(ByteBuf) - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSetID
- writeTo(ByteBuf) - Method in class org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
- writeTo(ByteBuf) - Method in class org.apache.flink.runtime.jobgraph.JobVertexID
- writeTo(ByteBuf) - Method in class org.apache.flink.runtime.scheduler.strategy.ExecutionVertexID
- writeToJobGraph(JobGraph, JobResourceRequirements) - Static method in class org.apache.flink.runtime.jobgraph.JobResourceRequirements
-
Write
resource requirementsinto the configuration of a givenJobGraph. - writeToOutput(ChannelWriterOutputView) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
Writes the records in this buffer in their logical order to the given output.
- writeToOutput(ChannelWriterOutputView) - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Writes the records in this buffer in their logical order to the given output.
- writeToOutput(ChannelWriterOutputView) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
Writes the records in this buffer in their logical order to the given output.
- writeToOutput(ChannelWriterOutputView, int, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
Writes a subset of the records in this buffer in their logical order to the given output.
- writeToOutput(ChannelWriterOutputView, int, int) - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Writes a subset of the records in this buffer in their logical order to the given output.
- writeToOutput(ChannelWriterOutputView, int, int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
Writes a subset of the records in this buffer in their logical order to the given output.
- writeToOutput(ChannelWriterOutputView, LargeRecordHandler<T>) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
- writeToOutput(ChannelWriterOutputView, LargeRecordHandler<T>) - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
- writeToOutput(ChannelWriterOutputView, LargeRecordHandler<T>) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
- writeToSocket(String, int, SerializationSchema<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Writes the DataStream to a socket as a byte array.
- writeUserArtifactEntriesToConfiguration() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
- writeUsingOutputFormat(OutputFormat<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
-
Deprecated.Please use the
org.apache.flink.streaming.api.functions.sink.filesystem.legacy.StreamingFileSinkexplicitly using theDataStream.addSink(SinkFunction)method. - writeUTF(String) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
- writeVariableIntBytes(int, DataOutputView) - Static method in class org.apache.flink.runtime.state.CompositeKeySerializationUtils
- writeWatermark(Watermark) - Method in interface org.apache.flink.streaming.api.functions.sink.legacy.SinkFunction
-
Deprecated.Writes the given watermark to the sink.
- writeWithKeyNormalization(Tuple2<byte[], INPUT>, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.sortpartition.FixedLengthByteKeyAndValueComparator
- writeWithKeyNormalization(Tuple2<byte[], INPUT>, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.sortpartition.VariableLengthByteKeyAndValueComparator
Y
- YarnCancelJobTerminationHeaders - Class in org.apache.flink.runtime.rest.messages
-
Deprecated.This should be removed once we can send arbitrary REST calls via the Yarn proxy.
- YarnStopJobTerminationHeaders - Class in org.apache.flink.runtime.rest.messages
-
Deprecated.This should be removed once we can send arbitrary REST calls via the Yarn proxy.
- yield() - Method in class org.apache.flink.streaming.runtime.tasks.mailbox.MailboxExecutorImpl
- YieldingOperator<OUT> - Interface in org.apache.flink.streaming.api.operators
-
A V1 operator that needs access to the
MailboxExecutorshould implement this interface. - YieldingOperatorFactory<OUT> - Interface in org.apache.flink.streaming.api.operators.legacy
-
Deprecated.
Z
- ZERO - Static variable in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
A ResourceProfile describing zero resources.
- ZERO - Static variable in class org.apache.flink.runtime.resourcemanager.WorkerResourceSpec
- ZOOKEEPER - org.apache.flink.runtime.jobmanager.HighAvailabilityMode
- ZooKeeperCheckpointIDCounter - Class in org.apache.flink.runtime.checkpoint
-
CheckpointIDCounterinstances for JobManagers running inHighAvailabilityMode.ZOOKEEPER. - ZooKeeperCheckpointIDCounter(CuratorFramework, LastStateConnectionStateListener) - Constructor for class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
-
Creates a
ZooKeeperCheckpointIDCounterinstance. - ZooKeeperCheckpointRecoveryFactory - Class in org.apache.flink.runtime.checkpoint
-
CheckpointCoordinatorcomponents inHighAvailabilityMode.ZOOKEEPER. - ZooKeeperCheckpointRecoveryFactory(CuratorFramework, Configuration, Executor) - Constructor for class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
- ZooKeeperCheckpointStoreUtil - Enum in org.apache.flink.runtime.checkpoint
-
Singleton
CheckpointStoreUtilimplementation for ZooKeeper. - ZooKeeperClientHAServices - Class in org.apache.flink.runtime.highavailability.zookeeper
-
ZooKeeper based implementation for
ClientHighAvailabilityServices. - ZooKeeperClientHAServices(CuratorFrameworkWithUnhandledErrorListener, Configuration) - Constructor for class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperClientHAServices
- ZooKeeperJobGraphStoreUtil - Enum in org.apache.flink.runtime.jobmanager
-
Singleton
JobGraphStoreUtilimplementation for ZooKeeper. - ZooKeeperJobGraphStoreWatcher - Class in org.apache.flink.runtime.jobmanager
-
JobGraphStoreWatcherimplementation for ZooKeeper. - ZooKeeperJobGraphStoreWatcher(PathChildrenCache) - Constructor for class org.apache.flink.runtime.jobmanager.ZooKeeperJobGraphStoreWatcher
- ZooKeeperLeaderElectionDriver - Class in org.apache.flink.runtime.leaderelection
-
ZooKeeper based
LeaderElectionDriverimplementation. - ZooKeeperLeaderElectionDriver(CuratorFramework, LeaderElectionDriver.Listener) - Constructor for class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionDriver
- ZooKeeperLeaderElectionDriverFactory - Class in org.apache.flink.runtime.leaderelection
-
Factory for
ZooKeeperLeaderElectionDriver. - ZooKeeperLeaderElectionDriverFactory(CuratorFramework) - Constructor for class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionDriverFactory
- ZooKeeperLeaderElectionHaServices - Class in org.apache.flink.runtime.highavailability.zookeeper
-
ZooKeeper HA services that only use a single leader election per process.
- ZooKeeperLeaderElectionHaServices(CuratorFrameworkWithUnhandledErrorListener, Configuration, Executor, BlobStoreService) - Constructor for class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperLeaderElectionHaServices
- ZooKeeperLeaderRetrievalDriver - Class in org.apache.flink.runtime.leaderretrieval
-
The counterpart to the
ZooKeeperLeaderElectionDriver. - ZooKeeperLeaderRetrievalDriver(CuratorFramework, String, LeaderRetrievalEventHandler, ZooKeeperLeaderRetrievalDriver.LeaderInformationClearancePolicy, FatalErrorHandler) - Constructor for class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalDriver
-
Creates a leader retrieval service which uses ZooKeeper to retrieve the leader information.
- ZooKeeperLeaderRetrievalDriver.LeaderInformationClearancePolicy - Enum in org.apache.flink.runtime.leaderretrieval
-
Policy when to clear the leader information and to notify the listener about it.
- ZooKeeperLeaderRetrievalDriverFactory - Class in org.apache.flink.runtime.leaderretrieval
-
LeaderRetrievalDriverFactoryimplementation for Zookeeper. - ZooKeeperLeaderRetrievalDriverFactory(CuratorFramework, String, ZooKeeperLeaderRetrievalDriver.LeaderInformationClearancePolicy) - Constructor for class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalDriverFactory
- ZooKeeperModule - Class in org.apache.flink.runtime.security.modules
-
Responsible for installing a process-wide ZooKeeper security configuration.
- ZooKeeperModule(SecurityConfiguration) - Constructor for class org.apache.flink.runtime.security.modules.ZooKeeperModule
- ZookeeperModuleFactory - Class in org.apache.flink.runtime.security.modules
- ZookeeperModuleFactory() - Constructor for class org.apache.flink.runtime.security.modules.ZookeeperModuleFactory
- ZooKeeperSharedCount - Class in org.apache.flink.runtime.zookeeper
-
Wrapper class for a
SharedCountso that we don't expose a curator dependency in our internal APIs. - ZooKeeperSharedCount(SharedCount) - Constructor for class org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
- ZooKeeperSharedValue - Class in org.apache.flink.runtime.zookeeper
-
Wrapper class for a
SharedValueso that we don't expose a curator dependency in our internal APIs. - ZooKeeperSharedValue(SharedValue) - Constructor for class org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
- ZooKeeperStateHandleStore<T extends Serializable> - Class in org.apache.flink.runtime.zookeeper
-
Class which stores state via the provided
RetrievableStateStorageHelperand writes the returned state handle to ZooKeeper. - ZooKeeperStateHandleStore(CuratorFramework, RetrievableStateStorageHelper<T>) - Constructor for class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Creates a
ZooKeeperStateHandleStore. - ZooKeeperUtils - Class in org.apache.flink.runtime.util
-
Class containing helper functions to interact with ZooKeeper.
- ZooKeeperUtils.SecureAclProvider - Class in org.apache.flink.runtime.util
-
Secure
ACLProviderimplementation. - ZooKeeperUtils.ZkClientACLMode - Enum in org.apache.flink.runtime.util
-
ZooKeeper client ACL mode enum.
- ZooKeeperVersionedValue<T> - Class in org.apache.flink.runtime.zookeeper
-
Wrapper class for a
VersionedValueso that we don't expose a curator dependency in our internal APIs. - ZooKeeperVersionedValue(VersionedValue<T>) - Constructor for class org.apache.flink.runtime.zookeeper.ZooKeeperVersionedValue
_
- _getByte(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- _getInt(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- _getIntLE(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- _getLong(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- _getLongLE(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- _getShort(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- _getShortLE(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- _getUnsignedMedium(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- _getUnsignedMediumLE(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- _setByte(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- _setInt(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- _setIntLE(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- _setLong(int, long) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- _setLongLE(int, long) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- _setMedium(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- _setMediumLE(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- _setShort(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
- _setShortLE(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
All Classes All Packages