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

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.
abortCheckpointOnBarrier(long, Throwable) - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Aborts a checkpoint as the result of receiving possibly some checkpoint barriers, but at least one CancelCheckpointMarker.
abortDeclined() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
abortError(Throwable) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
Aborts the pending checkpoint due to an error.
abortExpired() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
Aborts a checkpoint because it expired (took too long).
abortSubsumed() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
Aborts the pending checkpoint because a newer completed checkpoint subsumed it.
absoluteTimeMillis() - Method in class org.apache.flink.runtime.util.clock.Clock
 
absoluteTimeMillis() - Method in class org.apache.flink.runtime.util.clock.SystemClock
 
AbstractAggregatedMetricsHeaders<P extends AbstractAggregatedMetricsParameters<?>> - Class in org.apache.flink.runtime.rest.messages.job.metrics
Based MessageHeaders class 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 MessageParameters class 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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, AbstractAggregatedMetricsHeaders<P>, Executor, MetricFetcher<?>) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.AbstractAggregatingMetricsHandler
 
AbstractAsyncCallableWithResources<V> - Class in org.apache.flink.runtime.io.async
This abstract class encapsulates the lifecycle and execution strategy for asynchronous operations that use resources.
AbstractAsyncCallableWithResources() - Constructor for class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
 
AbstractAsynchronousOperationHandlers<K extends OperationKey,R> - Class in org.apache.flink.runtime.rest.handler.async
HTTP handlers for asynchronous operations.
AbstractAsynchronousOperationHandlers() - Constructor for class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers
 
AbstractAsynchronousOperationHandlers.CompletedOperationCache<K,R> - Class in org.apache.flink.runtime.rest.handler.async
Cache to manage ongoing operations.
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.
AbstractBlobCache - Class in org.apache.flink.runtime.blob
Abstract base class for permanent and transient BLOB files.
AbstractBlobCache(Configuration, BlobView, Logger, InetSocketAddress) - Constructor for class org.apache.flink.runtime.blob.AbstractBlobCache
 
AbstractBroadcastStateMetaInfoReader(ClassLoader) - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractBroadcastStateMetaInfoReader
 
AbstractBroadcastStateMetaInfoWriter(RegisteredBroadcastBackendStateMetaInfo.Snapshot<K, V>) - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractBroadcastStateMetaInfoWriter
 
AbstractCachedBuildSideJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
 
AbstractCachedBuildSideJoinDriver(int, int) - Constructor for class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
 
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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, R, M>, ExecutionGraphCache, Executor, 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.
AbstractEvent - Class in org.apache.flink.runtime.event
This type of event can be used to exchange notification messages between different TaskManager objects 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 AccessExecutionGraph based REST handlers.
AbstractExecutionGraphHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, R, M>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.AbstractExecutionGraphHandler
 
AbstractExecutionGraphRequestHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Base class for request handlers whose response depends on an ExecutionGraph that can be retrieved via "jobid" parameter.
AbstractExecutionGraphRequestHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.AbstractExecutionGraphRequestHandler
 
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
A base class for all state backends that store their metadata (and data) in files.
AbstractFileStateBackend(URI, URI) - Constructor for class org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
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
Creates a backend with the given optional checkpoint- and savepoint base directories.
AbstractFileStateBackend(Path, Path, Configuration) - Constructor for class org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
Creates a new backend using the given checkpoint-/savepoint directories, or the values defined in the given configuration.
AbstractFsCheckpointStorage - Class in org.apache.flink.runtime.state.filesystem
An implementation of durable checkpoint storage to file systems.
AbstractFsCheckpointStorage(JobID, Path) - Constructor for class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
Creates a new checkpoint storage.
AbstractHandler<T extends RestfulGateway,R extends RequestBody,M extends MessageParameters> - Class in org.apache.flink.runtime.rest
Super class for netty-based handlers that work with RequestBody.
AbstractHandler(CompletableFuture<String>, GatewayRetriever<? extends T>, Time, Map<String, String>, UntypedResponseMessageHeaders<R, M>) - Constructor for class org.apache.flink.runtime.rest.AbstractHandler
 
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
 
AbstractHeapMergingState<K,N,IN,SV,OUT,S extends org.apache.flink.api.common.state.State> - Class in org.apache.flink.runtime.state.heap
Base class for MergingState (InternalMergingState) that is stored on the heap.
AbstractHeapMergingState(StateTable<K, N, SV>, TypeSerializer<K>, TypeSerializer<SV>, TypeSerializer<N>, SV) - Constructor for class org.apache.flink.runtime.state.heap.AbstractHeapMergingState
Creates a new key/value state for the given hash map of key/value pairs.
AbstractHeapState<K,N,SV,S extends org.apache.flink.api.common.state.State> - Class in org.apache.flink.runtime.state.heap
Base class for partitioned State implementations that are backed by a regular heap hash map.
AbstractHeapState(StateTable<K, N, SV>, TypeSerializer<K>, TypeSerializer<SV>, TypeSerializer<N>, SV) - Constructor for class org.apache.flink.runtime.state.heap.AbstractHeapState
Creates a new key/value state for the given hash map of key/value pairs.
AbstractInvokable - Class in org.apache.flink.runtime.jobgraph.tasks
This is the abstract base class for every task that can be executed by a TaskManager.
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.
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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, 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.
AbstractJobVertexRequestHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Base class for request handlers whose response depends on a specific job vertex (defined via the "vertexid" parameter) in a specific job, defined via (defined via the "jobid" parameter).
AbstractJobVertexRequestHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.AbstractJobVertexRequestHandler
 
AbstractJsonRequestHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Base class for most request handlers.
AbstractJsonRequestHandler(Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.AbstractJsonRequestHandler
 
AbstractKeyedStateBackend<K> - Class in org.apache.flink.runtime.state
Base implementation of KeyedStateBackend.
AbstractKeyedStateBackend(TaskKvStateRegistry, TypeSerializer<K>, ClassLoader, int, KeyGroupRange, ExecutionConfig) - Constructor for class org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
AbstractMergeInnerJoinIterator<T1,T2,O> - Class in org.apache.flink.runtime.operators.sort
An implementation of the JoinTaskIterator that 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 JoinTaskIterator that 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 MetricGroup that 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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, MetricCollectionResponseBody, M>, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.AbstractMetricsHandler
 
AbstractMetricsHandler - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
Abstract request handler that returns a list of all available metrics or the values for a set of metrics.
AbstractMetricsHandler(Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.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
 
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
 
AbstractOperatorBackendStateMetaInfoReader(ClassLoader) - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractOperatorBackendStateMetaInfoReader
 
AbstractOperatorBackendStateMetaInfoWriter(RegisteredOperatorBackendStateMetaInfo.Snapshot<S>) - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractOperatorBackendStateMetaInfoWriter
 
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(MemorySegment, int, int) - Constructor for class org.apache.flink.runtime.memory.AbstractPagedInputView
Creates a new view that starts with the given segment.
AbstractPagedInputView(int) - Constructor for class org.apache.flink.runtime.memory.AbstractPagedInputView
Creates a new view that is initially not bound to a memory segment.
AbstractPagedOutputView - Class in org.apache.flink.runtime.memory
The base class for all output views that are backed by multiple memory pages.
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.
AbstractPagedOutputView(int, int) - Constructor for class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
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
 
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 and ResponseBodys.
AbstractRestHandler(CompletableFuture<String>, GatewayRetriever<? extends T>, Time, Map<String, String>, MessageHeaders<R, P, M>) - Constructor for class org.apache.flink.runtime.rest.handler.AbstractRestHandler
 
AbstractStateBackend - Class in org.apache.flink.runtime.state
An abstract base implementation of the StateBackend interface.
AbstractStateBackend() - Constructor for class org.apache.flink.runtime.state.AbstractStateBackend
 
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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, 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.
AbstractSubtaskAttemptRequestHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Base class for request handlers whose response depends on a specific subtask execution attempt (defined via the "attempt" parameter) of a specific subtask (defined via the "subtasknum" parameter) in a specific job vertex (defined via the "vertexid" parameter) in a specific job, defined via (defined voa the "jobid" parameter).
AbstractSubtaskAttemptRequestHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.AbstractSubtaskAttemptRequestHandler
 
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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, 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.
AbstractSubtaskRequestHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Base class for request handlers whose response depends on a specific subtask (defined via the "subtasknum" parameter) in a specific job vertex (defined via the "vertexid" parameter) in a specific job, defined via (defined voa the "jobid" parameter).
AbstractSubtaskRequestHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.AbstractSubtaskRequestHandler
 
AbstractTaskManagerFileHandler<M extends TaskManagerMessageParameters> - Class in org.apache.flink.runtime.rest.handler.taskmanager
Base class for serving files from the TaskExecutor.
AbstractTaskManagerFileHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, UntypedResponseMessageHeaders<EmptyRequestBody, M>, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, Time) - Constructor for class org.apache.flink.runtime.rest.handler.taskmanager.AbstractTaskManagerFileHandler
 
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 Execution and {@link ArchivedExecution}.
AccessExecutionGraph - Interface in org.apache.flink.runtime.executiongraph
Common interface for the runtime ExecutionGraph and ArchivedExecutionGraph.
AccessExecutionJobVertex - Interface in org.apache.flink.runtime.executiongraph
Common interface for the runtime ExecutionJobVertex and ArchivedExecutionJobVertex.
AccessExecutionVertex - Interface in org.apache.flink.runtime.executiongraph
Common interface for the runtime ExecutionVertex and ArchivedExecutionVertex.
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.
acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointCoordinatorGateway
 
acknowledgeCheckpoint(long, CheckpointMetrics) - Method in interface org.apache.flink.runtime.execution.Environment
Confirms that the invokable has successfully completed all steps it needed to to for the checkpoint with the give checkpoint-ID.
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(JobID, ExecutionAttemptID, long, CheckpointMetrics, 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 TaskManager to the JobManager to signal that the checkpoint of an individual task is completed.
AcknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Constructor for class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
 
AcknowledgeCheckpoint(JobID, ExecutionAttemptID, long) - Constructor for class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
 
acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcCheckpointResponder
 
acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayCheckpointResponder
 
acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, TaskStateSnapshot) - Method in interface org.apache.flink.runtime.taskmanager.CheckpointResponder
Acknowledges the given checkpoint.
acknowledgeCheckpoint(long, CheckpointMetrics) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
acknowledgeCheckpoint(long, CheckpointMetrics, TaskStateSnapshot) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
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.
acquireResources() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
Open the IO Handle (e.g.
actor() - Method in interface org.apache.flink.runtime.instance.ActorGateway
Returns the underlying actor with which is communicated
actor() - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
Returns ActorRef of the target actor
ActorGateway - Interface in org.apache.flink.runtime.instance
Interface to abstract the communication with an actor.
ActorGatewayCheckpointResponder - Class in org.apache.flink.runtime.taskmanager
Implementation using ActorGateway to forward the messages.
ActorGatewayCheckpointResponder(ActorGateway) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayCheckpointResponder
 
ActorGatewayKvStateLocationOracle - Class in org.apache.flink.runtime.taskmanager
ActorGatewayKvStateLocationOracle(ActorGateway, Time) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayKvStateLocationOracle
 
ActorGatewayKvStateRegistryListener - Class in org.apache.flink.runtime.taskmanager
This implementation uses ActorGateway to forward key-value state notifications to the job manager.
ActorGatewayKvStateRegistryListener(ActorGateway, InetSocketAddress) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayKvStateRegistryListener
 
ActorGatewayPartitionProducerStateChecker - Class in org.apache.flink.runtime.taskmanager
This implementation uses ActorGateway to trigger the partition state check at the job manager.
ActorGatewayPartitionProducerStateChecker(ActorGateway, FiniteDuration) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayPartitionProducerStateChecker
 
ActorGatewayResultPartitionConsumableNotifier - Class in org.apache.flink.runtime.taskmanager
This implementation uses ActorGateway to notify the job manager about consumable partitions.
ActorGatewayResultPartitionConsumableNotifier(ExecutionContext, ActorGateway, FiniteDuration) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayResultPartitionConsumableNotifier
 
ActorGatewayTaskExecutionStateListener - Class in org.apache.flink.runtime.taskmanager
Implementation using ActorGateway to forward the messages.
ActorGatewayTaskExecutionStateListener(ActorGateway) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayTaskExecutionStateListener
 
ActorGatewayTaskManagerActions - Class in org.apache.flink.runtime.taskmanager
Implementation using ActorGateway to forward the messages.
ActorGatewayTaskManagerActions(ActorGateway) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayTaskManagerActions
 
ActorSystemScheduledExecutorAdapter - Class in org.apache.flink.runtime.concurrent.akka
Adapter to use a ActorSystem as a ScheduledExecutor.
ActorSystemScheduledExecutorAdapter(ActorSystem) - Constructor for class org.apache.flink.runtime.concurrent.akka.ActorSystemScheduledExecutorAdapter
 
ActorTaskManagerGateway - Class in org.apache.flink.runtime.jobmanager.slots
Implementation of the TaskManagerGateway for ActorGateway.
ActorTaskManagerGateway(ActorGateway) - Constructor for class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
ActorUtils - Class in org.apache.flink.runtime.akka
Utility functions for the interaction with Akka Actor.
actualModVersion() - Method in exception org.apache.flink.runtime.executiongraph.GlobalModVersionMismatch
 
add(T) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
 
add(BufferConsumer) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
Adds the given buffer.
add(MetricDump) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
 
add(IN) - Method in class org.apache.flink.runtime.state.heap.HeapAggregatingState
 
add(T) - Method in class org.apache.flink.runtime.state.heap.HeapFoldingState
Deprecated.
 
add(V) - Method in class org.apache.flink.runtime.state.heap.HeapListState
 
add(V) - Method in class org.apache.flink.runtime.state.heap.HeapReducingState
 
add(Task) - 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.EvictingBoundedList
 
add(int) - Method in class org.apache.flink.runtime.util.IntArrayList
 
add(long) - Method in class org.apache.flink.runtime.util.LongArrayList
 
addAll(Collection<? extends T>) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
 
addAll(List<V>) - Method in class org.apache.flink.runtime.state.heap.HeapListState
 
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.
addAndLock(String, T) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Creates a state handle, stores it in ZooKeeper and locks it.
addAppConfigurationEntry(String, AppConfigurationEntry...) - Method in class org.apache.flink.runtime.security.DynamicConfiguration
Add entries for the given application name.
addBlob(PermanentBlobKey) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Adds the BLOB referenced by the key to the JobGraph's dependencies.
addBroadcastInputToGroup(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
addBufferConsumer(BufferConsumer, int) - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
Adds the bufferConsumer to the subpartition with the given index.
addBufferConsumer(BufferConsumer, int) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
 
addBufferListener(BufferListener) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
Adds a buffer availability listener to the buffer provider.
addChainedTask(Class<? extends ChainedDriver>, TaskConfig, String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
addCheckpoint(CompletedCheckpoint) - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
Adds a CompletedCheckpoint instance to the list of completed checkpoints.
addCheckpoint(CompletedCheckpoint) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
addCheckpoint(CompletedCheckpoint) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
Synchronously writes the new checkpoints to ZooKeeper and asynchronously removes older ones.
addClass(Class<?>) - Method in class org.apache.flink.runtime.util.JarFileCreator
Adds a Class object to the set of classes which shall eventually be included in the jar file.
addConsumer(JobEdge) - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
 
addCredit(int) - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
The credits from consumer are added in incremental way.
addGroup(int) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
addGroup(String) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
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(int) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
addGroup(String) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
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
 
addInputChannel(RemoteInputChannel) - Method in interface org.apache.flink.runtime.io.network.NetworkClientHandler
 
addInputToGroup(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
addInstanceListener(InstanceListener) - Method in class org.apache.flink.runtime.instance.InstanceManager
 
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.
addJob(JobGraph) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
addJob(JobGraph) - Method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredJobManagerMetricGroup
 
addJob(JobID) - Method in class 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.taskexecutor.JobLeaderService
Add the given job to be monitored.
addMasterHook(MasterTriggerRestoreHook<?>) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Adds the given master hook to the checkpoint coordinator.
addMasterState(MasterState) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
Adds a master state (state generated on the checkpoint coordinator) to the pending checkpoint.
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.
addNameSpace(Set<String>) - Method in class org.apache.flink.runtime.util.DependencyVisitor
 
addOperator(String) - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
addOperator(OperatorID, String) - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
addOperator(OperatorID, String) - Method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredTaskMetricGroup
 
addOutputShipStrategy(ShipStrategyType) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
addPackage(String) - Method in class org.apache.flink.runtime.util.JarFileCreator
Manually specify the package of the dependencies.
addPackages(String[]) - Method in class org.apache.flink.runtime.util.JarFileCreator
Manually specify the packages of the dependencies.
addRecord(T) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
Starts serializing and copying the given record to the target buffer (if available).
addRecord(T) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
Serializes the complete record to an intermediate data serialization buffer and starts copying it to the target buffer (if available).
addRecord(T) - Method in class org.apache.flink.runtime.operators.sort.LargeRecordHandler
 
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.
addSharedSlotAndAllocateSubSlot(SharedSlot, Locality, JobVertexID) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
 
addSharedSlotAndAllocateSubSlot(SharedSlot, Locality, CoLocationConstraint) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
 
addTask(JobVertexID, ExecutionAttemptID, String, int, int) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
 
addTask(JobVertexID, ExecutionAttemptID, String, int, int) - Method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredTaskManagerJobMetricGroup
 
addTask(Task) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Add the given task to the slot identified by the task's allocation id.
addTaskForJob(JobID, String, JobVertexID, ExecutionAttemptID, String, int, int) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
addTaskForJob(JobID, String, JobVertexID, ExecutionAttemptID, String, int, int) - Method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredTaskManagerMetricGroup
 
addToMessageDigest(MessageDigest) - Method in class org.apache.flink.runtime.blob.BlobKey
Adds the BLOB key to the given MessageDigest.
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.CoLocationGroup
 
addVertexToGroup(JobVertexID) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
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.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.
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, Double, Double, Double, Double) - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
 
AggregatedMetric(String) - 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
 
AggregatedTaskManagerMetricsHeaders - Class in org.apache.flink.runtime.rest.messages.job.metrics
Headers for aggregating task manager metrics.
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.ExecutionGraph
Merges all accumulator results from the tasks previously executed in the Executions.
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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, Executor, MetricFetcher<?>) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.AggregatingJobsMetricsHandler
 
AggregatingJobsMetricsHandler - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
Request handler that returns, aggregated across all jobs, a list of all available metrics or the values for a set of metrics.
AggregatingJobsMetricsHandler(Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.metrics.AggregatingJobsMetricsHandler
 
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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, Executor, MetricFetcher<?>) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.AggregatingSubtasksMetricsHandler
 
AggregatingSubtasksMetricsHandler - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
Request handler that returns, aggregated across all subtasks, a list of all available metrics or the values for a set of metrics.
AggregatingSubtasksMetricsHandler(Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, Executor, MetricFetcher<?>) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.AggregatingTaskManagersMetricsHandler
 
AggregatingTaskManagersMetricsHandler - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
Request handler that returns, aggregated across all task managers, a list of all available metrics or the values for a set of metrics.
AggregatingTaskManagersMetricsHandler(Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.metrics.AggregatingTaskManagersMetricsHandler
 
AGGREGATOR_NAME - Static variable in class org.apache.flink.runtime.iterative.convergence.WorksetEmptyConvergenceCriterion
 
AkkaActorGateway - Class in org.apache.flink.runtime.instance
Concrete ActorGateway implementation which uses Akka to communicate with remote actors.
AkkaActorGateway(ActorRef, UUID) - Constructor for class org.apache.flink.runtime.instance.AkkaActorGateway
 
AkkaHandshakeException - Exception in org.apache.flink.runtime.rpc.akka.exceptions
Exception which is thrown if the handshake fails.
AkkaHandshakeException(String) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaHandshakeException
 
AkkaHandshakeException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaHandshakeException
 
AkkaHandshakeException(Throwable) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaHandshakeException
 
AkkaJobManagerGateway - Class in org.apache.flink.runtime.akka
Implementation of the JobManagerGateway for old JobManager code based on Akka actors and the ActorGateway.
AkkaJobManagerGateway(ActorGateway) - Constructor for class org.apache.flink.runtime.akka.AkkaJobManagerGateway
 
AkkaJobManagerRetriever - Class in org.apache.flink.runtime.webmonitor.retriever.impl
LeaderGatewayRetriever implementation for Akka based JobManagers.
AkkaJobManagerRetriever(ActorSystem, Time, int, Time) - Constructor for class org.apache.flink.runtime.webmonitor.retriever.impl.AkkaJobManagerRetriever
 
AkkaQueryServiceGateway - Class in org.apache.flink.runtime.webmonitor.retriever.impl
MetricQueryServiceGateway implementation for Akka based MetricQueryService.
AkkaQueryServiceGateway(ActorRef) - Constructor for class org.apache.flink.runtime.webmonitor.retriever.impl.AkkaQueryServiceGateway
 
AkkaQueryServiceRetriever - Class in org.apache.flink.runtime.webmonitor.retriever.impl
MetricQueryServiceRetriever implementation for Akka based MetricQueryService.
AkkaQueryServiceRetriever(ActorSystem, Time) - Constructor for class org.apache.flink.runtime.webmonitor.retriever.impl.AkkaQueryServiceRetriever
 
AkkaRpcException - Exception in org.apache.flink.runtime.rpc.akka.exceptions
Base class for Akka RPC related exceptions.
AkkaRpcException(String) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaRpcException
 
AkkaRpcException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaRpcException
 
AkkaRpcException(Throwable) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaRpcException
 
AkkaRpcService - Class in org.apache.flink.runtime.rpc.akka
Akka based RpcService implementation.
AkkaRpcService(ActorSystem, Time) - Constructor for class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
AkkaRpcServiceUtils - Class in org.apache.flink.runtime.rpc.akka
These RPC utilities contain helper methods around RPC use, such as starting an RPC service, or constructing RPC addresses.
AkkaRpcServiceUtils.AkkaProtocol - Enum in org.apache.flink.runtime.rpc.akka
 
AkkaUnknownMessageException - Exception in org.apache.flink.runtime.rpc.akka.exceptions
Exception which indicates that the AkkaRpcActor has received an unknown message type.
AkkaUnknownMessageException(String) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaUnknownMessageException
 
AkkaUnknownMessageException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaUnknownMessageException
 
AkkaUnknownMessageException(Throwable) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaUnknownMessageException
 
AlignmentLimitExceededException - Exception in org.apache.flink.runtime.checkpoint.decline
Exception indicating that a checkpoint was declined because too many bytes were buffered in the alignment phase.
AlignmentLimitExceededException(long) - Constructor for exception org.apache.flink.runtime.checkpoint.decline.AlignmentLimitExceededException
 
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
 
allocate(JobID, AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Allocate the task slot for the given job and allocation id.
allocateAndAssignSlotForExecution(SlotProvider, boolean, LocationPreferenceConstraint, Time) - Method in class org.apache.flink.runtime.executiongraph.Execution
Allocates and assigns a slot obtained from the slot provider to the execution.
AllocatedSlotActions - Interface in org.apache.flink.runtime.jobmaster.slotpool
Interface for components which have to perform actions on allocated slots.
allocatePages(Object, int) - Method in class org.apache.flink.runtime.memory.MemoryManager
Allocates a set of memory segments from this memory manager.
allocatePages(Object, List<MemorySegment>, int) - Method in class org.apache.flink.runtime.memory.MemoryManager
Allocates a set of memory segments from this memory manager.
allocateResource(ResourceProfile) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerServices
Allocates a resource according to the resource profile.
allocateResource(ResourceProfile) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ResourceActions
Requests to allocate a resource with the given ResourceProfile.
allocateResourcesForAll(SlotProvider, boolean, LocationPreferenceConstraint, Time) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
Acquires a slot for all the execution vertices of this ExecutionJobVertex.
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
allocateSharedSlot(SlotSharingGroupAssignment) - Method in class org.apache.flink.runtime.instance.Instance
Allocates a shared slot on this TaskManager instance.
allocateSimpleSlot() - Method in class org.apache.flink.runtime.instance.Instance
Allocates a simple slot on this TaskManager instance.
allocateSlot(SlotRequestId, ScheduledUnit, boolean, SlotProfile, Time) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
allocateSlot(SlotRequestId, ScheduledUnit, SlotProfile, boolean, Time) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
 
allocateSlot(SlotRequestId, ScheduledUnit, SlotProfile, boolean, Time) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolGateway
Requests to allocate a slot for the given ScheduledUnit.
allocateSlot(SlotRequestId, ScheduledUnit, boolean, SlotProfile, Time) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotProvider
Allocating slot with specific requirement.
allocateSlot(ScheduledUnit, boolean, SlotProfile, Time) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotProvider
Allocating slot with specific requirement.
allocateSlot(int, JobID, AllocationID, Time) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Allocate the slot with the given index for the given job and allocation id.
allocationBaseDirectory(long) - Method in interface org.apache.flink.runtime.state.LocalRecoveryDirectoryProvider
Returns the local state allocation base directory for given checkpoint id w.r.t.
allocationBaseDirectory(long) - Method in class org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
 
allocationBaseDirsCount() - Method in interface org.apache.flink.runtime.state.LocalRecoveryDirectoryProvider
Returns the total number of allocation base directories.
allocationBaseDirsCount() - Method in class org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
 
allocationFuture - Variable in class org.apache.flink.runtime.executiongraph.ExecutionAndAllocationFuture
 
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.
allowLazyDeployment() - Method in enum org.apache.flink.runtime.jobgraph.ScheduleMode
Returns whether we are allowed to deploy consumers lazily.
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
 
allStartedWorkers() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Gets an iterable for all currently started TaskManagers.
AllWorkersDoneEvent - Class in org.apache.flink.runtime.iterative.event
Event sent by the IterationSynchronizationSinkTask to each IterationHead signaling 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
 
AnnotationVisitorImpl(int) - Constructor for class org.apache.flink.runtime.util.DependencyVisitor.AnnotationVisitorImpl
 
append(ByteBuffer) - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
Append as many data as possible from source.
appendAndCommit(ByteBuffer) - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
Same as BufferBuilder.append(ByteBuffer) but additionally BufferBuilder.commit() the appending.
appendRecord(T) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
Inserts the given object into the current buffer.
ApplicationStatus - Enum in org.apache.flink.runtime.clusterframework
The status of an application.
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(I) - Method in interface org.apache.flink.runtime.util.EvictingBoundedList.Function
Transforms the value.
apply(RetrievableStateHandle<T>) - Method in interface org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore.RemoveCallback
Callback method.
applyRepartitioner(OperatorID, OperatorStateRepartitioner, List<OperatorStateHandle>, int, int) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
 
applyRepartitioner(OperatorStateRepartitioner, List<OperatorStateHandle>, int, int) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
Repartitions the given operator state using the given OperatorStateRepartitioner with respect to the new parallelism.
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 class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
applyToAllKeys(N, TypeSerializer<N>, StateDescriptor<S, T>, KeyedStateFunction<K, S>) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
Applies the provided KeyedStateFunction to the state with the provided StateDescriptor of all the currently active keys.
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_NAME - Static variable in class org.apache.flink.runtime.jobmaster.JobMaster
 
ArchivedExecution - Class in org.apache.flink.runtime.executiongraph
 
ArchivedExecution(Execution) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecution
 
ArchivedExecution(StringifiedAccumulatorResult[], IOMetrics, ExecutionAttemptID, int, ExecutionState, String, TaskManagerLocation, int, long[]) - 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 the ExecutionGraph.
ArchivedExecutionGraph(JobID, String, Map<JobVertexID, ArchivedExecutionJobVertex>, List<ArchivedExecutionJobVertex>, long[], JobStatus, ErrorInfo, String, StringifiedAccumulatorResult[], Map<String, SerializedValue<OptionalFailure<Object>>>, ArchivedExecutionConfig, boolean, CheckpointCoordinatorConfiguration, CheckpointStatsSnapshot) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
ArchivedExecutionGraphStore - Interface in org.apache.flink.runtime.dispatcher
Interface for a ArchivedExecutionGraph store.
ArchivedExecutionJobVertex - Class in org.apache.flink.runtime.executiongraph
 
ArchivedExecutionJobVertex(ExecutionJobVertex) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
 
ArchivedExecutionJobVertex(ArchivedExecutionVertex[], JobVertexID, String, int, int, StringifiedAccumulatorResult[]) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
 
ArchivedExecutionVertex - Class in org.apache.flink.runtime.executiongraph
 
ArchivedExecutionVertex(ExecutionVertex) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
ArchivedExecutionVertex(int, String, ArchivedExecution, EvictingBoundedList<ArchivedExecution>) - 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(AccessExecutionGraph) - Method in interface org.apache.flink.runtime.dispatcher.HistoryServerArchivist
Archives the given AccessExecutionGraph on the history server.
archiveJob(Path, AccessExecutionGraph) - Static method in class org.apache.flink.runtime.history.FsJobArchivist
Deprecated.
only kept for legacy reasons
archiveJob(Path, JobID, Collection<ArchivedJson>) - Static method in class org.apache.flink.runtime.history.FsJobArchivist
Writes the given AccessExecutionGraph to the FileSystem pointed to by JobManagerOptions.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.JobExceptionsHandler
 
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 class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointConfigHandler.CheckpointConfigJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsDetailsHandler.CheckpointStatsDetailsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsDetailsSubtasksHandler.CheckpointStatsDetailsSubtasksJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsHandler.CheckpointStatsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobAccumulatorsHandler.JobAccumulatorsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobConfigHandler.JobConfigJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobDetailsHandler.JobDetailsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobExceptionsHandler.JobExceptionsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobPlanHandler.JobPlanJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobsOverviewHandler.CurrentJobsOverviewJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexAccumulatorsHandler.JobVertexAccumulatorsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexDetailsHandler.JobVertexDetailsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexTaskManagersHandler.JobVertexTaskManagersJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptAccumulatorsHandler.SubtaskExecutionAttemptAccumulatorsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptDetailsHandler.SubtaskExecutionAttemptDetailsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtasksAllAccumulatorsHandler.SubtasksAllAccumulatorsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtasksTimesHandler.SubtasksTimesJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in interface org.apache.flink.runtime.webmonitor.history.JsonArchivist
Returns a Collection of ArchivedJsons containing JSON responses and their respective REST URL for a given job.
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
 
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
 
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
 
Artifact(Path, Path, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
asByteBuf() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
 
asByteBuf() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
asByteBuf() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
ask(Object, FiniteDuration) - Method in interface org.apache.flink.runtime.instance.ActorGateway
Sends a message asynchronously and returns its response.
ask(Object, FiniteDuration) - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
Sends a message asynchronously and returns its response.
ask(Object, Time) - Method in class org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
 
assignExclusiveSegments(NetworkBufferPool, int) - 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.
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.
assignPendingSlotRequest(PendingSlotRequest) - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
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
 
assignStates() - Method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
 
assignToKeyGroup(Object, int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
Assigns the given key to a key-group index.
asVariable(String) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
Formats the given string to resemble a scope variable.
AsyncDoneCallback - Interface in org.apache.flink.runtime.io.async
Callback for an asynchronous operation that is called on termination
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 BlockChannelWriterWithCallback that 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
 
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 JobID and TriggerId used 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
 
AsyncStoppable - Interface in org.apache.flink.runtime.io.async
An asynchronous operation that can be stopped.
AsyncStoppableTaskWithCallback<V> - Class in org.apache.flink.runtime.io.async
 
AsyncStoppableTaskWithCallback(StoppableCallbackCallable<V>) - Constructor for class org.apache.flink.runtime.io.async.AsyncStoppableTaskWithCallback
 
AtomicDisposableReferenceCounter - Class in org.apache.flink.runtime.util
Atomic reference counter, which enters a "disposed" state after it reaches a configurable reference count (default 0).
AtomicDisposableReferenceCounter() - Constructor for class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
 
AtomicDisposableReferenceCounter(int) - Constructor for class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
 
attachJobGraph(List<JobVertex>) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
attachToRunningJob(JobID, Configuration, ActorSystem, HighAvailabilityServices, FiniteDuration, boolean) - Static method in class org.apache.flink.runtime.client.JobClient
Attaches to a running Job using the JobID.
attemptNumber() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
available() - Method in class org.apache.flink.runtime.state.BoundedInputStream
 
available() - Method in class org.apache.flink.runtime.util.ForwardingInputStream
 
availableMemory - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The free memory segments currently available to the hash join.
awaitJobResult(JobListeningContext) - Static method in class org.apache.flink.runtime.client.JobClient
Given a JobListeningContext, awaits the result of the job execution that this context is bound to
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
 
BackendWritableBroadcastState<K,V> - Interface in org.apache.flink.runtime.state
An interface with methods related to the interplay between the Broadcast State and the OperatorStateBackend.
BackPressureStatsTracker - Interface in org.apache.flink.runtime.rest.handler.legacy.backpressure
Interface for a tracker of back pressure statistics for ExecutionJobVertex.
BackPressureStatsTrackerImpl - Class in org.apache.flink.runtime.rest.handler.legacy.backpressure
Back pressure statistics tracker.
BackPressureStatsTrackerImpl(StackTraceSampleCoordinator, int, int, int, Time) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTrackerImpl
Creates a back pressure statistics tracker.
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.
bindVariables(String[], String[]) - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
BitSet - Class in org.apache.flink.runtime.operators.util
 
BitSet(int) - Constructor for class org.apache.flink.runtime.operators.util.BitSet
 
bitSet - Variable in class org.apache.flink.runtime.operators.util.BloomFilter
 
BitSet(int) - Constructor for class org.apache.flink.runtime.operators.util.BloomFilter.BitSet
 
bitSize() - Method in class org.apache.flink.runtime.operators.util.BitSet
Number of bits
bitSize() - Method in class org.apache.flink.runtime.operators.util.BloomFilter.BitSet
Number of bits
BlobCacheService - Class in org.apache.flink.runtime.blob
The BLOB cache provides access to BLOB services for permanent and transient BLOBs.
BlobCacheService(Configuration, 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.
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 PermanentBlobService and create a class loader with references to them.
BlobLibraryCacheManager(PermanentBlobService, FlinkUserCodeClassLoaders.ResolveOrder, String[]) - Constructor for class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
BlobServer - Class in org.apache.flink.runtime.blob
This class implements the BLOB server.
BlobServer(Configuration, 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
Defines constants for the protocol between the BLOB server and the caches.
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.
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
 
blockHeadCopy - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
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.
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
 
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
 
BloomFilter.BitSet - Class in org.apache.flink.runtime.operators.util
Bare metal bit set implementation.
BootstrapTools - Class in org.apache.flink.runtime.clusterframework
Tools for starting JobManager and TaskManager processes, including the Actor Systems used to run the JobManager and TaskManager actors.
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
 
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.RecordWriter
 
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.
broadcastStateMetaInfo - Variable in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractBroadcastStateMetaInfoWriter
 
BroadcastStateMetaInfoReaderV3(ClassLoader) - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.BroadcastStateMetaInfoReaderV3
 
BroadcastStateMetaInfoWriterV3(RegisteredBroadcastBackendStateMetaInfo.Snapshot<K, V>) - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.BroadcastStateMetaInfoWriterV3
 
BroadcastVariableKey - Class in org.apache.flink.runtime.broadcast
An identifier for a BroadcastVariableMaterialization based on the task's JobVertexID, 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 - Interface in org.apache.flink.runtime.io.network.buffer
Wrapper for pooled MemorySegment instances with reference counting.
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 - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
buffer - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
BufferAndAvailability(Buffer, boolean, int) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputChannel.BufferAndAvailability
 
BufferAndBacklog(Buffer, boolean, int, boolean) - 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 ResultSubpartitionView that 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
 
BufferConsumer - Class in org.apache.flink.runtime.io.network.buffer
Not thread safe class for producing Buffer.
BufferConsumer(MemorySegment, BufferRecycler, BufferBuilder.PositionMarker) - Constructor for class org.apache.flink.runtime.io.network.buffer.BufferConsumer
Constructs BufferConsumer instance with content that can be changed by BufferBuilder.
BufferConsumer(MemorySegment, BufferRecycler, boolean) - Constructor for class org.apache.flink.runtime.io.network.buffer.BufferConsumer
Constructs BufferConsumer instance with static content.
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
 
BufferListener - Interface in org.apache.flink.runtime.io.network.buffer
Interface of the availability of buffers.
BufferOrEvent - Class in org.apache.flink.runtime.io.network.partition.consumer
Either type for Buffer or AbstractEvent instances tagged with the channel index, from which they were received.
BufferOrEvent(Buffer, int) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
BufferOrEvent(AbstractEvent, int) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
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.
BufferPoolOwner - Interface in org.apache.flink.runtime.io.network.buffer
 
BufferProvider - Interface in org.apache.flink.runtime.io.network.buffer
A buffer provider to request buffers from in a synchronous or asynchronous fashion.
BufferRecycler - Interface in org.apache.flink.runtime.io.network.buffer
 
buffers - Variable in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
All buffers of this subpartition.
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
 
build() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState.Builder
 
build() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
build() - Method in class org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay.Builder
 
build() - Method in class org.apache.flink.runtime.clusterframework.overlays.HadoopConfOverlay.Builder
 
build() - Method in class org.apache.flink.runtime.clusterframework.overlays.HadoopUserOverlay.Builder
 
build() - Method in class org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay.Builder
 
build() - Method in class org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay.Builder
 
build() - Method in class org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay.Builder
 
build() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
 
build() - Method in class org.apache.flink.runtime.jobmaster.JobResult.Builder
 
build() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
 
buildBloomFilterForBucketsInPartition(int, HashPartition<BT, PT>) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
Builder(OperatorSubtaskState, List<OperatorSubtaskState>) - Constructor for class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState.Builder
 
Builder(OperatorSubtaskState, List<OperatorSubtaskState>, boolean) - Constructor for class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState.Builder
 
Builder() - Constructor for class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
Builder() - Constructor for class org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay.Builder
 
Builder() - Constructor for class org.apache.flink.runtime.clusterframework.overlays.HadoopConfOverlay.Builder
 
Builder() - Constructor for class org.apache.flink.runtime.clusterframework.overlays.HadoopUserOverlay.Builder
 
Builder() - Constructor for class org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay.Builder
 
Builder() - Constructor for class org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay.Builder
 
Builder() - Constructor for class org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay.Builder
 
Builder() - Constructor for class org.apache.flink.runtime.jobmaster.JobResult.Builder
 
Builder() - Constructor for class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
 
BuildFirstCachedJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
 
BuildFirstCachedJoinDriver() - Constructor for class org.apache.flink.runtime.operators.BuildFirstCachedJoinDriver
 
buildGraph(ExecutionGraph, JobGraph, Configuration, ScheduledExecutorService, Executor, SlotProvider, ClassLoader, CheckpointRecoveryFactory, Time, RestartStrategy, MetricGroup, BlobWriter, Time, Logger) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionGraphBuilder
Builds the ExecutionGraph from the JobGraph.
buildGraph(ExecutionGraph, JobGraph, Configuration, ScheduledExecutorService, Executor, SlotProvider, ClassLoader, CheckpointRecoveryFactory, Time, RestartStrategy, MetricGroup, int, BlobWriter, Time, Logger) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionGraphBuilder
Deprecated.
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
 
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

cachable - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
cachable - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
cachePartitionInfo(PartialInputChannelDeploymentDescriptor) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
calculateCutoffMB(Configuration, long) - Static method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
Calcuate cutoff memory size used by container, it will throw an IllegalArgumentException if the config is invalid or return the cutoff value if valid.
calculateHeapSizeMB(long, Configuration) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
Calculates the amount of heap memory to use (to set via -Xmx and -Xms) based on the total memory to use and the given configuration parameters.
calculateNetworkBufferMemory(long, Configuration) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
Calculates the amount of memory used for network buffers based on the total memory to use and the according configuration parameters.
calculateNetworkBufferMemory(TaskManagerServicesConfiguration, long) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
Calculates the amount of memory used for network buffers inside the current JVM instance based on the available heap or the max heap size and the according configuration parameters.
calculatePreferredLocations(LocationPreferenceConstraint) - Method in class org.apache.flink.runtime.executiongraph.Execution
Calculates the preferred locations based on the location preference constraint.
call() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
This method implements the strategy for the actual IO operation:
callAsync(Callable<V>, Time) - Method in interface org.apache.flink.runtime.rpc.MainThreadExecutable
Execute the callable in the main thread of the underlying RPC endpoint and return a future for the callable result.
CallAsync - Class in org.apache.flink.runtime.rpc.messages
Message for asynchronous callable invocations
CallAsync(Callable<?>) - Constructor for class org.apache.flink.runtime.rpc.messages.CallAsync
 
callAsync(Callable<V>, Time) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Execute the callable in the main thread of the underlying RPC service, returning a future for the result of the callable.
callAsyncWithoutFencing(Callable<V>, Time) - Method in class org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
 
callAsyncWithoutFencing(Callable<V>, Time) - Method in interface org.apache.flink.runtime.rpc.FencedMainThreadExecutable
Run the given callable in the main thread without attaching a fencing token.
callAsyncWithoutFencing(Callable<V>, Time) - Method in class org.apache.flink.runtime.rpc.FencedRpcEndpoint
Run the given callable in the main thread of the RpcEndpoint without checking the fencing token.
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<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 interface org.apache.flink.runtime.operators.util.JoinTaskIterator
Moves the internal pointer to the next key that both inputs share.
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(boolean) - Method in class org.apache.flink.runtime.concurrent.FutureUtils.ConjunctFuture
 
cancel() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
cancel() - Method in class 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
 
cancel(boolean) - Method in class org.apache.flink.runtime.io.async.AsyncStoppableTaskWithCallback
 
cancel() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
cancel() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
This method is called when a task is canceled either as a result of a user abort or an execution failure.
cancel(Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
cancel(Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Cancels the currently executed job.
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(boolean) - Method in class org.apache.flink.runtime.state.DoneFuture
 
cancelAndReleaseAllSlots() - Method in class org.apache.flink.runtime.instance.Instance
 
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
 
cancelExecution() - Method in class org.apache.flink.runtime.taskmanager.Task
Cancels the task execution.
cancelJob(JobID, Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
 
cancelJob(JobID, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
cancelJob(JobID, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerGateway
Cancels the given job.
cancelJob(JobID) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
 
cancelJob(JobID, Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
Cancel the given job.
cancelJobWithSavepoint(JobID, String, Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
 
cancelJobWithSavepoint(JobID, String, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerGateway
Cancels the given job after taking a savepoint and returning its path.
cancelRequestFor(InputChannelID) - Method in interface org.apache.flink.runtime.io.network.NetworkClientHandler
 
cancelSlotRequest(SlotRequestId, SlotSharingGroupId, Throwable) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
cancelSlotRequest(SlotRequestId, SlotSharingGroupId, Throwable) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotProvider
Cancels the slot request with the given SlotRequestId and SlotSharingGroupId.
cancelSlotRequest(AllocationID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
cancelSlotRequest(AllocationID) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Cancel the slot allocation requests from the resource manager.
cancelStackTraceSample(int, Throwable) - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator
Cancels a pending sample.
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
cancelTask(ExecutionAttemptID, Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
cancelTask(ExecutionAttemptID, Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Cancel the given task.
cancelTask(ExecutionAttemptID, Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
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.ChainedTerminationCriterionDriver
 
cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
 
cancelTask() - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
 
cancelTask(ExecutionAttemptID, Time) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
cancelTask(ExecutionAttemptID, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Cancel the given task.
CancelTaskException - Exception in org.apache.flink.runtime.execution
Thrown to trigger a canceling of the executing task.
CancelTaskException(Throwable) - Constructor for exception org.apache.flink.runtime.execution.CancelTaskException
 
CancelTaskException(String) - Constructor for exception org.apache.flink.runtime.execution.CancelTaskException
 
CancelTaskException() - 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.
canEqual(Object) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
canEqual(Object) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
 
canEqual(Object) - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
 
canRestart() - Method in class org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy
 
canRestart() - Method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
 
canRestart() - Method in class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
 
canRestart() - Method in interface org.apache.flink.runtime.executiongraph.restart.RestartStrategy
True if the restart strategy can be applied to restart the ExecutionGraph.
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
 
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
 
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.
ChainedTerminationCriterionDriver<IT,OT> - Class in org.apache.flink.runtime.operators.chaining
 
ChainedTerminationCriterionDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
 
channelIndex - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
 
channelRead0(ChannelHandlerContext, HttpObject) - Method in class org.apache.flink.runtime.rest.FileUploadHandler
 
channelRead0(ChannelHandlerContext, Routed) - Method in class org.apache.flink.runtime.rest.handler.legacy.ConstantTextHandler
 
channelRead0(ChannelHandlerContext, HttpRequest) - Method in class org.apache.flink.runtime.rest.handler.PipelineErrorHandler
 
channelRead0(ChannelHandlerContext, Routed) - Method in class org.apache.flink.runtime.rest.handler.RedirectHandler
 
ChannelReaderInputView - Class in org.apache.flink.runtime.io.disk.iomanager
A DataInputView that is backed by a BlockChannelReader, 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(IOManager, FileIOChannel.ID, 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(BlockChannelReader<MemorySegment>, LinkedBlockingQueue<MemorySegment>, List<MemorySegment>, List<MemorySegment>, TypeSerializer<E>, int) - Constructor for class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
 
ChannelReaderInputViewIterator(ChannelReaderInputView, List<MemorySegment>, TypeSerializer<E>) - 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 ChannelSelector determines to which logical channels a record should be written to.
ChannelWithBlockCount(FileIOChannel.ID, int) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ChannelWithBlockCount
 
ChannelWriterOutputView - Class in org.apache.flink.runtime.io.disk.iomanager
A DataOutputView that is backed by a BlockChannelWriter, making it effectively a data output stream.
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.
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.
CheckAndAllocateContainers - Class in org.apache.flink.runtime.clusterframework.messages
This message signals the resource master to check how many TaskManagers are desired, how many are available, and to trigger adjustments if needed.
checkErroneous() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
Checks the exception state of this channel.
checkError() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
Checks for an error and rethrows it if one was reported.
checkNetworkBufferConfig(int, float, long, long) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
Validates the (new) network buffer configuration.
checkNetworkConfigOld(int) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
Validates the (old) network buffer configuration.
checkNotShutdown() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
checkParallelismPreconditions(List<OperatorState>, ExecutionJobVertex) - Method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
 
checkParallelismPreconditions(int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
 
CHECKPOINT_DIR_PREFIX - Static variable in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
The prefix of the directory containing the data exclusive to a checkpoint.
CHECKPOINT_SHARED_STATE_DIR - Static variable in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
The name of the directory for shared checkpoint state.
CHECKPOINT_TASK_OWNED_STATE_DIR - Static variable in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
The name of the directory for state not owned/released by the master, but by the TaskManagers.
CheckpointAlignment(long, long) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
 
CheckpointAlignment(MinMaxAvgStatistics, MinMaxAvgStatistics) - 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
 
CheckpointConfigHandler - Class in org.apache.flink.runtime.rest.handler.job.checkpoints
Handler which serves the checkpoint configuration.
CheckpointConfigHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, CheckpointConfigInfo, JobMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointConfigHandler
 
CheckpointConfigHandler - Class in org.apache.flink.runtime.rest.handler.legacy.checkpoints
Handler that returns a job's snapshotting settings.
CheckpointConfigHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointConfigHandler
 
CheckpointConfigHandler.CheckpointConfigJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy.checkpoints
Archivist for the 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) - 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
CheckpointConfigJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointConfigHandler.CheckpointConfigJsonArchivist
 
CheckpointCoordinator - Class in org.apache.flink.runtime.checkpoint
The checkpoint coordinator coordinates the distributed snapshots of operators and state.
CheckpointCoordinator(JobID, long, long, long, int, CheckpointRetentionPolicy, ExecutionVertex[], ExecutionVertex[], ExecutionVertex[], CheckpointIDCounter, CompletedCheckpointStore, StateBackend, Executor, SharedStateRegistryFactory) - 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) - Constructor for class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
 
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) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointCoordinatorDeActivator
 
CheckpointCoordinatorGateway - Interface in org.apache.flink.runtime.checkpoint
 
CheckpointDeclineException - Exception in org.apache.flink.runtime.checkpoint.decline
Base class of all exceptions that indicate a declined checkpoint.
CheckpointDeclineException(String) - Constructor for exception org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineException
 
CheckpointDeclineException(String, Throwable) - Constructor for exception org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineException
 
CheckpointDeclineOnCancellationBarrierException - Exception in org.apache.flink.runtime.checkpoint.decline
Exception indicating that a checkpoint was declined because a cancellation barrier was received.
CheckpointDeclineOnCancellationBarrierException() - Constructor for exception org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineOnCancellationBarrierException
 
CheckpointDeclineReason - Enum in org.apache.flink.runtime.checkpoint
Various reasons why a checkpoint was declined.
CheckpointDeclineSubsumedException - Exception in org.apache.flink.runtime.checkpoint.decline
Exception indicating that a checkpoint was declined because a newer checkpoint barrier was received on an input before the pending checkpoint's barrier.
CheckpointDeclineSubsumedException(long) - Constructor for exception org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineSubsumedException
 
CheckpointDeclineTaskNotCheckpointingException - Exception in org.apache.flink.runtime.checkpoint.decline
Exception indicating that a checkpoint was declined because a task does not support checkpointing.
CheckpointDeclineTaskNotCheckpointingException(String) - Constructor for exception org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineTaskNotCheckpointingException
 
CheckpointDeclineTaskNotReadyException - Exception in org.apache.flink.runtime.checkpoint.decline
Exception indicating that a checkpoint was declined because a task was not ready to perform a checkpoint.
CheckpointDeclineTaskNotReadyException(String) - Constructor for exception org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineTaskNotReadyException
 
CheckpointDuration(long, long) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
 
CheckpointDuration(MinMaxAvgStatistics, MinMaxAvgStatistics) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
 
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, Throwable) - Constructor for exception org.apache.flink.runtime.checkpoint.CheckpointException
 
CheckpointException(String) - Constructor for exception org.apache.flink.runtime.checkpoint.CheckpointException
 
CheckpointException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
Exception indicating a problem with checkpointing on the TaskExecutor side.
CheckpointException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.CheckpointException
 
CheckpointException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.CheckpointException
 
CheckpointException(Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.CheckpointException
 
CheckpointIDCounter - Interface in org.apache.flink.runtime.checkpoint
A checkpoint ID counter.
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
 
checkpointIdPathParameter - Variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointMessageParameters
 
checkpointIdToPath(long) - Static method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
Convert a checkpoint id into a ZooKeeper path.
CheckpointingStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, CheckpointingStatistics, JobMessageParameters>, ExecutionGraphCache, 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
 
CheckpointListener - Interface in org.apache.flink.runtime.state
This interface must be implemented by functions/operations that want to receive a commit notification once a checkpoint has been completely acknowledged by all participants.
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
Encapsulates all the meta data for a checkpoint.
CheckpointMetaData(long, long) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointMetaData
 
CheckpointMetadataOutputStream - Class in org.apache.flink.runtime.state
 
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) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
CheckpointOptions - Class in org.apache.flink.runtime.checkpoint
Options for performing the checkpoint.
CheckpointOptions(CheckpointType, CheckpointStorageLocationReference) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointOptions
 
CheckpointProperties - Class in org.apache.flink.runtime.checkpoint
The configuration of a checkpoint.
CheckpointRecoveryFactory - Interface in org.apache.flink.runtime.checkpoint
A factory for per Job checkpoint recovery components.
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.
checkpointsMatch(Collection<CompletedCheckpoint>, Collection<CompletedCheckpoint>) - Static method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
CheckpointStateOutputStream() - Constructor for class org.apache.flink.runtime.state.CheckpointStreamFactory.CheckpointStateOutputStream
 
CheckpointStatisticDetailsHandler - Class in org.apache.flink.runtime.rest.handler.job.checkpoints
REST handler which returns the details for a checkpoint.
CheckpointStatisticDetailsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, CheckpointStatistics, CheckpointMessageParameters>, ExecutionGraphCache, Executor, CheckpointStatsCache) - Constructor for class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointStatisticDetailsHandler
 
CheckpointStatisticDetailsHeaders - Class in org.apache.flink.runtime.rest.messages.checkpoints
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.
CheckpointStatsDetailsHandler - Class in org.apache.flink.runtime.rest.handler.legacy.checkpoints
Request handler that returns checkpoint stats for a single job vertex.
CheckpointStatsDetailsHandler(ExecutionGraphCache, Executor, CheckpointStatsCache) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsDetailsHandler
 
CheckpointStatsDetailsHandler.CheckpointStatsDetailsJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy.checkpoints
Archivist for the CheckpointStatsDetails.
CheckpointStatsDetailsJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsDetailsHandler.CheckpointStatsDetailsJsonArchivist
 
CheckpointStatsDetailsSubtasksHandler - Class in org.apache.flink.runtime.rest.handler.legacy.checkpoints
Request handler that returns checkpoint stats for a single job vertex with the summary stats and all subtasks.
CheckpointStatsDetailsSubtasksHandler(ExecutionGraphCache, Executor, CheckpointStatsCache) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsDetailsSubtasksHandler
 
CheckpointStatsDetailsSubtasksHandler.CheckpointStatsDetailsSubtasksJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy.checkpoints
Archivist for the CheckpointStatsDetailsSubtasksHandler.
CheckpointStatsDetailsSubtasksJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsDetailsSubtasksHandler.CheckpointStatsDetailsSubtasksJsonArchivist
 
CheckpointStatsHandler - Class in org.apache.flink.runtime.rest.handler.legacy.checkpoints
Handler that returns checkpoint statistics for a job.
CheckpointStatsHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsHandler
 
CheckpointStatsHandler.CheckpointStatsJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy.checkpoints
Archivist for the CheckpointStatsJsonHandler.
CheckpointStatsHistory - Class in org.apache.flink.runtime.checkpoint
An array based history of checkpoint stats.
CheckpointStatsJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsHandler.CheckpointStatsJsonArchivist
 
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 - Class in org.apache.flink.runtime.checkpoint
Tracker for checkpoint statistics.
CheckpointStatsTracker(int, List<ExecutionJobVertex>, CheckpointCoordinatorConfiguration, MetricGroup) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
Creates a new checkpoint stats tracker.
CheckpointStorage - Interface in org.apache.flink.runtime.state
CheckpointStorage implements the durable storage of checkpoint data and metadata streams.
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.
CheckpointStreamFactory - Interface in org.apache.flink.runtime.state
A factory for checkpoint output streams, which are used to persist data for checkpoints.
CheckpointStreamFactory.CheckpointStateOutputStream - Class in org.apache.flink.runtime.state
A dedicated output stream that produces a StreamStateHandle when closed.
CheckpointStreamWithResultProvider - Interface in org.apache.flink.runtime.state
Interface that provides access to a CheckpointStateOutputStream and a method to provide the SnapshotResult.
CheckpointStreamWithResultProvider.PrimaryAndSecondaryStream - Class in org.apache.flink.runtime.state
Implementation of CheckpointStreamWithResultProvider that 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 CheckpointStreamWithResultProvider that only creates the primary/remote/jm-owned state.
CheckpointTriggerException - Exception in org.apache.flink.runtime.checkpoint
Exceptions which indicate that a checkpoint triggering has failed.
CheckpointTriggerException(String, CheckpointDeclineReason) - Constructor for exception org.apache.flink.runtime.checkpoint.CheckpointTriggerException
 
CheckpointTriggerResult - Class in org.apache.flink.runtime.checkpoint
The result of triggering a checkpoint.
CheckpointType - Enum in org.apache.flink.runtime.checkpoint
The type of checkpoint to perform.
childFirst(URL[], ClassLoader, String[]) - Static method in class org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders
 
CircularElement() - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.CircularElement
 
CircularElement(int, InMemorySorter<E>, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.CircularElement
 
CircularQueues() - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.CircularQueues
 
CircularQueues(int) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.CircularQueues
 
ClassLoaderUtil - Class in org.apache.flink.runtime.util
Utilities for information with respect to class loaders, specifically class loaders for the dynamic loading of user defined classes.
ClassloadingProps - Class in org.apache.flink.runtime.jobmaster.message
The response of classloading props request to JobManager.
ClassloadingProps(int, Collection<PermanentBlobKey>, Collection<URL>) - Constructor for class org.apache.flink.runtime.jobmaster.message.ClassloadingProps
Constructor of ClassloadingProps.
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.ExecutionGraphCache
Perform the cleanup of out dated ExecutionGraphEntry.
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".
cleanupJob(JobID, boolean) - Method in class org.apache.flink.runtime.blob.BlobServer
Removes all BLOBs from local and HA store belonging to the given job ID.
cleanUpOperatorStatsCache() - Method in interface org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTracker
Cleans up the operator stats cache if it contains timed out entries.
cleanUpOperatorStatsCache() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTrackerImpl
Cleans up the operator stats cache if it contains timed out entries.
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 interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
Clear and release internal state.
clear() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
 
clear() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
 
clear() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
clear() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
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.operators.util.BloomFilter.BitSet
Clear the bit set.
clear() - Method in class org.apache.flink.runtime.query.KvStateEntry
 
clear() - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
Stop and clear the currently registered job leader id listeners.
clear() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
 
clear() - Method in class org.apache.flink.runtime.state.HeapBroadcastState
 
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.EvictingBoundedList
 
clear() - Method in class org.apache.flink.runtime.util.IntArrayList
 
clear() - Method in class org.apache.flink.runtime.util.LongArrayList
 
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
 
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
 
clearBuffers() - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
clearJob(JobID) - Method in class org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
 
clearJob(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
 
clearJob(JobID) - Method in interface org.apache.flink.runtime.highavailability.RunningJobsRegistry
Clear job state form the registry, usually called after job finish.
clearJob(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperRunningJobsRegistry
 
clearPartitions() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
This method clears all partitions currently residing (partially) in memory.
clearPendingSlotRequest() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
clearReaders(MutableReader<?>[]) - Static method in class org.apache.flink.runtime.operators.BatchTask
 
clearTaskAssignment() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
clearWriters(List<RecordWriter<?>>) - Static method in class org.apache.flink.runtime.operators.BatchTask
 
client - Variable in class org.apache.flink.runtime.client.JobClientActor
The client which the actor is responsible for
CLIENT_CONNECT_TIMEOUT_SECONDS - Static variable in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
Clock - Class in org.apache.flink.runtime.util.clock
A clock that gives access to time.
Clock() - Constructor for class org.apache.flink.runtime.util.clock.Clock
 
clone() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
 
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(Collection<MasterTriggerRestoreHook<?>>, Logger) - Static method in class org.apache.flink.runtime.checkpoint.hooks.MasterHooks
Closes the master hooks.
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.FileArchivedExecutionGraphStore
 
close() - Method in class org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
 
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.zookeeper.ZooKeeperHaServices
 
close() - Method in class org.apache.flink.runtime.io.disk.FileChannelInputView
 
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.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.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.buffer.BufferConsumer
 
close(RemoteInputChannel) - Method in class org.apache.flink.runtime.io.network.netty.PartitionRequestClient
 
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 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.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.ChainedTerminationCriterionDriver
 
close() - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
close() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
 
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.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.sort.UnilateralSortMerger
Shuts down all the threads initiated by this sort/merger.
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.SlotManager
Closes the slot manager.
close() - Method in class org.apache.flink.runtime.rest.handler.FileUploads
 
close() - Method in class org.apache.flink.runtime.rest.handler.legacy.ExecutionGraphCache
 
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.CheckpointMetadataOutputStream
This method should close the stream, if has not been closed before.
close() - Method in class org.apache.flink.runtime.state.CheckpointStreamFactory.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.DefaultOperatorStateBackend
 
close() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
 
close() - Method in class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
 
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.KeyedStateCheckpointOutputStream
 
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.SharedStateRegistry
 
close() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
 
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.NonClosingOutpusStreamDecorator
 
close() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
 
close() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
 
close(boolean) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
Closes the ZooKeeperUtilityFactory.
CloseableInputProvider<E> - Interface in org.apache.flink.runtime.operators.util
Utility interface for a provider of an input that can be closed.
closeAndCleanupAllData() - Method in interface org.apache.flink.runtime.blob.BlobStoreService
Closes and cleans up the store.
closeAndCleanupAllData() - Method in class org.apache.flink.runtime.blob.FileSystemBlobStore
 
closeAndCleanupAllData() - Method in class org.apache.flink.runtime.blob.VoidBlobStore
 
closeAndCleanupAllData() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
Closes the high availability services (releasing all resources) and deletes all data stored by these services in external stores.
closeAndCleanupAllData() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
closeAndCleanupAllData() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
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
 
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.CheckpointStreamFactory.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.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
 
closeAndGetHandle() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
 
closeAndGetPrimaryHandle() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
closeAndGetSecondaryHandle() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
closeAsync() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
 
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.minicluster.StandaloneMiniCluster
 
closeAsync() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRunner
 
closeAsync() - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
 
closeAsync() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
closeAsync() - Method in enum org.apache.flink.runtime.webmonitor.WebMonitorExtension.EmptyWebMonitorExtension
 
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.
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 - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Flag indicating that the sorter was closed.
closeJobManagerConnection(JobID, 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
 
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.ChainedTerminationCriterionDriver
 
closeTask() - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
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.
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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, ClusterConfigurationInfo, EmptyMessageParameters>, Configuration) - Constructor for class org.apache.flink.runtime.rest.handler.cluster.ClusterConfigHandler
 
ClusterConfigHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Returns the Job Manager's configuration.
ClusterConfigHandler(Executor, Configuration) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.ClusterConfigHandler
 
ClusterConfiguration - Class in org.apache.flink.runtime.entrypoint
Configuration class which contains the parsed command line arguments for the ClusterEntrypoint.
ClusterConfiguration(String, int) - Constructor for class org.apache.flink.runtime.entrypoint.ClusterConfiguration
 
clusterConfiguration - Variable in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
 
ClusterConfigurationInfo - Class in org.apache.flink.runtime.rest.messages
Response of the ClusterConfigHandler, represented as a list of key-value pairs of the cluster Configuration.
ClusterConfigurationInfo() - Constructor for class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfo
 
ClusterConfigurationInfo(int) - Constructor for class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfo
 
ClusterConfigurationInfoEntry - Class in org.apache.flink.runtime.rest.messages
A single key-value pair entry in the ClusterConfigurationInfo response.
ClusterConfigurationInfoEntry(String, String) - Constructor for class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoEntry
 
ClusterConfigurationInfoHeaders - Class in org.apache.flink.runtime.rest.messages
Message headers for the ClusterConfigHandler.
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.
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 RequestStatusOverview message, carrying a description of the Flink cluster status.
ClusterOverview(int, int, int, int, int, int, int) - Constructor for class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
 
ClusterOverview(int, int, int, JobsOverview, JobsOverview) - 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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, ClusterOverviewWithVersion, EmptyMessageParameters>) - Constructor for class org.apache.flink.runtime.rest.handler.cluster.ClusterOverviewHandler
 
ClusterOverviewHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Responder that returns the status of the Flink cluster, such as how many TaskManagers are currently connected, and how many jobs are running.
ClusterOverviewHandler(Executor, Time) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.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, int, int, int, int, String, String) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
 
ClusterOverviewWithVersion(int, int, int, JobsOverview, JobsOverview, String, String) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
 
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
 
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(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(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(T) - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
 
collect(IT) - Method in class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
 
collect(IN) - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
collect(IN) - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
 
collect(IT) - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
 
collect(T) - Method in class org.apache.flink.runtime.operators.shipping.OutputCollector
Collects a record and emits it to all writers.
collect(OUT) - Method in class org.apache.flink.runtime.operators.util.metrics.CountingCollector
 
collectStackTraces(int, ExecutionAttemptID, List<StackTraceElement[]>) - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator
Collects stack traces of a task.
CoLocationConstraint - Class in org.apache.flink.runtime.jobmanager.scheduler
A CoLocationConstraint manages the location of a set of tasks (Execution Vertices).
CoLocationGroup - Class in org.apache.flink.runtime.jobmanager.scheduler
A Co-location group is a group of JobVertices, where the i-th subtask of one vertex has to be executed on the same TaskManager as the i-th subtask of all other JobVertices in the same group.
CoLocationGroup() - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
 
CoLocationGroup(JobVertex...) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
 
combine(JobsOverview) - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
Combines the given jobs overview with this.
combineAll(Collection<? extends CompletableFuture<? extends T>>) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
Creates a future that is complete once multiple other futures completed.
CombiningSpillingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable, MemoryManager, IOManager, TypeSerializer<E>, TypeComparator<E>, List<MemorySegment>, List<MemorySegment>, int, boolean) - Constructor for class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger.CombiningSpillingThread
 
CombiningUnilateralSortMerger<E> - Class in org.apache.flink.runtime.operators.sort
The CombiningUnilateralSortMerger is part of a merge-sort implementation.
CombiningUnilateralSortMerger(GroupCombineFunction<E, E>, MemoryManager, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, double, int, float, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger
Creates a new sorter that reads the data from a given reader and provides an iterator returning that data in a sorted manner.
CombiningUnilateralSortMerger(GroupCombineFunction<E, E>, MemoryManager, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, double, int, int, float, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger
Creates a new sorter that reads the data from a given reader and provides an iterator returning that data in a sorted manner.
CombiningUnilateralSortMerger.CombiningSpillingThread - Class in org.apache.flink.runtime.operators.sort
 
commit() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
Make the change visible to the readers.
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)
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 If entries are inserted during iteration they may be overlooked by the iterator
CompactingHashTable.HashTableProber<PT> - Class in org.apache.flink.runtime.operators.hash
 
comparator - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
compare(int, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
compare(int, int, 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, 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) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
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<RestHandlerSpecification, ChannelInboundHandler>, Tuple2<RestHandlerSpecification, ChannelInboundHandler>) - Method in class org.apache.flink.runtime.rest.RestServerEndpoint.RestHandlerUrlComparator
 
compareTo(BlobKey) - Method in class org.apache.flink.runtime.blob.BlobKey
 
compareTo(ResourceProfile) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
 
compareTo(TaskManagerLocation) - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
 
complete() - Static method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationInfo
 
completeAll(Collection<? extends CompletableFuture<?>>) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
Creates a FutureUtils.ConjunctFuture which is only completed after all given futures have completed.
completeAllocation(AllocationID, JobID) - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
completed(V) - Static method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationResult
 
completed() - Static method in class org.apache.flink.runtime.rest.messages.queue.QueueStatus
 
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) - Constructor for class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
CompletedCheckpointStatistics(long, CheckpointStatsStatus, boolean, long, long, long, long, long, int, int, 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.
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 CompletedCheckpoint instances.
completedExceptionally(Throwable) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
Returns an exceptionally completed CompletableFuture.
CompletedOperationCache() - Constructor for class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.CompletedOperationCache
 
CompletedSubtaskCheckpointStatistics(int, long, long, long, SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration, SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment) - 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
 
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 DirectoryStateHandle that points to the snapshot directory.
ComponentMetricGroup<P extends AbstractMetricGroup<?>> - Class in org.apache.flink.runtime.metrics.groups
Abstract MetricGroup for 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.
composeAfterwards(CompletableFuture<?>, Supplier<CompletableFuture<?>>) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
Run the given asynchronous action after the completion of the given future.
CompositeContainerOverlay - Class in org.apache.flink.runtime.clusterframework.overlays
A composite overlay that delegates to a set of inner overlays.
CompositeContainerOverlay(ContainerOverlay...) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.CompositeContainerOverlay
 
CompositeContainerOverlay(List<ContainerOverlay>) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.CompositeContainerOverlay
 
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
 
CompositeStateHandle - Interface in org.apache.flink.runtime.state
Base of all snapshots that are taken by StateBackends and some other components in tasks.
computeDefaultMaxParallelism(int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
Computes a default maximum parallelism from the operator parallelism.
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.
computeMemorySize(double) - Method in class org.apache.flink.runtime.memory.MemoryManager
Computes the memory size of the fraction per slot.
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.
concat(String...) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
concat(CharacterFilter, String...) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
concat(Character, String...) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
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.clusterframework.FlinkResourceManager
The Flink configuration object
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
 
ConfigurableStateBackend - Interface in org.apache.flink.runtime.state
An interface for state backends that pick up additional parameters from a configuration.
configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.CompositeContainerOverlay
 
configure(ContainerSpecification) - Method in interface org.apache.flink.runtime.clusterframework.overlays.ContainerOverlay
Configure the given container specification.
configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay
 
configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.HadoopConfOverlay
 
configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.HadoopUserOverlay
 
configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay
 
configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay
 
configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay
 
configure(Configuration) - Method in interface org.apache.flink.runtime.state.ConfigurableStateBackend
Creates a variant of the state backend that applies additional configuration parameters.
configure(Configuration) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a copy of this state backend that uses the values defined in the configuration for fields where that were not specified in this state backend.
configure(Configuration) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
Creates a copy of this state backend that uses the values defined in the configuration for fields where that were not specified in this state backend.
configureFileSystems(Configuration) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
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) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
confirmCheckpoint(ExecutionAttemptID, long, long) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Confirm a checkpoint for the given task.
confirmLeaderSessionID(UUID) - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
 
confirmLeaderSessionID(UUID) - Method in interface org.apache.flink.runtime.leaderelection.LeaderElectionService
Confirms that the new leader session ID has been successfully received by the new leader.
confirmLeaderSessionID(UUID) - Method in class org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
 
confirmLeaderSessionID(UUID) - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
ConjunctFuture() - Constructor for class org.apache.flink.runtime.concurrent.FutureUtils.ConjunctFuture
 
connecDataSet(IntermediateDataSet) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
 
connect(String, Class<C>) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
connect(String, F, Class<C>) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
connect(String, Class<C>) - Method in interface org.apache.flink.runtime.rpc.RpcService
Connect to a remote rpc server under the provided address.
connect(String, F, Class<C>) - Method in interface org.apache.flink.runtime.rpc.RpcService
Connect to ta remote fenced rpc server under the provided address.
CONNECT_BACKLOG - Static variable in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
connectDataSetAsInput(IntermediateDataSet, DistributionPattern) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
connectedToJobManager() - Method in class org.apache.flink.runtime.client.JobAttachmentClientActor
 
connectedToJobManager() - Method in class org.apache.flink.runtime.client.JobClientActor
Hook to be called once a connection has been established with the JobManager.
connectedToJobManager() - Method in class org.apache.flink.runtime.client.JobSubmissionClientActor
 
connectIdInput(IntermediateDataSetID, DistributionPattern) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
ConnectionID - Class in org.apache.flink.runtime.io.network
A ConnectionID identifies a connection to a remote task manager by the socket address and a connection index.
ConnectionID(TaskManagerLocation, int) - Constructor for class org.apache.flink.runtime.io.network.ConnectionID
 
ConnectionID(InetSocketAddress, int) - Constructor for class org.apache.flink.runtime.io.network.ConnectionID
 
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 LeaderRetrievalListener that allows retrieving an InetAddress for the current leader.
connectNewDataSetAsInput(JobVertex, DistributionPattern, ResultPartitionType) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
connectSource(int, IntermediateResult, JobEdge, int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
connectToPredecessors(Map<IntermediateDataSetID, IntermediateResult>) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
connectToResourceManager(ResourceManagerGateway) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
 
connectToResourceManager(ResourceManagerGateway) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolGateway
Connects the SlotPool to the given ResourceManager.
ConstantTextHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Responder that returns a constant String.
ConstantTextHandler(String) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.ConstantTextHandler
 
constructLogString(String, String, AbstractInvokable) - Static method in class org.apache.flink.runtime.operators.BatchTask
Utility function that composes a string for logging purposes.
consumeAndCacheRemainingData() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
ContaineredTaskManagerParameters - Class in org.apache.flink.runtime.clusterframework
This class describes the basic parameters for launching a TaskManager process.
ContaineredTaskManagerParameters(long, long, long, int, HashMap<String, String>) - Constructor for class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
 
ContainerOverlay - Interface in org.apache.flink.runtime.clusterframework.overlays
A container overlay to produce a container specification.
ContainerSpecification - Class in org.apache.flink.runtime.clusterframework
Encapsulates a container specification, including artifacts, environment variables, system properties, and Flink configuration settings.
ContainerSpecification() - Constructor for class org.apache.flink.runtime.clusterframework.ContainerSpecification
 
ContainerSpecification.Artifact - Class in org.apache.flink.runtime.clusterframework
An artifact to be copied into the container.
ContainerSpecification.Artifact.Builder - Class in org.apache.flink.runtime.clusterframework
 
contains(Object) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
 
contains(Object) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
contains(SlotRequestId) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager
 
contains(AbstractID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.MultiTaskSlot
Checks whether this slot or any of its children contains the given groupId.
contains(AbstractID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.TaskSlot
Check whether the task slot contains the given groupId.
contains(UK) - Method in class org.apache.flink.runtime.state.heap.HeapMapState
 
contains(K) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
 
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(JobID) - Method in class org.apache.flink.runtime.taskexecutor.JobManagerTable
 
containsAll(Collection<?>) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
 
containsAll(Collection<?>) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
containsJob(JobID) - Method in class 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.JobLeaderService
Check whether the service monitors the given job.
containsKey(N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
containsKey(N) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
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.jobmaster.slotpool.DualKeyMap
 
containsKeyB(B) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
containsSlot(SlotID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
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
 
continueWritingWithNextBufferBuilder(BufferBuilder) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
Sets a (next) target buffer to use and continues writing remaining data to it until it is full.
continueWritingWithNextBufferBuilder(BufferBuilder) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
 
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(Throwable) - Constructor for exception org.apache.flink.runtime.rest.messages.ConversionException
 
ConversionException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rest.messages.ConversionException
 
convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointIdPathParameter
 
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.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.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
 
convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.AccumulatorsIncludeSerializedValueQueryParameter
 
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.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.TerminationModeQueryParameter
 
convertToOperatorStateSavepointV2(Map<JobVertexID, ExecutionJobVertex>, Savepoint) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
Deprecated.
Only kept for backwards-compatibility with versions < 1.3. Will be removed in the future.
convertToString(Long) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointIdPathParameter
 
convertToString(Integer) - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskAttemptPathParameter
 
convertToString(JobID) - Method in class org.apache.flink.runtime.rest.messages.JobIDPathParameter
 
convertToString(JobVertexID) - Method in class org.apache.flink.runtime.rest.messages.JobVertexIdPathParameter
 
convertToString(X) - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
Converts the given value to its string representation.
convertToString(List<X>) - Method in class org.apache.flink.runtime.rest.messages.MessageQueryParameter
 
convertToString(Integer) - Method in class org.apache.flink.runtime.rest.messages.SubtaskIndexPathParameter
 
convertToString(ResourceID) - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerIdPathParameter
 
convertToString(TriggerId) - Method in class org.apache.flink.runtime.rest.messages.TriggerIdPathParameter
 
convertValueToString(Boolean) - Method in class org.apache.flink.runtime.rest.messages.AccumulatorsIncludeSerializedValueQueryParameter
 
convertValueToString(JobID) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobsFilterQueryParameter
 
convertValueToString(MetricsAggregationParameter.AggregationMode) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter
 
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(ResourceID) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagersFilterQueryParameter
 
convertValueToString(X) - Method in class org.apache.flink.runtime.rest.messages.MessageQueryParameter
Converts the given value to its string representation.
convertValueToString(Integer) - Method in class org.apache.flink.runtime.rest.messages.RescalingParallelismQueryParameter
 
convertValueToString(TerminationModeQueryParameter.TerminationMode) - Method in class org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter
 
copy(Path, Path, boolean) - Static method in class org.apache.flink.runtime.filecache.FileCache
 
copy() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
 
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.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(VoidNamespace) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
 
copy(VoidNamespace, VoidNamespace) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
 
copy1 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
copy2 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
CopyOnWriteStateTable<K,N,S> - Class in org.apache.flink.runtime.state.heap
Implementation of Flink's in-memory state tables with copy-on-write support.
CopyOnWriteStateTableSnapshot<K,N,S> - Class in org.apache.flink.runtime.state.heap
This class represents the snapshot of a CopyOnWriteStateTable and has a role in operator state checkpointing.
copyTemplate() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
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
 
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(int) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
counter(String) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
counter(int, C) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
counter(String, C) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
counter(int) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
counter(String) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
counter(int, C) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
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
 
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
 
Counts(long, long, int, long, long) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
 
create() - Method in class org.apache.flink.runtime.akka.StoppingSupervisorWithoutLoggingActorKilledExceptionStrategy
 
create() - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook.Factory
Instantiates the MasterTriggerRestoreHook.
create(Configuration, long, int) - Static method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
Computes the parameters to be used to start a TaskManager Java process.
create(FlinkUserCodeClassLoaders.ResolveOrder, URL[], ClassLoader, String[]) - Static method in class org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders
 
create(ExecutionGraph) - Method in interface org.apache.flink.runtime.executiongraph.failover.FailoverStrategy.Factory
Instantiates the FailoverStrategy.
create(ExecutionGraph) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy.Factory
 
create(ExecutionGraph) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy.Factory
 
create(ExecutionGraph) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy.Factory
 
create(String, JobID, ExecutionAttemptID, InputGateDeploymentDescriptor, NetworkEnvironment, TaskActions, TaskIOMetricGroup) - Static method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
Creates an input gate and all of its input channels.
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(Collection<JobStatus>) - Static method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
create(AccessExecution, MutableIOMetrics) - Static method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
create(Executor) - Method in interface org.apache.flink.runtime.state.SharedStateRegistryFactory
Factory method for SharedStateRegistry.
createActivatorDeactivator() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
createActorProps(LeaderRetrievalService, FiniteDuration, boolean) - Static method in class org.apache.flink.runtime.client.JobAttachmentClientActor
 
createActorProps(LeaderRetrievalService, FiniteDuration, boolean, Configuration) - Static method in class org.apache.flink.runtime.client.JobSubmissionClientActor
 
createAggregatingState(TypeSerializer<N>, AggregatingStateDescriptor<T, ACC, R>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
Creates and returns a new AggregatingState.
createAggregatingState(TypeSerializer<N>, AggregatingStateDescriptor<T, ACC, R>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
createAndAddResultDataSet(ResultPartitionType) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
createAndAddResultDataSet(IntermediateDataSetID, ResultPartitionType) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
createAttemptAccumulatorsJson(AccessExecution) - Static method in class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptAccumulatorsHandler
 
createAttemptDetailsJson(AccessExecution, String, String, MetricFetcher) - Static method in class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptDetailsHandler
 
createAvailableOrEmbeddedServices(Configuration, Executor) - Static method in class org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
 
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
 
createBlobStore() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
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, 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, 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.IOManagerAsync
 
createBufferConsumer() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
 
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
 
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 class org.apache.flink.runtime.io.disk.iomanager.IOManager
Creates a new FileIOChannel.ID in one of the temp directories.
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.
createCheckpointDataSerializer() - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
Creates a the serializer to (de)serializes the data stored by this hook.
createCheckpointDetailsJson(AbstractCheckpointStats) - Static method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsDetailsHandler
 
createCheckpointDirectory(Path, long) - Static method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
Creates the directory path for the data exclusive to a specific checkpoint.
createCheckpointIDCounter(JobID) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
Creates a CheckpointIDCounter instance for a job.
createCheckpointIDCounter(JobID) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
 
createCheckpointIDCounter(JobID) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
 
createCheckpointIDCounter(CuratorFramework, Configuration, JobID) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
Creates a ZooKeeperCheckpointIDCounter instance.
createCheckpointStateOutputStream(CheckpointedStateScope) - Method in interface org.apache.flink.runtime.state.CheckpointStreamFactory
createCheckpointStateOutputStream(CheckpointedStateScope) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
 
createCheckpointStateOutputStream(CheckpointedStateScope) - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory
 
createCheckpointStorage(JobID) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
 
createCheckpointStorage(JobID) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
 
createCheckpointStorage(JobID) - Method in interface org.apache.flink.runtime.state.StateBackend
Creates a storage for checkpoints for the given job.
createCheckpointStore(JobID, int, ClassLoader) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
Creates a CompletedCheckpointStore instance for a job.
createCheckpointStore(JobID, int, ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
 
createCheckpointStore(JobID, int, ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
 
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
 
createClient() - Method in class org.apache.flink.runtime.blob.BlobServer
 
createClientSSLContext() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
createClientSSLEngineFactory(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
Creates a SSLEngineFactory to be used by the Client.
createCompletedCheckpoints(CuratorFramework, Configuration, JobID, int, Executor) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
createConfigJson(DashboardConfiguration) - Static method in class org.apache.flink.runtime.rest.handler.legacy.DashboardConfigHandler
 
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
 
createDetailsForJob(AccessExecutionGraph) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
 
createDispatcher(Configuration, RpcService, HighAvailabilityServices, ResourceManagerGateway, BlobServer, HeartbeatServices, JobManagerMetricGroup, String, ArchivedExecutionGraphStore, FatalErrorHandler, String, HistoryServerArchivist) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
createDispatcher(Configuration, RpcService, HighAvailabilityServices, ResourceManagerGateway, BlobServer, HeartbeatServices, JobManagerMetricGroup, String, ArchivedExecutionGraphStore, FatalErrorHandler, String, HistoryServerArchivist) - Method in class org.apache.flink.runtime.entrypoint.JobClusterEntrypoint
 
createDispatcher(Configuration, RpcService, HighAvailabilityServices, ResourceManagerGateway, BlobServer, HeartbeatServices, JobManagerMetricGroup, String, ArchivedExecutionGraphStore, FatalErrorHandler, String, HistoryServerArchivist) - Method in class org.apache.flink.runtime.entrypoint.SessionClusterEntrypoint
 
createDuplicatingStream(long, CheckpointedStateScope, CheckpointStreamFactory, LocalRecoveryDirectoryProvider) - Static method in interface org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
 
createFactory(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy
 
createFactory(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
Creates a FixedDelayRestartStrategy from the given Configuration.
createFactory(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
Creates a NoRestartStrategy instance.
createFileSystemStateStorage(Configuration, String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
Creates a FileSystemStateStorageHelper instance.
createFoldingState(TypeSerializer<N>, FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
Deprecated.
will be removed in a future version
createFoldingState(TypeSerializer<N>, FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
createFrom(ExecutionGraph) - Static method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
Create a ArchivedExecutionGraph from the given ExecutionGraph.
createFrom(AccessExecutionGraph) - Static method in class org.apache.flink.runtime.jobmaster.JobResult
Creates the JobResult from the given AccessExecutionGraph which must be in a globally terminal state.
createFromConfig(Configuration) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackendFactory
 
createFromConfig(Configuration) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackendFactory
 
createFromConfig(Configuration) - Method in interface org.apache.flink.runtime.state.StateBackendFactory
Creates the state backend, optionally using the given configuration.
createGateway(CompletableFuture<Tuple2<String, UUID>>) - Method in class org.apache.flink.runtime.webmonitor.retriever.impl.AkkaJobManagerRetriever
 
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
 
createHaServices(Configuration, Executor) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
createHeartbeatManager(ResourceID, HeartbeatListener<I, O>, ScheduledExecutor, Logger) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatServices
Creates a heartbeat manager which does not actively send heartbeats.
createHeartbeatManagerSender(ResourceID, HeartbeatListener<I, O>, ScheduledExecutor, Logger) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatServices
Creates a heartbeat manager which actively sends heartbeats to monitoring targets.
createHeartbeatServices(Configuration) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
createHighAvailabilityServices(Configuration, Executor, HighAvailabilityServicesUtils.AddressResolution) - Static method in class org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
 
createHistoryServerArchivist(Configuration, JsonArchivist) - Static method in interface org.apache.flink.runtime.dispatcher.HistoryServerArchivist
 
createInputChannelDeploymentDescriptor(Execution) - Method in class org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor
Creates a channel deployment descriptor by completing the partition location.
createInputIterator(MutableReader<?>, TypeSerializerFactory<?>) - Method in class org.apache.flink.runtime.operators.BatchTask
 
createInstance() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
createInstance() - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
 
createJarFile() - Method in class org.apache.flink.runtime.util.JarFileCreator
Creates a jar file which contains the previously added class.
createJobAccumulatorsJson(AccessExecutionGraph) - Static method in class org.apache.flink.runtime.rest.handler.legacy.JobAccumulatorsHandler
 
createJobConfigJson(AccessExecutionGraph) - Static method in class org.apache.flink.runtime.rest.handler.legacy.JobConfigHandler
 
createJobDetailsJson(AccessExecutionGraph, MetricFetcher) - Static method in class org.apache.flink.runtime.rest.handler.legacy.JobDetailsHandler
 
createJobExceptionsJson(AccessExecutionGraph) - Static method in class org.apache.flink.runtime.rest.handler.legacy.JobExceptionsHandler
 
createJobManagerRunner(ResourceID, JobGraph, Configuration, RpcService, HighAvailabilityServices, HeartbeatServices, BlobServer, JobManagerSharedServices, JobManagerJobMetricGroupFactory, FatalErrorHandler) - Method in enum org.apache.flink.runtime.dispatcher.Dispatcher.DefaultJobManagerRunnerFactory
 
createJobManagerRunner(ResourceID, JobGraph, Configuration, RpcService, HighAvailabilityServices, HeartbeatServices, BlobServer, JobManagerSharedServices, JobManagerJobMetricGroupFactory, FatalErrorHandler) - Method in interface org.apache.flink.runtime.dispatcher.Dispatcher.JobManagerRunnerFactory
 
createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
 
createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
 
createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
 
createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry) - Method in interface org.apache.flink.runtime.state.StateBackend
Creates a new AbstractKeyedStateBackend that is responsible for holding keyed state and checkpointing it.
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
 
createKeyGroupPartitions(int, int) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
Groups the available set of key groups into key group partitions.
createKvStateClientProxy(InetAddress, Iterator<Integer>, int, int, KvStateRequestStats) - Static method in class org.apache.flink.runtime.query.QueryableStateUtils
Initializes the client proxy responsible for receiving requests from the external (to the cluster) client and forwarding them internally.
createKvStateServer(InetAddress, Iterator<Integer>, int, int, KvStateRegistry, KvStateRequestStats) - Static method in class org.apache.flink.runtime.query.QueryableStateUtils
Initializes the server responsible for sending the requested internal state to the client proxy.
createKvStateTaskRegistry(JobID, JobVertexID) - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
createLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
 
createLeaderElectionService(CuratorFramework, Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
Creates a ZooKeeperLeaderElectionService instance.
createLeaderElectionService(CuratorFramework, Configuration, String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
Creates a ZooKeeperLeaderElectionService instance.
createLeaderRetrievalService() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
 
createLeaderRetrievalService() - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
 
createLeaderRetrievalService(Configuration) - Static method in class org.apache.flink.runtime.util.StandaloneUtils
Creates a StandaloneLeaderRetrievalService from the given configuration.
createLeaderRetrievalService(Configuration, boolean, String) - Static method in class org.apache.flink.runtime.util.StandaloneUtils
Creates a StandaloneLeaderRetrievalService form the given configuration and the JobManager name.
createLeaderRetrievalService(CuratorFramework, Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
createLeaderRetrievalService(CuratorFramework, Configuration, String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
createListState(TypeSerializer<N>, ListStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
Creates and returns a new ListState.
createListState(TypeSerializer<N>, ListStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
createLocal() - Static method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
 
createLocalRecoveryConfig() - Method in interface org.apache.flink.runtime.state.TaskStateManager
Returns the configuration for local recovery, i.e.
createLocalRecoveryConfig() - Method in class org.apache.flink.runtime.state.TaskStateManagerImpl
 
createMapState(TypeSerializer<N>, MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
Creates and returns a new MapState.
createMapState(TypeSerializer<N>, MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
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
 
createMetricRegistry(Configuration) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
createMetricRegistry(Configuration) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
Factory method to create the metric registry for the mini cluster.
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
 
createOperationKey(HandlerRequest<B, M>) - 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, RescalingTriggerMessageParameters>) - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingTriggerHandler
 
createOperationKey(HandlerRequest<SavepointDisposalRequest, EmptyMessageParameters>) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalTriggerHandler
 
createOperationKey(HandlerRequest<SavepointTriggerRequestBody, SavepointTriggerMessageParameters>) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointTriggerHandler
 
createOperatorStateBackend(Environment, String) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
 
createOperatorStateBackend(Environment, String) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
 
createOperatorStateBackend(Environment, String) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
 
createOperatorStateBackend(Environment, String) - Method in interface org.apache.flink.runtime.state.StateBackend
Creates a new OperatorStateBackend that can be used for storing operator state.
createPartitionRequestClient(ConnectionID) - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
Creates a PartitionRequestClient instance for the given ConnectionID.
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
 
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.JobManagerMetricGroup
 
createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.JobMetricGroup
 
createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
 
createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
createRandomName(String) - Static method in class org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
Creates a random name of the form prefix_X, where X is an increasing number.
createReadView(BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
createReducingState(TypeSerializer<N>, ReducingStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
Creates and returns a new ReducingState.
createReducingState(TypeSerializer<N>, ReducingStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
createRemote(ConnectionID) - Static method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
 
createResourceManager(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, FatalErrorHandler, ClusterInformation, String) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
createResourceManager(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, FatalErrorHandler, ClusterInformation, String) - Method in class org.apache.flink.runtime.entrypoint.StandaloneSessionClusterEntrypoint
 
createRestartStrategy() - Method in class org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy.FailureRateRestartStrategyFactory
 
createRestartStrategy() - Method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy.FixedDelayRestartStrategyFactory
 
createRestartStrategy() - Method in class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy.NoRestartStrategyFactory
 
createRestartStrategy() - Method in class org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
Factory method to create a restart strategy
createRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - Static method in class org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
Creates a RestartStrategy instance from the given RestartStrategies.RestartStrategyConfiguration.
createRestartStrategyFactory(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
Creates a RestartStrategy instance from the given Configuration.
createRestEndpoint(Configuration, LeaderGatewayRetriever<DispatcherGateway>, LeaderGatewayRetriever<ResourceManagerGateway>, TransientBlobService, Executor, MetricQueryServiceRetriever, LeaderElectionService) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
createRestEndpoint(Configuration, LeaderGatewayRetriever<DispatcherGateway>, LeaderGatewayRetriever<ResourceManagerGateway>, TransientBlobService, Executor, MetricQueryServiceRetriever, LeaderElectionService) - Method in class org.apache.flink.runtime.entrypoint.JobClusterEntrypoint
 
createRestEndpoint(Configuration, LeaderGatewayRetriever<DispatcherGateway>, LeaderGatewayRetriever<ResourceManagerGateway>, TransientBlobService, Executor, MetricQueryServiceRetriever, LeaderElectionService) - Method in class org.apache.flink.runtime.entrypoint.SessionClusterEntrypoint
 
createRpcService(Configuration, String, String) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
createRpcService(Configuration, Time, boolean, String) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
Factory method to instantiate the RPC service.
createRpcService(String, int, Configuration) - Static method in class org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
Utility method to create RPC service from configuration and hostname, port.
createRpcService(Configuration, HighAvailabilityServices) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
Create a RPC service for the task manager.
createRuntimeContext(MetricGroup) - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
createRuntimeContext(MetricGroup) - Method in class org.apache.flink.runtime.operators.BatchTask
 
createRuntimeContext() - Method in class org.apache.flink.runtime.operators.DataSinkTask
 
createRuntimeContext() - Method in class org.apache.flink.runtime.operators.DataSourceTask
 
createSavepointLocation(FileSystem, Path) - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
 
createSavepointLocation(FileSystem, Path) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
 
createSavepointLocation(FileSystem, Path) - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
 
createSerializableExecutionGraphStore(Configuration, ScheduledExecutor) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
createSerializableExecutionGraphStore(Configuration, ScheduledExecutor) - Method in class org.apache.flink.runtime.entrypoint.JobClusterEntrypoint
 
createSerializableExecutionGraphStore(Configuration, ScheduledExecutor) - Method in class org.apache.flink.runtime.entrypoint.SessionClusterEntrypoint
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
 
createServerSSLContext() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
createServerSSLEngineFactory(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
Creates a SSLEngineFactory to be used by the Server.
createSharedCount(String, int) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
Creates a ZooKeeperSharedCount to store a shared count between multiple instances.
createSharedStateRegistryKeyFromFileName(StateHandleID) - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
Create a unique key to register one of our shared state handles.
createSharedValue(String, byte[]) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
Creates a ZooKeeperSharedValue to store a shared value between multiple instances.
createSimpleStream(CheckpointedStateScope, CheckpointStreamFactory) - Static method in interface org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
 
createSlotPool(JobID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultSlotPoolFactory
 
createSlotPool(JobID) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolFactory
 
createSlotReport(ResourceID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
 
createSnapshot() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
Creates a new snapshot of the available stats.
createSnapshot() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
createSnapshot() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
Creates a snapshot of this CopyOnWriteStateTable, to be written in checkpointing.
createSnapshot() - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
createSolutionSetUpdateOutputCollector(Collector<OT>) - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
Creates a new solution set update output collector.
createSSLClientContext(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
Creates the SSL Context for the client if SSL is configured.
createSSLEngine() - Method in class org.apache.flink.runtime.net.SSLEngineFactory
 
createSSLServerContext(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
Creates the SSL Context for the server if SSL is configured.
createSubmittedJobGraphs(CuratorFramework, Configuration, Executor) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
createSubpartitionView(int, BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
Returns the requested subpartition.
createSubpartitionView(ResultPartitionID, int, BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
createSubpartitionView(ResultPartitionID, int, BufferAvailabilityListener) - Method in interface org.apache.flink.runtime.io.network.partition.ResultPartitionProvider
Returns the requested intermediate result partition input view.
createSubtasksAccumulatorsJson(AccessExecutionJobVertex) - Static method in class org.apache.flink.runtime.rest.handler.legacy.SubtasksAllAccumulatorsHandler
 
createSubtaskTimesJson(AccessExecutionJobVertex) - Static method in class org.apache.flink.runtime.rest.handler.legacy.SubtasksTimesHandler
 
createTaskOwnedStateStream() - Method in interface org.apache.flink.runtime.state.CheckpointStorage
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.FsCheckpointStorage
 
createTaskOwnedStateStream() - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
 
createTaskRegistry(JobID, JobVertexID) - Method in class org.apache.flink.runtime.query.KvStateRegistry
Creates a TaskKvStateRegistry facade for the Task identified by the given JobID and JobVertexID instance.
createTmpFile(String, DistributedCache.DistributedCacheEntry, JobID) - Method in class org.apache.flink.runtime.filecache.FileCache
If the file doesn't exists locally, it will copy the file to the temp directory.
createUnknown() - Static method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
 
createUnregisteredJobManagerJobMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
 
createUnregisteredJobManagerMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
 
createUnregisteredOperatorMetricGroup() - 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
 
createValueState(TypeSerializer<N>, ValueStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
Creates and returns a new ValueState.
createValueState(TypeSerializer<N>, ValueStateDescriptor<V>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
createVertexAccumulatorsJson(AccessExecutionJobVertex) - Static method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexAccumulatorsHandler
 
createVertexDetailsByTaskManagerJson(AccessExecutionJobVertex, String, MetricFetcher) - Static method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexTaskManagersHandler
 
createVertexDetailsJson(AccessExecutionJobVertex, String, MetricFetcher) - Static method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexDetailsHandler
 
createWorksetUpdateOutputCollector(Collector<OT>) - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
createWorksetUpdateOutputCollector() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
createZooKeeperStateHandleStore(String, RetrievableStateStorageHelper<T>, Executor) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
Creates a ZooKeeperStateHandleStore instance with the provided arguments.
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
 
CURRENT_JOB_IDS_REST_PATH - Static variable in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
 
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.
currentIteration() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
CurrentJobIdsHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Responder that returns with a list of all JobIDs of jobs found at the target actor.
CurrentJobIdsHandler(Executor, Time) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.CurrentJobIdsHandler
 
CurrentJobsOverviewJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.JobsOverviewHandler.CurrentJobsOverviewJsonArchivist
 
currentKey - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
The currently active key.
currentlyRegisteredTaskManagers() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterResourceManagerSuccessful
 
currentNamespace - Variable in class org.apache.flink.runtime.state.heap.AbstractHeapState
The current namespace, which the access methods will refer to.
currentRecursionDepth - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The recursion depth of the partition that is currently processed.

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
 
DASHBOARD_CONFIG_REST_PATH - Static variable in class org.apache.flink.runtime.rest.handler.legacy.DashboardConfigHandler
 
DashboardConfigHandler - Class in org.apache.flink.runtime.rest.handler.cluster
Handler which returns the dashboard configuration.
DashboardConfigHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, DashboardConfiguration, EmptyMessageParameters>, long) - Constructor for class org.apache.flink.runtime.rest.handler.cluster.DashboardConfigHandler
 
DashboardConfigHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Responder that returns the parameters that define how the asynchronous requests against this web server should behave.
DashboardConfigHandler(Executor, long) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.DashboardConfigHandler
 
DashboardConfiguration - Class in org.apache.flink.runtime.rest.messages
Response of the DashboardConfigHandler containing general configuration values such as the time zone and the refresh interval.
DashboardConfiguration(long, String, int, String, String) - Constructor for class org.apache.flink.runtime.rest.messages.DashboardConfiguration
 
DashboardConfigurationHeaders - Class in org.apache.flink.runtime.rest.messages
Message headers for the DashboardConfigHandler.
DataExchangeMode - Enum in org.apache.flink.runtime.io.network
Defines how the data exchange between two specific operators happens.
dataPort() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
Returns the port instance's task manager expects to receive transfer envelopes on.
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.
date() - Method in class org.apache.flink.runtime.clusterframework.messages.InfoMessage
 
deallocate() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
Decline(String) - Constructor for class org.apache.flink.runtime.registration.RegistrationResponse.Decline
Creates a new rejection message.
declineCheckpoint(JobID, ExecutionAttemptID, long, Throwable) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointCoordinatorGateway
 
declineCheckpoint(long, Throwable) - Method in interface org.apache.flink.runtime.execution.Environment
Declines a checkpoint.
declineCheckpoint(JobID, ExecutionAttemptID, long, Throwable) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
DeclineCheckpoint - Class in org.apache.flink.runtime.messages.checkpoint
This message is sent from the TaskManager to the JobManager to tell the checkpoint coordinator that a checkpoint request could not be heeded.
DeclineCheckpoint(JobID, ExecutionAttemptID, long) - Constructor for class org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint
 
DeclineCheckpoint(JobID, ExecutionAttemptID, long, Throwable) - Constructor for class org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint
 
declineCheckpoint(JobID, ExecutionAttemptID, long, Throwable) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcCheckpointResponder
 
declineCheckpoint(JobID, ExecutionAttemptID, long, Throwable) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayCheckpointResponder
 
declineCheckpoint(JobID, ExecutionAttemptID, long, Throwable) - Method in interface org.apache.flink.runtime.taskmanager.CheckpointResponder
Declines the given checkpoint.
declineCheckpoint(long, Throwable) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
decode(ChannelHandlerContext, HttpObject, List<Object>) - Method in class org.apache.flink.runtime.rest.FlinkHttpObjectAggregator
 
decodePathFromReference(CheckpointStorageLocationReference) - Static method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
Decodes the given reference into a path.
decorate(Object) - Method in class org.apache.flink.runtime.messages.LeaderSessionMessageDecorator
 
decorate(Object) - Method in interface org.apache.flink.runtime.messages.MessageDecorator
Decorates a message
decorateMessage(Object) - Method in class org.apache.flink.runtime.akka.FlinkUntypedActor
This method should be called for every outgoing message.
decorateWithCompression(NonClosingOutpusStreamDecorator) - Method in class org.apache.flink.runtime.state.SnappyStreamCompressionDecorator
 
decorateWithCompression(NonClosingInputStreamDecorator) - Method in class org.apache.flink.runtime.state.SnappyStreamCompressionDecorator
 
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(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(NonClosingOutpusStreamDecorator) - Method in class org.apache.flink.runtime.state.StreamCompressionDecorator
 
decorateWithCompression(NonClosingInputStreamDecorator) - Method in class org.apache.flink.runtime.state.StreamCompressionDecorator
 
decorateWithCompression(NonClosingOutpusStreamDecorator) - Method in class org.apache.flink.runtime.state.UncompressedStreamCompressionDecorator
 
decorateWithCompression(NonClosingInputStreamDecorator) - Method in class org.apache.flink.runtime.state.UncompressedStreamCompressionDecorator
 
decreaseBuffersInBacklog(Buffer) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
Decreases the number of non-event buffers by one after fetching a non-event buffer from this subpartition (for access by the subpartition views).
decreaseBuffersInBacklogUnsafe(boolean) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
decrement() - Method in class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
Decrements the reference count and returns whether the reference counter entered the disposed state.
decrementReference(BatchTask<?, ?>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
 
decrementReferenceIfHeld(BatchTask<?, ?>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
 
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.RegisteredBroadcastBackendStateMetaInfo
Creates a deep copy of the itself.
deepCopy() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo
Creates a deep copy of the itself.
DEFAULT_FACTORY - Static variable in class org.apache.flink.runtime.state.SharedStateRegistry
A singleton object for the default implementation of a SharedStateRegistryFactory
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_MAX_STATE_SIZE - Static variable in class org.apache.flink.runtime.state.memory.MemoryStateBackend
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_PAGE_SIZE - Static variable in class org.apache.flink.runtime.memory.MemoryManager
The default memory page size.
DEFAULT_WRITE_BUFFER_SIZE - Static variable in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
Default size for the write buffer
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.
DefaultBroadcastVariableInitializer<T> - Class in org.apache.flink.runtime.broadcast
The default BroadcastVariableInitializer implementation that initializes the broadcast variable into a list.
DefaultJobManagerJobMetricGroupFactory - Class in org.apache.flink.runtime.jobmaster.factories
Default implementation of JobManagerJobMetricGroupFactory which creates for a given JobGraph a JobManagerJobMetricGroup.
DefaultJobManagerJobMetricGroupFactory(JobManagerMetricGroup) - Constructor for class org.apache.flink.runtime.jobmaster.factories.DefaultJobManagerJobMetricGroupFactory
 
DefaultKeyedStateStore - Class in org.apache.flink.runtime.state
Default implementation of KeyedStateStore that currently forwards state registration to a RuntimeContext.
DefaultKeyedStateStore(KeyedStateBackend<?>, ExecutionConfig) - Constructor for class org.apache.flink.runtime.state.DefaultKeyedStateStore
 
defaultMetricRegistryConfiguration() - Static method in class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
 
DefaultOperatorStateBackend - Class in org.apache.flink.runtime.state
Default implementation of OperatorStateStore that provides the ability to make snapshots.
DefaultOperatorStateBackend(ClassLoader, ExecutionConfig, boolean) - Constructor for class org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
DefaultQuarantineHandler - Class in org.apache.flink.runtime.akka
Default quarantine handler which logs the quarantining events, then shuts down the given actor system by sending Kill to all actors and then shutting the JVM down with the given exit code.
DefaultQuarantineHandler(Time, int, Logger) - Constructor for class org.apache.flink.runtime.akka.DefaultQuarantineHandler
 
DefaultSlotPoolFactory - Class in org.apache.flink.runtime.jobmaster.slotpool
Default slot pool factory.
DefaultSlotPoolFactory(RpcService, SchedulingStrategy, Clock, Time, Time) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.DefaultSlotPoolFactory
 
delegate - Variable in class org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
 
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
 
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
 
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) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
Deletes the file underlying the given channel.
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(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(TransientBlobKey) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
 
deleteFromCache(JobID, 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.
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.
deleteTmpFile(String, JobID) - Method in class org.apache.flink.runtime.filecache.FileCache
Deletes the local file after a 5 second delay.
DependencyVisitor - Class in org.apache.flink.runtime.util
This class tracks class dependency with ASM visitors.
DependencyVisitor(int) - Constructor for class org.apache.flink.runtime.util.DependencyVisitor
 
DependencyVisitor.AnnotationVisitorImpl - Class in org.apache.flink.runtime.util
 
DependencyVisitor.FieldVisitorImpl - Class in org.apache.flink.runtime.util
 
DependencyVisitor.MethodVisitorImpl - Class in org.apache.flink.runtime.util
 
DependencyVisitor.SignatureVisitorImpl - Class in org.apache.flink.runtime.util
 
deploy() - Method in class org.apache.flink.runtime.executiongraph.Execution
Deploys the execution to the previously assigned resource.
deployToSlot(SimpleSlot) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
deprecated() - Static method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
 
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.
DescriptiveStatisticsHistogram - Class in org.apache.flink.runtime.metrics
The DescriptiveStatisticsHistogram use a DescriptiveStatistics DescriptiveStatistics as a Flink Histogram.
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(DescriptiveStatistics) - Constructor for class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
 
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(DataInputStream, ClassLoader) - Method in interface org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializer
Deserializes a savepoint from an input stream.
deserialize(DataInputStream, ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
deserialize(JsonParser, DeserializationContext) - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails.JobDetailsDeserializer
 
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(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.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.TriggerId.TriggerIdDeserializer
 
deserialize(DataInputView) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
deserialize(ArrayList<T>, DataInputView) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
 
deserialize(VoidNamespace, DataInputView) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
 
deserializeKey(String, DeserializationContext) - Method in class org.apache.flink.runtime.rest.messages.json.JobVertexIDKeyDeserializer
 
deserializeKeyedStateHandle(DataInputStream) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
deserializeOperatorStateHandle(DataInputStream) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
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.Deserializer
 
deserializeStreamStateHandle(DataInputStream) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
deserializeUserAccumulators(ClassLoader) - Method in class org.apache.flink.runtime.accumulators.AccumulatorSnapshot
Gets the user-defined accumulators values.
dest - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
dest - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
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
 
destroyBufferPool() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
 
directExecutionContext() - Static method in class org.apache.flink.runtime.concurrent.Executors
Return a direct execution context.
directExecutor() - Static method in class org.apache.flink.runtime.concurrent.Executors
Return a direct executor.
directory - Variable in class org.apache.flink.runtime.state.SnapshotDirectory
This path describes the underlying directory for the snapshot.
DirectoryKeyedStateHandle - Class in org.apache.flink.runtime.state
This class is a keyed state handle based on a directory.
DirectoryKeyedStateHandle(DirectoryStateHandle, KeyGroupRange) - Constructor for class org.apache.flink.runtime.state.DirectoryKeyedStateHandle
 
DirectoryStateHandle - Class in org.apache.flink.runtime.state
This state handle represents a directory.
DirectoryStateHandle(Path) - Constructor for class org.apache.flink.runtime.state.DirectoryStateHandle
 
disabled() - Static method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
Gets the configuration describing the queryable state as deactivated.
discardOnFailedStoring() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
discardOnShutdown(JobStatus) - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
discardOnSubsume() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
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
 
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.ChainedStateHandle
 
discardState() - Method in class org.apache.flink.runtime.state.DirectoryKeyedStateHandle
 
discardState() - Method in class org.apache.flink.runtime.state.DirectoryStateHandle
 
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.IncrementalKeyedStateHandle
 
discardState() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
 
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.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(RunnableFuture<? extends StateObject>) - Static method in class org.apache.flink.runtime.state.StateUtil
Discards the given state future by first trying to cancel it.
disconnectFromJobManager(InstanceID, Exception) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
disconnectFromJobManager(InstanceID, Exception) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Disconnect the task manager from the job manager.
disconnectFromJobManager(InstanceID, Exception) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
disconnectJobManager(JobID, Exception) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
disconnectJobManager(JobID, Exception) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Disconnects a JobManager specified by the given resourceID from the ResourceManager.
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.
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.
disconnectResourceManager() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
 
disconnectResourceManager() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolGateway
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.
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 TaskExecutor from the JobMaster.
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.
Dispatcher - Class in org.apache.flink.runtime.dispatcher
Base class for the Dispatcher component.
Dispatcher(RpcService, String, Configuration, HighAvailabilityServices, SubmittedJobGraphStore, ResourceManagerGateway, BlobServer, HeartbeatServices, JobManagerMetricGroup, String, ArchivedExecutionGraphStore, Dispatcher.JobManagerRunnerFactory, FatalErrorHandler, String, HistoryServerArchivist) - Constructor for class org.apache.flink.runtime.dispatcher.Dispatcher
 
Dispatcher.DefaultJobManagerRunnerFactory - Enum in org.apache.flink.runtime.dispatcher
Singleton default factory for JobManagerRunner.
Dispatcher.JobManagerRunnerFactory - Interface in org.apache.flink.runtime.dispatcher
Factory for a JobManagerRunner.
DISPATCHER_NAME - Static variable in class org.apache.flink.runtime.dispatcher.Dispatcher
 
DispatcherException - Exception in org.apache.flink.runtime.dispatcher
Base class for Dispatcher related exceptions.
DispatcherException(String) - Constructor for exception org.apache.flink.runtime.dispatcher.DispatcherException
 
DispatcherException(Throwable) - Constructor for exception org.apache.flink.runtime.dispatcher.DispatcherException
 
DispatcherException(String, Throwable) - Constructor for exception org.apache.flink.runtime.dispatcher.DispatcherException
 
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.
DispatcherRestEndpoint - Class in org.apache.flink.runtime.dispatcher
REST endpoint for the Dispatcher component.
DispatcherRestEndpoint(RestServerEndpointConfiguration, GatewayRetriever<DispatcherGateway>, Configuration, RestHandlerConfiguration, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, Executor, MetricQueryServiceRetriever, LeaderElectionService, FatalErrorHandler) - Constructor for class org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint
 
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.
DispatcherThreadFactory(ThreadGroup, String, ClassLoader) - Constructor for class org.apache.flink.runtime.taskmanager.DispatcherThreadFactory
Creates a new thread factory.
dispose() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
 
dispose() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
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 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.
disposeIfNotUsed() - Method in class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
 
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, StateBackend, ClassLoader) - Static method in class org.apache.flink.runtime.checkpoint.Checkpoints
 
disposeSavepoint(String, Configuration, ClassLoader, Logger) - Static method in class org.apache.flink.runtime.checkpoint.Checkpoints
 
disposeSavepoint(String, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
disposeSavepoint(String) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
 
disposeSavepoint(String, Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
Dispose the given savepoint.
disposeSortBuffers(boolean) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Releases the memory that is registered for in-memory sorted run generation.
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
 
DistributedRuntimeUDFContext - Class in org.apache.flink.runtime.operators.util
A standalone implementation of the RuntimeContext, created by runtime UDF operators.
DistributedRuntimeUDFContext(TaskInfo, ClassLoader, ExecutionConfig, Map<String, Future<Path>>, Map<String, Accumulator<?, ?>>, MetricGroup) - 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.
done(boolean) - Method in class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
Optional callback that subclasses can implement.
done(boolean) - Method in interface org.apache.flink.runtime.io.async.AsyncDoneCallback
the callback
done() - Method in class org.apache.flink.runtime.io.async.AsyncStoppableTaskWithCallback
 
DoneFuture<T> - Class in org.apache.flink.runtime.state
A Future that 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
 
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(ExecutionGraph) - Constructor for class org.apache.flink.runtime.executiongraph.metrics.DownTimeGauge
 
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.
DualKeyMap<A,B,V> - Class in org.apache.flink.runtime.jobmaster.slotpool
Map which stores values under two different indices.
DualKeyMap(int) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
duplicate() - Method in class org.apache.flink.runtime.query.KvStateInfo
Creates a deep copy of the current KvStateInfo by duplicating all the included serializers.
duplicate() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
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(CheckpointStreamFactory.CheckpointStateOutputStream, CheckpointStreamFactory.CheckpointStateOutputStream) - Constructor for class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
 
DuplicatingCheckpointOutputStream(CheckpointStreamFactory.CheckpointStateOutputStream, CheckpointStreamFactory.CheckpointStateOutputStream, int) - Constructor for class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
 
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.

E

EmbeddedHaServices - Class in org.apache.flink.runtime.highavailability.nonha.embedded
An implementation of the HighAvailabilityServices for 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
 
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(T) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
emit() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.ReduceFacade
Emits all elements currently held by the table to the collector.
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.
empty() - Static method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
 
empty() - Static method in class org.apache.flink.runtime.resourcemanager.ResourceOverview
 
EMPTY - Static variable in class org.apache.flink.runtime.rest.handler.FileUploads
 
empty() - Static method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
 
empty() - Static method in class org.apache.flink.runtime.state.SnapshotResult
 
EMPTY - Static variable in class org.apache.flink.runtime.util.IntArrayList
 
empty() - Static method in interface org.apache.flink.runtime.webmonitor.WebMonitorExtension
 
EMPTY_KEY_GROUP_RANGE - Static variable in class org.apache.flink.runtime.state.KeyGroupRange
The empty key-group
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 PrioritizedOperatorSubtaskState singleton 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 ResponseBody implementation.
enableCheckpointing(long, long, long, int, CheckpointRetentionPolicy, List<ExecutionJobVertex>, List<ExecutionJobVertex>, List<ExecutionJobVertex>, List<MasterTriggerRestoreHook<?>>, CheckpointIDCounter, CompletedCheckpointStore, StateBackend, CheckpointStatsTracker) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
encodePathAsReference(Path) - Static method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
Encodes the given path as a reference in bytes.
ENCODING - Static variable in class org.apache.flink.runtime.rest.handler.util.HandlerRedirectUtils
 
endMarker() - Static method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Gets the element that is passed as marker for the end of data.
EndOfPartitionEvent - Class in org.apache.flink.runtime.io.network.api
This event marks a subpartition as fully consumed.
EndOfSuperstepEvent - Class in org.apache.flink.runtime.io.network.api
Marks the end of a superstep of one particular iteration superstep.
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
ensureWritable(int) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
enterMainThread() - Method in class org.apache.flink.runtime.rpc.MainThreadValidatorUtil
 
entries() - Method in class org.apache.flink.runtime.state.heap.HeapMapState
 
entries() - Method in class org.apache.flink.runtime.state.HeapBroadcastState
 
EntryIterator() - Constructor for class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.EntryIterator
 
Enumerator(File[], Random) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.Enumerator
 
envelopeSelfMessage(Object) - Method in class org.apache.flink.runtime.rpc.akka.FencedAkkaRpcActor
 
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, ...
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.
equals(Object) - Method in class org.apache.flink.runtime.blob.BlobKey
 
equals(Object) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
 
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.OperatorState
 
equals(Object) - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
 
equals(Object) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
 
equals(Object) - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
 
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.messages.CheckAndAllocateContainers
 
equals(Object) - Method in class org.apache.flink.runtime.clusterframework.messages.GetClusterStatus
 
equals(Object) - Method in class org.apache.flink.runtime.clusterframework.messages.GetClusterStatusResponse
 
equals(Object) - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListener
 
equals(Object) - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListenerSuccessful
 
equals(Object) - Method in class org.apache.flink.runtime.clusterframework.messages.SetWorkerPoolSize
 
equals(Object) - Method in class org.apache.flink.runtime.clusterframework.messages.UnRegisterInfoMessageListener
 
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.instance.HardwareDescription
 
equals(Object) - Method in class org.apache.flink.runtime.instance.Slot
Slots must always compare on referential equality.
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.EndOfPartitionEvent
 
equals(Object) - Method in class org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
 
equals(Object) - Method in class org.apache.flink.runtime.io.network.ConnectionID
 
equals(Object) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionID
 
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 exception org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
 
equals(Object) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
equals(Object) - Method in class org.apache.flink.runtime.jobmaster.ResourceManagerAddress
 
equals(Object) - Method in class org.apache.flink.runtime.leaderelection.LeaderAddressAndId
 
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.checkpoint.NotifyCheckpointComplete
 
equals(Object) - Method in class org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
 
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.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.query.KvStateInfo
 
equals(Object) - Method in class org.apache.flink.runtime.query.KvStateLocation
 
equals(Object) - Method in class org.apache.flink.runtime.rest.handler.async.OperationKey
 
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.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.MinMaxAvgStatistics
 
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.ClusterConfigurationInfoEntry
 
equals(Object) - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
 
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.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.JobExceptionsInfo
 
equals(Object) - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfo.ExecutionExceptionInfo
 
equals(Object) - Method in class org.apache.flink.runtime.rest.messages.JobPlanInfo
 
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.JobVertexDetailsInfo.VertexTaskDetail
 
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.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.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.state.ArrayListSerializer
 
equals(Object) - Method in class org.apache.flink.runtime.state.ChainedStateHandle
 
equals(Object) - Method in class org.apache.flink.runtime.state.CheckpointStorageLocationReference
 
equals(Object) - Method in class org.apache.flink.runtime.state.DirectoryKeyedStateHandle
 
equals(Object) - Method in class org.apache.flink.runtime.state.DirectoryStateHandle
 
equals(Object) - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
 
equals(Object) - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
This method is should only be called in tests! This should never serve as key in a hash map.
equals(Object) - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
 
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.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.RegisteredBroadcastBackendStateMetaInfo
 
equals(Object) - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo.Snapshot
 
equals(Object) - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
 
equals(Object) - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo.Snapshot
 
equals(Object) - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo
 
equals(Object) - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo.Snapshot
 
equals(Object) - Method in class org.apache.flink.runtime.state.SnapshotDirectory
 
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.SlotOffer
 
equals(Object) - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
 
equals(Object) - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
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.OperatorSubtaskDescriptionText
 
equals(Object) - Method in class org.apache.flink.runtime.webmonitor.history.ArchivedJson
 
error() - Method in class org.apache.flink.runtime.clusterframework.messages.FatalErrorOccurred
 
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
 
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.
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
 
eventualOutputs - Variable in class org.apache.flink.runtime.operators.BatchTask
The output writers for the data that this task forwards to the next task.
EvictingBoundedList<T> - Class in org.apache.flink.runtime.util
This class implements a list (array based) that is physically bounded in maximum size, but can virtually grow beyond the bounded size.
EvictingBoundedList(int) - Constructor for class org.apache.flink.runtime.util.EvictingBoundedList
 
EvictingBoundedList(EvictingBoundedList<T>) - Constructor for class org.apache.flink.runtime.util.EvictingBoundedList
 
EvictingBoundedList(int, T) - Constructor for class org.apache.flink.runtime.util.EvictingBoundedList
 
EvictingBoundedList.Function<I,O> - Interface in org.apache.flink.runtime.util
A simple unary function that can be used to transform elements via the EvictingBoundedList.map(Function) method.
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.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.
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
 
exceptionUnwrap(Exception) - Static method in exception org.apache.flink.runtime.operators.chaining.ExceptionInChainedStubException
 
excludeFromReset(int) - Method in class org.apache.flink.runtime.operators.BatchTask
 
executable - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
executable - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
execute(Runnable) - Method in class org.apache.flink.runtime.concurrent.akka.ActorSystemScheduledExecutorAdapter
 
execute(Runnable) - Method in class org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
 
execute(Runnable) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
execute(Callable<T>) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
execute(Runnable) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint.MainThreadExecutor
 
execute(Runnable) - Method in interface org.apache.flink.runtime.rpc.RpcService
Execute the given runnable in the executor of the RPC service.
execute(Callable<T>) - Method in interface org.apache.flink.runtime.rpc.RpcService
Execute the given callable and return its result as a CompletableFuture.
executeJobBlocking(JobGraph) - Method in interface org.apache.flink.runtime.minicluster.JobExecutor
Run the given job and block until its execution result can be returned.
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, long, Time) - Constructor for class org.apache.flink.runtime.executiongraph.Execution
Creates a new Execution attempt.
EXECUTION_MODE - Static variable in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
ExecutionAndAllocationFuture - Class in org.apache.flink.runtime.executiongraph
A pair of an Execution together with an allocation future.
ExecutionAndAllocationFuture(Execution, CompletableFuture<Void>) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionAndAllocationFuture
 
executionAttempt - Variable in class org.apache.flink.runtime.executiongraph.ExecutionAndAllocationFuture
 
ExecutionAttemptID - Class in org.apache.flink.runtime.executiongraph
Unique identifier for the attempt to execute a tasks.
ExecutionAttemptID() - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionAttemptID
 
ExecutionAttemptID(long, long) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionAttemptID
 
executionConfig - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
executionConfig - Variable in class org.apache.flink.runtime.state.DefaultKeyedStateStore
 
ExecutionConfigInfo(String, String, int, boolean, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
 
ExecutionEdge - Class in org.apache.flink.runtime.executiongraph
 
ExecutionEdge(IntermediateResultPartition, ExecutionVertex, int) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionEdge
 
ExecutionExceptionInfo(String, String, String, long) - Constructor for class org.apache.flink.runtime.rest.messages.JobExceptionsInfo.ExecutionExceptionInfo
 
ExecutionGraph - Class in org.apache.flink.runtime.executiongraph
The execution graph is the central data structure that coordinates the distributed execution of a data flow.
ExecutionGraph(JobInformation, ScheduledExecutorService, Executor, Time, RestartStrategy, FailoverStrategy.Factory, SlotProvider, ClassLoader, BlobWriter, Time) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
ExecutionGraphBuilder - Class in org.apache.flink.runtime.executiongraph
Utility class to encapsulate the logic of building an ExecutionGraph from a JobGraph.
ExecutionGraphCache - Class in org.apache.flink.runtime.rest.handler.legacy
Cache for AccessExecutionGraph which are obtained from the Flink cluster.
ExecutionGraphCache(Time, Time) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.ExecutionGraphCache
 
ExecutionGraphException - Exception in org.apache.flink.runtime.executiongraph
Base class for exceptions occurring in the ExecutionGraph.
ExecutionGraphException(String) - Constructor for exception org.apache.flink.runtime.executiongraph.ExecutionGraphException
 
ExecutionGraphException(String, Throwable) - Constructor for exception org.apache.flink.runtime.executiongraph.ExecutionGraphException
 
ExecutionGraphException(Throwable) - Constructor for exception org.apache.flink.runtime.executiongraph.ExecutionGraphException
 
ExecutionGraphException - Exception in org.apache.flink.runtime.jobmaster
Exceptions thrown by operations on the ExecutionGraph by the JobMaster.
ExecutionGraphException(String) - Constructor for exception org.apache.flink.runtime.jobmaster.ExecutionGraphException
 
ExecutionGraphException(String, Throwable) - Constructor for exception org.apache.flink.runtime.jobmaster.ExecutionGraphException
 
ExecutionGraphException(Throwable) - Constructor for exception org.apache.flink.runtime.jobmaster.ExecutionGraphException
 
ExecutionGraphRestartCallback - Class in org.apache.flink.runtime.executiongraph.restart
A RestartCallback that abstracts restart calls on an ExecutionGraph.
ExecutionGraphRestartCallback(ExecutionGraph, long) - Constructor for class org.apache.flink.runtime.executiongraph.restart.ExecutionGraphRestartCallback
Creates a new ExecutionGraphRestartCallback.
executionId() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
ExecutionJobVertex - Class in org.apache.flink.runtime.executiongraph
An ExecutionJobVertex is part of the ExecutionGraph, and the peer to the JobVertex.
ExecutionJobVertex(ExecutionGraph, JobVertex, int, Time, long, long) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
ExecutionState - Enum in org.apache.flink.runtime.execution
An enumeration of all states that a task can be in during its execution.
executionStatusChanged(JobID, JobVertexID, String, int, int, ExecutionAttemptID, ExecutionState, long, String) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionStatusListener
Called whenever the execution status of a task changes.
executionStatusChanged(JobID, JobVertexID, String, int, int, ExecutionAttemptID, ExecutionState, long, String) - Method in class org.apache.flink.runtime.executiongraph.StatusListenerMessenger
 
ExecutionStatusListener - Interface in org.apache.flink.runtime.executiongraph
Interface for observers that monitor the status of individual task executions.
ExecutionVertex - Class in org.apache.flink.runtime.executiongraph
The ExecutionVertex is a parallel subtask of the execution.
ExecutionVertex(ExecutionJobVertex, int, IntermediateResult[], Time, long, long, int) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
executor - Variable in class org.apache.flink.runtime.rest.handler.legacy.AbstractJsonRequestHandler
 
executor - Variable in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
 
Executors - Class in org.apache.flink.runtime.concurrent
Collection of Executor implementations.
Executors() - Constructor for class org.apache.flink.runtime.concurrent.Executors
 
ExecutorThreadFactory - Class in org.apache.flink.runtime.util
A thread factory intended for use by critical thread pools.
ExecutorThreadFactory() - Constructor for class org.apache.flink.runtime.util.ExecutorThreadFactory
Creates a new thread factory using the default thread pool name ('flink-executor-pool') and the default uncaught exception handler (log exception and kill process).
ExecutorThreadFactory(String) - Constructor for class org.apache.flink.runtime.util.ExecutorThreadFactory
Creates a new thread factory using the given thread pool name and the default uncaught exception handler (log exception and kill process).
ExecutorThreadFactory(String, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.flink.runtime.util.ExecutorThreadFactory
Creates a new thread factory using the given thread pool name and the given uncaught exception handler.
exists() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
 
exists(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Returns the version of the node if it exists or -1 if it doesn't.
existsActiveSlot(JobID, AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Check whether there exists an active slot for the given job and allocation id.
EXIT_CODE_FATAL_ERROR - Static variable in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
The exit code with which the process is stopped in case of a fatal error
exitMainThread() - Method in class org.apache.flink.runtime.rpc.MainThreadValidatorUtil
 
expectedEntries - Variable in class org.apache.flink.runtime.operators.util.BloomFilter
 
expectedModVersion() - Method in exception org.apache.flink.runtime.executiongraph.GlobalModVersionMismatch
 
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
 
extract - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
extract - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
extractFromSystem(long) - Static method in class org.apache.flink.runtime.instance.HardwareDescription
 
extractImplementedRpcGateways(Class<?>) - Static method in class org.apache.flink.runtime.rpc.RpcUtils
Extracts all RpcGateway interfaces implemented by the given clazz.

F

Factory() - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy.Factory
 
Factory() - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy.Factory
 
Factory() - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy.Factory
 
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 interface org.apache.flink.runtime.jobmaster.LogicalSlot.Payload
Fail the payload with the given cause.
failAllocation(AllocationID, Exception) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
Fail the specified allocation and release the corresponding slot if we have one.
failAllocation(AllocationID, Exception) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolGateway
Fails the slot with the given allocation id.
FailedCheckpointStatistics(long, CheckpointStatsStatus, boolean, long, long, long, long, long, int, int, 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 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.ExecutionGraph
Fails the execution graph globally.
FailoverRegion - Class in org.apache.flink.runtime.executiongraph.failover
FailoverRegion manages the failover of a minimal pipeline connected sub graph.
FailoverRegion(ExecutionGraph, Executor, List<ExecutionVertex>) - Constructor for class org.apache.flink.runtime.executiongraph.failover.FailoverRegion
 
FailoverStrategy - Class in org.apache.flink.runtime.executiongraph.failover
A FailoverStrategy describes how the job computation recovers from task failures.
FailoverStrategy() - Constructor for class org.apache.flink.runtime.executiongraph.failover.FailoverStrategy
 
FailoverStrategy.Factory - Interface in org.apache.flink.runtime.executiongraph.failover
This factory is a necessary indirection when creating the FailoverStrategy to that we can have both the FailoverStrategy final in the ExecutionGraph, and the ExecutionGraph final in the FailOverStrategy.
FailoverStrategyLoader - Class in org.apache.flink.runtime.executiongraph.failover
A utility class to load failover strategies from the configuration.
FailoverStrategyLoader() - Constructor for class org.apache.flink.runtime.executiongraph.failover.FailoverStrategyLoader
 
failPartition(ExecutionAttemptID) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
failPartition(ExecutionAttemptID) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Fail all intermediate result partitions of the given task.
failPartition(ExecutionAttemptID) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
failPartition(ExecutionAttemptID) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
failPartition(ExecutionAttemptID) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Fail all intermediate result partitions of the given task.
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 class org.apache.flink.runtime.taskmanager.ActorGatewayTaskManagerActions
 
failTask(ExecutionAttemptID, Throwable) - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerActions
Tells the task manager to fail the given task.
failUnacknowledgedPendingCheckpointsFor(ExecutionAttemptID, Throwable) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Fails all pending checkpoints which have not been acknowledged by the given execution attempt id.
FailureRateRestartStrategy - Class in org.apache.flink.runtime.executiongraph.restart
Restart strategy which tries to restart the given ExecutionGraph when failure rate exceeded with a fixed time delay in between.
FailureRateRestartStrategy(int, Time, Time) - Constructor for class org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy
 
FailureRateRestartStrategy.FailureRateRestartStrategyFactory - Class in org.apache.flink.runtime.executiongraph.restart
 
FailureRateRestartStrategyFactory(int, Time, Time) - Constructor for class org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy.FailureRateRestartStrategyFactory
 
fatalError(String, Throwable) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Notifies the resource master of a fatal error.
fatalError(String, Throwable) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
FatalErrorHandler - Interface in org.apache.flink.runtime.rpc
Handler for fatal errors.
FatalErrorOccurred - Class in org.apache.flink.runtime.clusterframework.messages
Message sent to the Flink's resource manager in case of a fatal error that cannot be recovered in the running process.
FatalErrorOccurred(String, Throwable) - Constructor for class org.apache.flink.runtime.clusterframework.messages.FatalErrorOccurred
 
FatalExitExceptionHandler - Class in org.apache.flink.runtime.util
Handler for uncaught exceptions that will log the exception and kill the process afterwards.
FatalExitExceptionHandler() - Constructor for class org.apache.flink.runtime.util.FatalExitExceptionHandler
 
FencedAkkaInvocationHandler<F extends Serializable> - Class in org.apache.flink.runtime.rpc.akka
Fenced extension of the AkkaInvocationHandler.
FencedAkkaInvocationHandler(String, String, ActorRef, Time, long, CompletableFuture<Void>, Supplier<F>) - Constructor for class org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
 
FencedAkkaRpcActor<F extends Serializable,T extends FencedRpcEndpoint<F> & RpcGateway> - Class in org.apache.flink.runtime.rpc.akka
Fenced extension of the AkkaRpcActor.
FencedAkkaRpcActor(T, CompletableFuture<Boolean>, int) - Constructor for class org.apache.flink.runtime.rpc.akka.FencedAkkaRpcActor
 
FencedMainThreadExecutable - Interface in org.apache.flink.runtime.rpc
Extended MainThreadExecutable interface which allows to run unfenced runnables in the main thread.
FencedMessage<F extends Serializable,P> - Interface in org.apache.flink.runtime.rpc.messages
Interface for fenced messages.
FencedRpcEndpoint<F extends Serializable> - Class in org.apache.flink.runtime.rpc
Base class for fenced RpcEndpoint.
FencedRpcEndpoint(RpcService, String) - Constructor for class org.apache.flink.runtime.rpc.FencedRpcEndpoint
 
FencedRpcEndpoint(RpcService) - Constructor for class org.apache.flink.runtime.rpc.FencedRpcEndpoint
 
FencedRpcGateway<F extends Serializable> - Interface in org.apache.flink.runtime.rpc
Fenced RpcGateway.
fenceRpcServer(RpcServer, F) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
fenceRpcServer(RpcServer, F) - Method in interface org.apache.flink.runtime.rpc.RpcService
Fence the given RpcServer with the given fencing token.
FencingTokenException - Exception in org.apache.flink.runtime.rpc.exceptions
Exception which is thrown if the fencing tokens of a FencedRpcEndpoint do not match.
FencingTokenException(String) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.FencingTokenException
 
FencingTokenException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.FencingTokenException
 
FencingTokenException(Throwable) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.FencingTokenException
 
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_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_ALL_EXCEPTIONS - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfo
 
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 - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
 
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_AVERAGE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
 
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_BUFFERED_DATA - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
 
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_TIMEOUT - 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_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_CONFIG_KEY - Static variable in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoEntry
 
FIELD_NAME_CONFIG_VALUE - Static variable in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoEntry
 
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_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.JobVertexDetailsInfo.VertexTaskDetail
 
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_TIME - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
 
FIELD_NAME_END_TIMESTAMP - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
 
FIELD_NAME_EXCEPTION - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfo.ExecutionExceptionInfo
 
FIELD_NAME_EXECUTION_CONFIG - Static variable in class org.apache.flink.runtime.rest.messages.JobConfigInfo
 
FIELD_NAME_EXECUTION_MODE - Static variable in class org.apache.flink.runtime.rest.messages.JobConfigInfo.ExecutionConfigInfo
 
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_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_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_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_HOST - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
FIELD_NAME_HOST - Static variable in class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo
 
FIELD_NAME_HOST - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
 
FIELD_NAME_HOST - Static variable in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
 
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_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_JOB_ACCUMULATORS - Static variable in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
 
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_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_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_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_LOCATION - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfo.ExecutionExceptionInfo
 
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_MAXIMUM - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
 
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.JobVertexDetailsInfo.VertexTaskDetail
 
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.MinMaxAvgStatistics
 
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_MEMORY_SEGMENTS_AVAILABLE - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
 
FIELD_NAME_NETWORK_MEMROY_SEGMENTS_TOTAL - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo
 
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_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_PROCESSING_MODE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
 
FIELD_NAME_RATIO - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
 
FIELD_NAME_REFRESH_INTERVAL - Static variable in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
 
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_ROOT_EXCEPTION - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfo
 
FIELD_NAME_SAVEPOINT - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
 
FIELD_NAME_SERIALIZED_USER_TASK_ACCUMULATORS - Static variable in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
 
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_SLOTS_AVAILABLE - 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_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_START_TIME - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
 
FIELD_NAME_STATE_SIZE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
 
FIELD_NAME_STATE_SIZE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
FIELD_NAME_STATE_SIZE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
 
FIELD_NAME_STATE_SIZE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
 
FIELD_NAME_STATE_SIZE - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
 
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.JobVertexDetailsInfo.VertexTaskDetail
 
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.JobVertexDetailsInfo.VertexTaskDetail
 
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_TASK - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfo.ExecutionExceptionInfo
 
FIELD_NAME_TASK_MANAGERS - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersInfo
 
FIELD_NAME_TASKMANAGERS - 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_TIME - Static variable in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo.GarbageCollectorInfo
 
FIELD_NAME_TIMESTAMP - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfo.ExecutionExceptionInfo
 
FIELD_NAME_TIMESTAMP - Static variable in class org.apache.flink.runtime.rest.messages.JobExceptionsInfo
 
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_TOTAL_CHECKPOINTS - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
 
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.JobExceptionsInfo
 
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
 
FieldVisitorImpl(int) - Constructor for class org.apache.flink.runtime.util.DependencyVisitor.FieldVisitorImpl
 
FileArchivedExecutionGraphStore - Class in org.apache.flink.runtime.dispatcher
FileArchivedExecutionGraphStore(File, Time, long, ScheduledExecutor, Ticker) - Constructor for class org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
 
FileBasedStateOutputStream - Class in org.apache.flink.runtime.state.filesystem
A CheckpointStreamFactory.CheckpointStateOutputStream that writes into a specified file and returns a FileStateHandle upon 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 create the local files for the registered cache files when a task is deployed.
FileCache(String[]) - 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 DataInputView that is backed by a BlockChannelReader, making it effectively a data input stream.
FileChannelInputView(BlockChannelReader<MemorySegment>, MemoryManager, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.FileChannelInputView
 
FileChannelOutputView - Class in org.apache.flink.runtime.io.disk
A DataOutputView that is backed by a BlockChannelWriter, making it effectively a data output stream.
FileChannelOutputView(BlockChannelWriter<MemorySegment>, MemoryManager, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.FileChannelOutputView
 
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.
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
 
FileStateHandle - Class in org.apache.flink.runtime.state.filesystem
StreamStateHandle for 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.SnapshotDirectory
The filesystem that contains the snapshot directory.
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
 
FileSystemStateStorageHelper<T extends Serializable> - Class in org.apache.flink.runtime.zookeeper.filesystem
RetrievableStateStorageHelper implementation which stores the state in the given filesystem path.
FileSystemStateStorageHelper(String, String) - Constructor for class org.apache.flink.runtime.zookeeper.filesystem.FileSystemStateStorageHelper
 
FileSystemStateStorageHelper(Path, String) - Constructor for class org.apache.flink.runtime.zookeeper.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) - 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
 
finalizeBuildPhase(IOManager, FileIOChannel.Enumerator, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
 
finalizeCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
finalizeOnMaster(ClassLoader) - 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.
finalizeOnMaster(ClassLoader) - Method in class org.apache.flink.runtime.jobgraph.OutputFormatVertex
 
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
 
finalStatus() - Method in class org.apache.flink.runtime.clusterframework.messages.StopCluster
 
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(FiniteDuration) - Method in class org.apache.flink.runtime.net.ConnectionUtils.LeaderConnectingAddressListener
 
findConnectingAddress(FiniteDuration, FiniteDuration) - Method in class org.apache.flink.runtime.net.ConnectionUtils.LeaderConnectingAddressListener
 
findConnectingAddress(LeaderRetrievalService, Time) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
 
findConnectingAddress(LeaderRetrievalService, FiniteDuration) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
 
findMatchingRequest(ResourceProfile) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Finds a matching slot request for a given resource profile.
findMatchingSlot(ResourceProfile) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Finds a matching slot for a given resource profile.
findMatchWithLocality(SlotProfile, Stream<IN>, Function<IN, SlotContext>, Predicate<IN>, BiFunction<IN, Locality, OUT>) - Method in class org.apache.flink.runtime.jobmaster.slotpool.LocationPreferenceSchedulingStrategy
 
findMatchWithLocality(SlotProfile, Stream<IN>, Function<IN, SlotContext>, Predicate<IN>, BiFunction<IN, Locality, OUT>) - Method in class org.apache.flink.runtime.jobmaster.slotpool.PreviousAllocationSchedulingStrategy
 
findMatchWithLocality(SlotProfile, Stream<IN>, Function<IN, SlotContext>, Predicate<IN>, BiFunction<IN, Locality, OUT>) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SchedulingStrategy
This method takes the candidate slots, extracts slot contexts from them, filters them by the profile requirements and potentially by additional requirements, and produces a result from a match.
findVertexByID(JobVertexID) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Searches for a vertex with a matching ID and returns it.
finish() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
Mark this BufferBuilder and associated BufferConsumer as finished - no new data writes will be allowed.
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
 
finishWriteAndSortKeys(List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.sort.LargeRecordHandler
 
firstDam() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
 
FixedDelayRestartStrategy - Class in org.apache.flink.runtime.executiongraph.restart
Restart strategy which tries to restart the given ExecutionGraph a fixed number of times with a fixed time delay in between.
FixedDelayRestartStrategy(int, long) - Constructor for class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
 
FixedDelayRestartStrategy.FixedDelayRestartStrategyFactory - Class in org.apache.flink.runtime.executiongraph.restart
 
FixedDelayRestartStrategyFactory(int, long) - Constructor for class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy.FixedDelayRestartStrategyFactory
 
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
 
FLAG_LAST_BLOCK - Static variable in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
The flag marking a block as the last block.
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
 
FlinkDistributionOverlay - Class in org.apache.flink.runtime.clusterframework.overlays
Overlays Flink into a container, based on supplied bin/conf/lib directories.
FlinkDistributionOverlay(File, File, File) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay
 
FlinkDistributionOverlay.Builder - Class in org.apache.flink.runtime.clusterframework.overlays
A builder for the FlinkDistributionOverlay.
FlinkHttpObjectAggregator - Class in org.apache.flink.runtime.rest
Same as HttpObjectDecoder but returns HTTP 413 to the client if the payload exceeds HttpObjectAggregator.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
 
FlinkResourceManager<WorkerType extends ResourceIDRetrievable> - Class in org.apache.flink.runtime.clusterframework
Worker allocation steps
FlinkResourceManager(int, Configuration, LeaderRetrievalService) - Constructor for class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Creates a AbstractFrameworkMaster actor.
FlinkUntypedActor - Class in org.apache.flink.runtime.akka
Base class for Flink's actors implemented with Java.
FlinkUntypedActor() - Constructor for class org.apache.flink.runtime.akka.FlinkUntypedActor
 
FlinkUserCodeClassLoaders - Class in org.apache.flink.runtime.execution.librarycache
Gives the URLClassLoader a nicer name for debugging purposes.
FlinkUserCodeClassLoaders() - Constructor for class org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders
 
FlinkUserCodeClassLoaders.ResolveOrder - Enum in org.apache.flink.runtime.execution.librarycache
Class resolution order for Flink URL ClassLoader.
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
 
floatingNetworkBuffersPerGate() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
flush(int) - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
Manually trigger consumption from enqueued BufferConsumers in one specified subpartition.
flush(int) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
 
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.DuplicatingCheckpointOutputStream
 
flush() - Method in class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
 
flush() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
 
flush() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
 
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
 
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 consumption from enqueued BufferConsumers in all subpartitions.
flushAll() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
 
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
 
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(JobManagerMetricGroup, JobID, String) - Method in class org.apache.flink.runtime.metrics.scope.JobManagerJobScopeFormat
 
formatScope(String) - Method in class org.apache.flink.runtime.metrics.scope.JobManagerScopeFormat
 
formatScope(TaskMetricGroup, OperatorID, String) - Method in class org.apache.flink.runtime.metrics.scope.OperatorScopeFormat
 
formatScope(TaskManagerMetricGroup, JobID, String) - Method in class org.apache.flink.runtime.metrics.scope.TaskManagerJobScopeFormat
 
formatScope(String, String) - Method in class org.apache.flink.runtime.metrics.scope.TaskManagerScopeFormat
 
formatScope(TaskManagerJobMetricGroup, AbstractID, AbstractID, String, int, int) - Method in class org.apache.flink.runtime.metrics.scope.TaskScopeFormat
 
formatSystemProperties(Configuration) - Static method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
Format the system properties as a shell-compatible command-line argument.
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
 
forSavepoint() - Static method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
Creates the checkpoint properties for a (manually triggered) savepoint.
forward(Object, ActorGateway) - Method in interface org.apache.flink.runtime.instance.ActorGateway
Forwards a message.
forward(Object, ActorGateway) - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
Forwards a message.
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
Output stream, that wraps another input stream and forwards all method calls to the wrapped stream.
ForwardingOutputStream(OutputStream) - Constructor for class org.apache.flink.runtime.util.ForwardingOutputStream
 
FreeingBufferRecycler - Class in org.apache.flink.runtime.io.network.buffer
A simple buffer recycler that frees the memory segments.
freeSlot() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
freeSlot(AllocationID, Throwable, Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
freeSlot(AllocationID, Throwable, Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Frees the slot with the given allocation ID.
freeSlot(AllocationID, Throwable, Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
freeSlot(SlotID, AllocationID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Free the given slot from the given allocation.
freeSlot() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
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 class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Try to free the slot.
freeSlot(AllocationID, Throwable) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Tries to free the slot.
freeSlot(AllocationID, Throwable, Time) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
freeSlot(AllocationID, Throwable, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Frees the slot with the given allocation ID.
from(IntermediateResultPartition, int, boolean) - Static method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
from(StoppableCallbackCallable<V>) - Static method in class org.apache.flink.runtime.io.async.AsyncStoppableTaskWithCallback
 
from(Configuration) - Static method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfo
 
from(long, ZonedDateTime) - Static method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
 
fromApplicationOrConfigOrDefault(StateBackend, Configuration, ClassLoader, Logger) - Static method in class org.apache.flink.runtime.state.StateBackendLoader
Checks if an application-defined state backend is given, and if not, loads the state backend from the configuration, from the parameter 'state.backend', as defined in CheckpointingOptions.STATE_BACKEND.
fromBuffer(Buffer, ClassLoader) - Static method in class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
 
fromByteBuf(ByteBuf) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionAttemptID
 
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.jobgraph.IntermediateResultPartitionID
 
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.
fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.heartbeat.HeartbeatServices
Creates an HeartbeatServices instance from a Configuration.
fromConfiguration(Configuration, BlobServer) - Static method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
 
fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.jobmaster.JobMasterConfiguration
 
fromConfiguration(Configuration, RpcService) - Static method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultSlotPoolFactory
 
fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
Create a metric registry configuration object from the given Configuration.
fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.resourcemanager.ResourceManagerConfiguration
 
fromConfiguration(ResourceManagerRuntimeServicesConfiguration, HighAvailabilityServices, ScheduledExecutor) - Static method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
 
fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
 
fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
 
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 RestClientConfiguration from the given Configuration.
fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
Creates and returns a new RestServerEndpointConfiguration from the given Configuration.
fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
fromConfiguration(TaskManagerServicesConfiguration, ResourceID, Executor, long, long) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
Creates and returns the task manager services.
fromConfiguration(Configuration, InetAddress, boolean) - 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.
fromEdge(IntermediateResultPartition, Execution) - Static method in class org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor
Creates a partial input channel for the given partition and producing task.
fromEdges(ExecutionEdge[], ResourceID, boolean) - Static method in class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
Creates an input channel deployment descriptor for each partition.
fromEnvironment(Configuration) - Method in class org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay.Builder
Configures the overlay using the current environment.
fromEnvironment(Configuration) - Method in class org.apache.flink.runtime.clusterframework.overlays.HadoopConfOverlay.Builder
Configures the overlay using the current environment's Hadoop configuration.
fromEnvironment(Configuration) - Method in class org.apache.flink.runtime.clusterframework.overlays.HadoopUserOverlay.Builder
Configures the overlay using the current Hadoop user information (from UserGroupInformation).
fromEnvironment(Configuration) - Method in class org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay.Builder
Configures the overlay using the current environment (and global configuration).
fromEnvironment(Configuration) - Method in class org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay.Builder
Configures the overlay using the current environment.
fromEnvironment(Configuration) - Method in class org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay.Builder
Configures the overlay using the current environment (and global configuration).
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
 
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.
fromJobVertexID(JobVertexID) - Static method in class org.apache.flink.runtime.jobgraph.OperatorID
 
fromKeyValueJsonArray(String) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
 
fromSerializedEvent(ByteBuffer, ClassLoader) - Static method in class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
 
fromStatusOverview(ClusterOverview, String, String) - Static method in class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
 
fromString(String) - Static method in enum org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders.ResolveOrder
 
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.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.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) or MetricGroup.getMetricIdentifier(String, CharacterFilter).
FrontMetricGroup(int, P) - Constructor for class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
 
FS_STATE_BACKEND_NAME - Static variable in class org.apache.flink.runtime.state.StateBackendLoader
The shortcut configuration name for the FileSystem State backend
FsCheckpointMetadataOutputStream - Class in org.apache.flink.runtime.state.filesystem
A CheckpointMetadataOutputStream that writes a specified file and directory, and returns a FsCompletedCheckpointStorageLocation upon 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
 
FsCheckpointStorage - Class in org.apache.flink.runtime.state.filesystem
An implementation of durable checkpoint storage to file systems.
FsCheckpointStorage(Path, Path, JobID, int) - Constructor for class org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
 
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) - Constructor for class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
 
FsCheckpointStreamFactory - Class in org.apache.flink.runtime.state.filesystem
A CheckpointStreamFactory that produces streams that write to a FileSystem.
FsCheckpointStreamFactory(FileSystem, Path, Path, 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 CheckpointStreamFactory.CheckpointStateOutputStream that writes into a file and returns a StreamStateHandle upon closing.
FsCompletedCheckpointStorageLocation - Class in org.apache.flink.runtime.state.filesystem
A CompletedCheckpointStorageLocation that resides on a file system.
FsCompletedCheckpointStorageLocation(FileSystem, Path, FileStateHandle, String) - Constructor for class org.apache.flink.runtime.state.filesystem.FsCompletedCheckpointStorageLocation
 
FsJobArchivist - Class in org.apache.flink.runtime.history
Utility class for writing an archive file to a FileSystem and reading it back.
FsNegativeRunningJobsRegistry - Class in org.apache.flink.runtime.highavailability
This RunningJobsRegistry tracks the status jobs via marker files, marking running jobs via running marker files, marking finished jobs via finished marker files.
FsNegativeRunningJobsRegistry(Path) - Constructor for class org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
Creates a new registry that writes to the FileSystem and working directory denoted by the given path.
FsNegativeRunningJobsRegistry(FileSystem, Path) - Constructor for class org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
Creates a new registry that writes its files to the given FileSystem at the given working directory path.
FsStateBackend - Class in org.apache.flink.runtime.state.filesystem
This state backend holds the working state in the memory (JVM heap) of the TaskManagers.
FsStateBackend(String) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(String, boolean) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(Path) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(Path, boolean) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(URI) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(URI, URI) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(URI, boolean) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(URI, int) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(URI, int, boolean) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(URI, URI, int, TernaryBoolean) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackendFactory - Class in org.apache.flink.runtime.state.filesystem
A factory that creates an FsStateBackend from a configuration.
FsStateBackendFactory() - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackendFactory
 
FULL_RESTART_STRATEGY_NAME - Static variable in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategyLoader
Config name for the RestartAllStrategy
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
 
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.
FunctionSnapshotContext - Interface in org.apache.flink.runtime.state
This interface provides a context in which user functions that use managed state (i.e.
furtherPartitioning - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
 
furtherPartitioning - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
future() - Method in class org.apache.flink.runtime.minicluster.OneTimeLeaderListenerFuture
Gets the future that is completed with the leader address and ID.
FutureUtils - Class in org.apache.flink.runtime.concurrent
A collection of utilities that expand the usage of CompletableFuture.
FutureUtils() - Constructor for class org.apache.flink.runtime.concurrent.FutureUtils
 
FutureUtils.ConjunctFuture<T> - Class in org.apache.flink.runtime.concurrent
A future that is complete once multiple other futures completed.
FutureUtils.RetryException - Exception in org.apache.flink.runtime.concurrent
Exception with which the returned future is completed if the FutureUtils.retry(Supplier, int, Executor) operation fails.

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
 
GatewayRetriever<T extends RpcGateway> - Interface in org.apache.flink.runtime.webmonitor.retriever
Generic retriever interface for RpcGateway.
gauge(int, G) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
gauge(String, G) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
gauge(int, G) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
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
 
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.
generateCheckpointStatistics(AbstractCheckpointStats, boolean) - Static method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
generatePlan(JobGraph) - Static method in class org.apache.flink.runtime.jobgraph.jsonplan.JsonPlanGenerator
 
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
 
generateSlotOffer() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Generate the slot offer from this TaskSlot.
generateTaskManagerConfiguration(Configuration, String, int, int, FiniteDuration) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
Generate a task manager configuration.
generateZookeeperPath(String, String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
 
GenericKeyMetricGroup - Class in org.apache.flink.runtime.metrics.groups
A GenericMetricGroup for representing the key part of a key-value metric group pair.
GenericMetricGroup - Class in org.apache.flink.runtime.metrics.groups
A simple named MetricGroup that is used to hold subgroups of metrics.
GenericMetricGroup(MetricRegistry, AbstractMetricGroup, String) - Constructor for class org.apache.flink.runtime.metrics.groups.GenericMetricGroup
 
GenericValueMetricGroup - Class in org.apache.flink.runtime.metrics.groups
A GenericMetricGroup for representing the value part of a key-value metric group pair.
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() - Static method in class org.apache.flink.runtime.clusterframework.messages.CheckAndAllocateContainers
Gets the singleton instance.
get() - Static method in class org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListenerSuccessful
Gets the singleton instance.
get() - Static method in class org.apache.flink.runtime.clusterframework.messages.UnRegisterInfoMessageListener
Gets the singleton instance.
get(JobID) - Method in interface org.apache.flink.runtime.dispatcher.ArchivedExecutionGraphStore
Get the ArchivedExecutionGraph for the given job id.
get(JobID) - Method in class org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
 
get(JobID) - Method in class org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
 
get(String) - Method in class org.apache.flink.runtime.iterative.concurrent.Broker
Blocking retrieval and removal of the object to share.
get() - Static method in class org.apache.flink.runtime.messages.Acknowledge
Gets the singleton instance.
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.operators.util.BloomFilter.BitSet
Returns true if the bit is set in the specified index.
get(K) - Method in class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.CompletedOperationCache
Returns the operation result or a Throwable if the CompletableFuture finished, otherwise null.
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() - Method in class org.apache.flink.runtime.state.DoneFuture
 
get(long, TimeUnit) - Method in class org.apache.flink.runtime.state.DoneFuture
 
get(K, N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
get(N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
get() - Method in class org.apache.flink.runtime.state.heap.HeapAggregatingState
 
get() - Method in class org.apache.flink.runtime.state.heap.HeapFoldingState
Deprecated.
 
get() - Method in class org.apache.flink.runtime.state.heap.HeapListState
 
get(UK) - Method in class org.apache.flink.runtime.state.heap.HeapMapState
 
get() - Method in class org.apache.flink.runtime.state.heap.HeapReducingState
 
get(N) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
get(K, N) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
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(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(K) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
 
get() - Static method in class org.apache.flink.runtime.state.VoidNamespace
Getter for the singleton instance
get(JobID) - Method in class org.apache.flink.runtime.taskexecutor.JobManagerTable
 
get() - Method in class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
 
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(int) - Method in class org.apache.flink.runtime.util.EvictingBoundedList
 
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
 
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.ExecutionGraph
Returns the a stringified version of the user-defined accumulators.
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.ExecutionGraph
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
Returns the summary stats for the ACK timestamps.
getAclForPath(String) - Method in class org.apache.flink.runtime.util.ZooKeeperUtils.SecureAclProvider
 
getActiveSlots(JobID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Return an iterator of active slots (their application ids) for the given job id.
getActorGateway() - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
getActorGatewayFuture() - Method in class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderGatewayListener
 
getActorSystem() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
getActual() - Method in exception org.apache.flink.runtime.highavailability.LeaderIdMismatchException
 
getAddress() - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
 
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 class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
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 class org.apache.flink.runtime.jobmaster.JobManagerRunner
 
getAddress() - Method in class org.apache.flink.runtime.jobmaster.ResourceManagerAddress
 
getAddress() - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
getAddress() - Method in interface org.apache.flink.runtime.leaderelection.LeaderContender
Returns the address of the LeaderContender under which other instances can connect to it.
getAddress() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
 
getAddress() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
getAddress() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Gets the address of the underlying RPC endpoint.
getAddress() - Method in interface org.apache.flink.runtime.rpc.RpcGateway
Returns the fully qualified address under which the associated rpc endpoint is reachable.
getAddress() - Method in interface org.apache.flink.runtime.rpc.RpcService
Return the hostname or host address under which the rpc service can be reached.
getAddress() - Method in class org.apache.flink.runtime.util.LeaderConnectionInfo
 
getAddress() - Method in class org.apache.flink.runtime.webmonitor.retriever.impl.AkkaQueryServiceGateway
 
getAddress() - Method in interface org.apache.flink.runtime.webmonitor.retriever.MetricQueryServiceGateway
 
getAddress() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
 
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
 
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 ExecutionState for 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
 
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
 
getAlignment() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
 
getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the total buffered bytes during alignment over all subtasks.
getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
 
getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
 
getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
 
getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
Returns the number of bytes buffered during stream alignment (for exactly-once only).
getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the total buffered bytes during alignment over all subtasks.
getAlignmentBuffered() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
 
getAlignmentBuffered() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
getAlignmentBuffered() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
 
getAlignmentBuffered() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
 
getAlignmentBufferedStats() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummary
Returns the summary stats for the bytes buffered during alignment.
getAlignmentBufferedStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
Returns the summary stats for the buffered bytes during alignments.
getAlignmentDuration() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
Returns the duration of the stream alignment (for exactly-once only).
getAlignmentDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
 
getAlignmentDurationNanos() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
getAlignmentDurationStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
Returns the summary stats for the alignment duration.
getAllAggregators() - Method in class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
 
getAllAndLock() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Gets all available state handles from ZooKeeper and locks the respective state nodes.
getAllCheckpoints() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
Returns all CompletedCheckpoint instances.
getAllCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
getAllCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
 
getAllExecutionVertexes() - Method in class org.apache.flink.runtime.executiongraph.failover.FailoverRegion
get all execution vertexes contained in this region
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.ExecutionGraph
 
getAllInputGates() - Method in interface org.apache.flink.runtime.execution.Environment
 
getAllInputGates() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getAllInputGates() - Method in class org.apache.flink.runtime.taskmanager.Task
 
getAllIntermediateResults() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getAllocatedSlots() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
 
getAllocatedSlots(JobID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Return an iterator of allocated slots for the given job id.
getAllocationId() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
getAllocationId() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
 
getAllocationId() - Method in class org.apache.flink.runtime.instance.SharedSlot
 
getAllocationId() - Method in class org.apache.flink.runtime.instance.SimpleSlot
 
getAllocationId() - Method in class org.apache.flink.runtime.instance.SimpleSlotContext
 
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.SlotContext
Gets the id under which the slot has been allocated on the TaskManager.
getAllocationId() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
 
getAllocationId() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
getAllocationId() - Method in class org.apache.flink.runtime.resourcemanager.SlotRequest
Get the unique identification of this request
getAllocationId() - Method in exception org.apache.flink.runtime.taskexecutor.exceptions.SlotOccupiedException
 
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 class org.apache.flink.runtime.taskexecutor.SlotStatus
Get the allocation id of this slot
getAllocationId() - Method in class org.apache.flink.runtime.taskmanager.Task
 
getAllocationIdsPerJob(JobID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Returns the all AllocationID for the given job.
getAllocationTimeout() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getAllowQueuedScheduling() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
 
getAllPaths() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Return a list of all valid paths for state handles.
getAllRegisteredInstances() - Method in class org.apache.flink.runtime.instance.InstanceManager
 
getAllSortedByNameAndLock() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Gets all available state handles from ZooKeeper sorted by name (ascending) and locks the respective state nodes.
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.
getAllVariables() - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
getAllVariables() - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
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.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.TaskManagerConfiguration
 
getAndIncrement() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
Atomically increments the current checkpoint ID.
getAndIncrement() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
 
getAndIncrement() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
 
getAndLock(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Gets the RetrievableStateHandle stored 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.
getAndResetUnannouncedCredit() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
Gets the unannounced credit and resets it to 0 atomically.
getAppConfigurationEntry(String) - Method in class org.apache.flink.runtime.security.DynamicConfiguration
Retrieve the AppConfigurationEntries for the specified name from this Configuration.
getArchivedExecutionConfig() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the ArchivedExecutionConfig for this execution graph.
getArchivedExecutionConfig() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getArchivedExecutionConfig() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Returns the serializable ArchivedExecutionConfig.
getArchivedJsons(Path) - Static method in class org.apache.flink.runtime.history.FsJobArchivist
Reads the given archive file and returns a Collection of contained ArchivedJson.
getArgs() - Method in class org.apache.flink.runtime.rpc.messages.LocalRpcInvocation
 
getArgs() - Method in class org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation
 
getArgs() - Method in interface org.apache.flink.runtime.rpc.messages.RpcInvocation
Returns the arguments of the remote procedure call
getArity() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
 
getArtifacts() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
Get the container artifacts.
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 TaskManagerLocation for this execution.
getAssignedResourceLocation() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
 
getAssignedResourceLocation() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
getAssignedSlotRequest() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
getAssignmentMode() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo
 
getAssignmentMode() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo.Snapshot
 
getAssignmentMode() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo
 
getAssignmentMode() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo.Snapshot
 
getAsyncCheckpointDuration() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
Returns the duration of the asynchronous part of the checkpoint.
getAsyncCheckpointDurationStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
Returns the summary stats for the async checkpoint duration.
getAsyncDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
 
getAsyncDurationMillis() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
getAsyncExecutor() - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerServices
Gets the async executor which executes outside of the main thread of the ResourceManager
getAsynchronousDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
 
getAttempt() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
getAttemptId() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
Returns the ExecutionAttemptID for 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
 
getAvailableJobDetails() - Method in interface org.apache.flink.runtime.dispatcher.ArchivedExecutionGraphStore
Return the collection of JobDetails of all currently stored jobs.
getAvailableJobDetails(JobID) - Method in interface org.apache.flink.runtime.dispatcher.ArchivedExecutionGraphStore
Return the JobDetails} for the given job.
getAvailableJobDetails() - Method in class org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
 
getAvailableJobDetails(JobID) - Method in class org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
 
getAvailableJobDetails() - Method in class org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
 
getAvailableJobDetails(JobID) - Method in class org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
 
getAvailableSlots() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
 
getAverage() - Method in class org.apache.flink.runtime.checkpoint.MinMaxAvgStats
Calculates the average over all seen values.
getAverage() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
 
getAvg() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
 
getBackendIdentifier() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
 
getBackendIdentifier() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
 
getBackpressureLevel() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
 
getBackpressureLevel() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
 
getBackPressureRatio(int) - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
Returns the ratio of stack traces indicating back pressure to total number of sampled stack traces.
getBackPressureStatsTracker() - Method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
 
getBasePath() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
Deprecated.
Deprecated in favor of FsStateBackend.getCheckpointPath().
getBlobManagerPort() - Method in class org.apache.flink.runtime.jobmaster.message.ClassloadingProps
 
getBlobServerHostname() - Method in class org.apache.flink.runtime.entrypoint.ClusterInformation
 
getBlobServerPort(Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
getBlobServerPort(Time) - Method in interface org.apache.flink.runtime.dispatcher.DispatcherGateway
Returns the port of the blob server.
getBlobServerPort() - Method in class org.apache.flink.runtime.entrypoint.ClusterInformation
 
getBlobWriter() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
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.ChannelWriterOutputView
Gets the number of blocks used by this view.
getBlockCount() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
 
getBlockCount() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ChannelWithBlockCount
 
getBroadcastGroupSize(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
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
 
getBroadcastStateMetaInfoSnapshots() - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
 
getBroadcastStateReaderForVersion(int, ClassLoader) - Static method in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters
 
getBroadcastStateWriterForVersion(int, RegisteredBroadcastBackendStateMetaInfo.Snapshot<K, V>) - Static method in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters
 
getBroadcastVariable(String) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
 
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
 
getBuffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
getBufferedData() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
 
getBufferPool() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
getBufferPool() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
 
getBufferProvider() - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
 
getBufferProvider() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
getBufferProvider() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
 
getBuffersInBacklog() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
Gets the number of non-event buffers in this subpartition.
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
 
getBytes(int, ByteBuf, int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
getBytes(int, byte[], int, 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, OutputStream, 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
 
getBytesBufferedInAlignment() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
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.
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
 
getCacheSize() - Method in class org.apache.flink.runtime.query.KvStateEntry
 
getCallable() - Method in class org.apache.flink.runtime.rpc.messages.CallAsync
 
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.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
 
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
 
getChainLength() - Method in class org.apache.flink.runtime.checkpoint.TaskState
Deprecated.
 
getChannel() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ChannelWithBlockCount
 
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.BufferOrEvent
 
getCheckpointAlignment() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
 
getCheckpointById(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
 
getCheckpointCoordinator() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getCheckpointCoordinatorConfiguration() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the CheckpointCoordinatorConfiguration or null if checkpointing is disabled.
getCheckpointCoordinatorConfiguration() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getCheckpointCoordinatorConfiguration() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getCheckpointCoordinatorConfiguration() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
getCheckpointDeclineReason() - Method in exception org.apache.flink.runtime.checkpoint.CheckpointTriggerException
 
getCheckpointDirectory() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
 
getCheckpointDirectoryForJob(Path, JobID) - Static method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
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
 
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.CompletedCheckpoint
 
getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
Returns the ID of this checkpoint.
getCheckpointId() - Method in interface org.apache.flink.runtime.checkpoint.savepoint.Savepoint
Returns the checkpoint ID of the savepoint.
getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
 
getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
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.TaskCheckpointStatistics
 
getCheckpointId() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
 
getCheckpointId() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
 
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
 
getCheckpointIdCounter() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
getCheckpointingSettings() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Gets the settings for asynchronous snapshots.
getCheckpointInterval() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
 
getCheckpointMetrics() - Method in class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
 
getCheckpointOptions() - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
 
getCheckpointOptions() - Method in class org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
 
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
Gets the checkpoint base directory.
getCheckpointPath() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
Gets the base directory where all the checkpoints are stored.
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.zookeeper.ZooKeeperHaServices
 
getCheckpointResponder() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getCheckpointRetentionPolicy() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
 
getCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
 
getCheckpointsDirectory() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
 
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 null if checkpointing is disabled.
getCheckpointStatsSnapshot() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getCheckpointStatsSnapshot() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getCheckpointStatus() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics
 
getCheckpointStatus() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
 
getCheckpointStorage() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
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
 
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
 
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).
getClassLoader() - Method in class org.apache.flink.runtime.client.JobListeningContext
The class loader necessary to deserialize the result of a job execution, i.e.
getClassLoader(JobID) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
getClassLoader(JobID) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
Returns the user code class loader associated with id.
getClassLoaderResolveOrder() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getClasspaths() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
 
getCleanUpInterval() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTrackerImpl
Cleanup interval for completed stats cache.
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
 
getClientMessageClass() - Method in class org.apache.flink.runtime.client.JobAttachmentClientActor
 
getClientMessageClass() - Method in class org.apache.flink.runtime.client.JobClientActor
Hook to let the client know about messages that should start a timer for a timeout
getClientMessageClass() - Method in class org.apache.flink.runtime.client.JobSubmissionClientActor
 
getClientNumThreads() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
getClusterInformation() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
Gets the cluster information.
GetClusterStatus - Class in org.apache.flink.runtime.clusterframework.messages
Message sent to the resource manager to request a GetClusterStatusResponse which contains the current number of task managers and the total number of task slots.
GetClusterStatusResponse - Class in org.apache.flink.runtime.clusterframework.messages
The reply to a GetClusterStatus message sent by the job manager.
GetClusterStatusResponse(int, int) - Constructor for class org.apache.flink.runtime.clusterframework.messages.GetClusterStatusResponse
 
getCoLocationConstraint() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
getCoLocationGroup() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getCoLocationGroup() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
getCommitId() - Method in class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
 
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
 
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.
getComponentMetricStore(HandlerRequest<EmptyRequestBody, M>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.AbstractMetricsHandler
Returns the MetricStore.ComponentMetricStore that should be queried for metrics.
getComponentMetricStore(HandlerRequest<EmptyRequestBody, JobManagerMetricsMessageParameters>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.JobManagerMetricsHandler
 
getComponentMetricStore(HandlerRequest<EmptyRequestBody, JobMetricsMessageParameters>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.JobMetricsHandler
 
getComponentMetricStore(HandlerRequest<EmptyRequestBody, JobVertexMetricsMessageParameters>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.JobVertexMetricsHandler
Deprecated.
 
getComponentMetricStore(HandlerRequest<EmptyRequestBody, SubtaskMetricsMessageParameters>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.SubtaskMetricsHandler
 
getComponentMetricStore(HandlerRequest<EmptyRequestBody, TaskManagerMetricsMessageParameters>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.TaskManagerMetricsHandler
 
getConfigDir() - Method in class org.apache.flink.runtime.entrypoint.ClusterConfiguration
 
getConfigDir() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
getConfigDir() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerCliOptions
 
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.MiniClusterConfiguration
 
getConfiguration() - Method in class org.apache.flink.runtime.minicluster.StandaloneMiniCluster
 
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.taskexecutor.TaskManagerConfiguration
 
getConfiguration() - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
Gets the configuration that the TaskManager was started with.
getConfiguredMemory() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
Returns the size of the managed memory (in megabytes), if configured.
getConjunctFutures() - Method in class org.apache.flink.runtime.concurrent.FutureUtils.ConjunctFuture
Gets the individual futures which make up the FutureUtils.ConjunctFuture.
getConnectionId() - Method in class org.apache.flink.runtime.clusterframework.messages.ReconnectResourceManager
 
getConnectionId() - Method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
 
getConnectionIndex() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
 
getConnectionIndex() - Method in class org.apache.flink.runtime.io.network.ConnectionID
 
getConnectionManager() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
getConnectionTimeout() - Method in class org.apache.flink.runtime.rest.RestClientConfiguration
 
getConsumedPartitionId() - Method in class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
 
getConsumedPartitionLocation() - Method in class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
 
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.SingleInputGate
 
getConsumedSubpartitionIndex() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
 
getConsumers() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
 
getConsumers() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
 
getContainingTask() - Method in class org.apache.flink.runtime.operators.BatchTask
 
getContainingTask() - Method in interface org.apache.flink.runtime.operators.TaskContext
 
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
 
getCount() - Method in class org.apache.flink.runtime.checkpoint.MinMaxAvgStats
Returns the count of all seen values.
getCount() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogram
 
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
 
getCpuCores() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
Get the cpu cores needed.
getCreateDump() - Static method in class org.apache.flink.runtime.metrics.dump.MetricQueryService
 
getCreationTimestamp() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
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 class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Get the current allocation for the task slot with the given index.
getCurrentAssignedResource() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getCurrentAssignedResourceLocation() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
Returns the TaskManagerLocation for this execution vertex.
getCurrentAssignedResourceLocation() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
getCurrentAssignedResourceLocation() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getCurrentBackoff() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
Returns the current backoff in ms.
getCurrentBuffer() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
 
getCurrentBuffer() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
 
getCurrentConfiguration() - Method in class org.apache.flink.runtime.security.modules.JaasModule
 
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
 
getCurrentKey() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
getCurrentKey() - Method in interface org.apache.flink.runtime.state.heap.InternalKeyContext
Used by states to access the current key.
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.heap.InternalKeyContext
Returns the key-group to which the current key belongs.
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
 
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
 
getCurrentRestartAttempt() - Method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
 
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
 
getData() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
 
getDataPort() - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
 
getDataPort() - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
 
getDataPort() - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
 
getDataPort() - Method in class org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
 
getDataPort() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
 
getDefault() - Static method in class org.apache.flink.runtime.state.CheckpointStorageLocationReference
 
getDefaultAcl() - Method in class org.apache.flink.runtime.util.ZooKeeperUtils.SecureAclProvider
 
getDefaultElement() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
 
getDefaultIOMode() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
getDefaultMimeType() - Static method in class org.apache.flink.runtime.rest.handler.util.MimeTypes
Gets the default MIME type, which is "application/octet-stream".
getDefaultSavepointDirectory() - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
Gets the default directory for savepoints.
getDefaultStateBackend() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
getDefaultValue() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
 
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
 
getDelimiter() - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
Returns the global delimiter.
getDelimiter(int) - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
Returns the configured delimiter for the reporter with the given index.
getDelimiter() - Method in class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
 
getDelimiter() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
 
getDelimiter(int) - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
 
getDelimiter() - Method in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
 
getDelimiter(int) - Method in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
 
getDescription() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
 
getDescription() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
 
getDescription() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
 
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.TaskCheckpointStatisticsHeaders
 
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.DashboardConfigurationHeaders
 
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.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.JobMetricsHeaders
 
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.SubtaskMetricsHeaders
 
getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsHeaders
 
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.SavepointDisposalTriggerHeaders
 
getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
 
getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
 
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.JobAccumulatorsHeaders
 
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.JobIdsWithStatusesOverviewHeaders
 
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.JobTerminationHeaders
 
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.JobVertexTaskManagersHeaders
 
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.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.TaskManagersHeaders
 
getDesignatedWorkerPoolSize() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Gets the current designated worker pool size, meaning the number of workers that the resource master strives to maintain.
getDirectMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
Get the direct memory needed in MB.
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.SnapshotDirectory
 
getDirectoryStateHandle() - Method in class org.apache.flink.runtime.state.DirectoryKeyedStateHandle
 
getDispatcherLeaderElectionService() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
Gets the leader election service for the cluster's dispatcher.
getDispatcherLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
 
getDispatcherLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
 
getDispatcherLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
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
 
getDispatcherLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
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.JobEdge
Returns the distribution pattern used for this edge.
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.checkpoint.CompletedCheckpoint
 
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.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
 
getDynamicConfiguration() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
Get the dynamic configuration.
getElementsCollectedAndReset() - Method in class org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
 
getElementSerializer() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
getEndKeyGroup() - Method in class org.apache.flink.runtime.state.KeyGroupRange
 
getEndOffsetExclusive() - Method in class org.apache.flink.runtime.state.BoundedInputStream
 
getEndpointId() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Returns the rpc endpoint's identifier.
getEndTime() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
 
getEndTime() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSample
Returns the time stamp, when all stack traces were collected at the JobManager.
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
 
getEndTimestamp() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
Returns the time stamp, when all stack traces were collected at the JobManager.
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 -1 if 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 -1 if 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.
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.
getEnvironment() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Returns the environment of this task.
getEnvironmentVariables() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
Get the environment variables.
getError(ClassLoader) - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
Gets the attached exception, which is in serialized form.
getErrorResponse(Throwable) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRedirectUtils
 
getErrorResponse(Throwable, HttpResponseStatus) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRedirectUtils
 
getEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
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.
getExecutingThread() - Method in class org.apache.flink.runtime.taskmanager.Task
 
getExecutionAttemptID() - Method in class org.apache.flink.runtime.accumulators.AccumulatorSnapshot
 
getExecutionAttemptId() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
 
getExecutionAttemptID() - Method in class org.apache.flink.runtime.messages.StackTraceSampleResponse
 
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
 
getExecutionConfigInfo() - Method in class org.apache.flink.runtime.rest.messages.JobConfigInfo
 
getExecutionGraph() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getExecutionGraph(JobID) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
 
getExecutionGraph(JobID, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.legacy.ExecutionGraphCache
Gets the AccessExecutionGraph for the given JobID and caches it.
getExecutionId() - Method in interface org.apache.flink.runtime.execution.Environment
Gets the ID of the task execution attempt.
getExecutionId() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getExecutionId() - Method in class org.apache.flink.runtime.taskmanager.Task
 
getExecutionState() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
Returns the current ExecutionState for 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.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.
getExecutor() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
getExecutor() - Method in interface org.apache.flink.runtime.rpc.RpcService
Gets the executor, provided by this RPC service.
getExpected() - Method in exception org.apache.flink.runtime.highavailability.LeaderIdMismatchException
 
getExtendedResources() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
Get the extended resources.
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
 
getFailedCheckpointStatistics() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
 
getFailoverRegion(ExecutionVertex) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
Finds the failover region that contains the given execution vertex.
getFailoverStrategy() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Gets the failover strategy used by the execution graph to recover from failures of tasks.
getFailureCause() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
getFailureCause() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getFailureCause() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getFailureCause() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
 
getFailureCause() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
 
getFailureCause() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
getFailureCause() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
 
getFailureCause() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationInfo
 
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.
getFailureCauseAsString() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
Returns the exception that caused the job to fail.
getFailureCauseAsString() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
Returns the exception that caused the job to fail.
getFailureCauseAsString() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
 
getFailureCauseAsString() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
getFailureCauseAsString() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
getFailureCauseAsString() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getFailureInfo() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the exception that caused the job to fail.
getFailureInfo() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getFailureInfo() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getFailureMessage() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
Returns the failure message or null if no cause was provided.
getFailureMessage() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.FailedCheckpointStatistics
 
getFailureReason() - Method in class org.apache.flink.runtime.checkpoint.CheckpointTriggerResult
 
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
 
getFencingToken() - Method in class org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
 
getFencingToken() - Method in class org.apache.flink.runtime.rpc.FencedRpcEndpoint
 
getFencingToken() - Method in interface org.apache.flink.runtime.rpc.FencedRpcGateway
Get the current fencing token.
getFencingToken() - Method in interface org.apache.flink.runtime.rpc.messages.FencedMessage
 
getFencingToken() - Method in class org.apache.flink.runtime.rpc.messages.LocalFencedMessage
 
getFencingToken() - Method in class org.apache.flink.runtime.rpc.messages.RemoteFencedMessage
 
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(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, 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(TransientBlobKey) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
 
getFile(JobID, 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(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() - Method in class org.apache.flink.runtime.rest.FileUpload
 
getFileCache() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
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
 
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
 
getFilePath() - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
Gets the path where this handle's state is stored.
getFileSystem() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
 
getFlinkConfig() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
 
getFlinkRevision() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
 
getFlinkVersion() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
 
getFoldingState(FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
 
getForForwardExchange(ExecutionMode) - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
 
getFormatDescription() - Method in class org.apache.flink.runtime.jobgraph.InputFormatVertex
 
getFormatDescription() - Method in class org.apache.flink.runtime.jobgraph.OutputFormatVertex
 
getForShuffleOrBroadcast(ExecutionMode) - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
 
getFQDNHostname() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
Returns the fully-qualified domain name the TaskManager.
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
 
getFreeSlotForTask(ExecutionVertex, Iterable<TaskManagerLocation>, boolean) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
Gets a suitable instance to schedule the vertex execution to.
getFullSegments() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBulkBlockReader
 
getFullSegments() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BulkBlockChannelReader
 
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.ExecutionGraph
Returns the ExecutionContext associated with this ExecutionGraph.
getGarbageCollectorStatsAsString(List<GarbageCollectorMXBean>) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
Gets the garbage collection statistics from the JVM.
getGlobalModVersion() - Method in class org.apache.flink.runtime.executiongraph.Execution
Gets the global modification version of the execution graph when this execution was created.
getGraph() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getGroupID() - Method in class org.apache.flink.runtime.instance.Slot
Gets the ID that identifies the logical group to which this slot belongs: If the slot does not belong to any group in particular, this field is null. If this slot was allocated as a sub-slot of a SlotSharingGroupAssignment, then this ID will be the JobVertexID of the vertex whose task the slot holds in its shared slot. In case that the slot represents the shared slot of a co-location constraint, this ID will be the ID of the co-location constraint.
getGroupId() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Gets the ID that identifies the co-location group.
getGroupId() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.TaskSlot
 
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.JobManagerMetricGroup
 
getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.JobMetricGroup
 
getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
 
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
 
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.
getHardwareDescription() - Method in class org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
 
getHardwareDescription() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
 
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
 
getHeapMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
Get the heap memory needed in MB.
getHeartbeatInterval() - Method in class org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess
Gets the interval in which the ResourceManager will heartbeat the JobMaster.
getHeartbeatInterval() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerConfiguration
 
getHeartbeatInterval() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
Gets the interval in which the ResourceManager will heartbeat the TaskExecutor.
getHighAvailabilityServices() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
 
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
 
getHost() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
getHost() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
getHostname() - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
 
getHostname() - Method in class org.apache.flink.runtime.minicluster.StandaloneMiniCluster
 
getHostname() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Gets the hostname of the underlying RPC endpoint.
getHostname() - Method in interface org.apache.flink.runtime.rpc.RpcGateway
Returns the fully qualified hostname under which the associated rpc endpoint is reachable.
getHostname() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
Gets the hostname of the TaskManager.
getHostname() - Method in class org.apache.flink.runtime.util.LeaderConnectionInfo
 
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.LogFileHandlerSpecification
 
getHttpMethod() - Method in class org.apache.flink.runtime.rest.handler.legacy.files.StdoutFileHandlerSpecification
 
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 HttpMethodWrapper to 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.TaskCheckpointStatisticsHeaders
 
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.DashboardConfigurationHeaders
 
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.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.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.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.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.JobPlanHeaders
 
getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
 
getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobTerminationHeaders
 
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.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.TaskManagerDetailsHeaders
 
getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
 
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.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.executiongraph.IntermediateResult
 
getId() - Method in class org.apache.flink.runtime.instance.Instance
 
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.JobVertex
Returns the ID of this job vertex.
getId() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
Gets the ID that identifies this co-location group.
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.taskmanager.TaskExecutionState
Returns the ID of the task this result belongs to
getIdAlternatives() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Returns a list of all alternative IDs of this job vertex.
getIdentifier() - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
Gets the identifier of this hook.
getIdleSince() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
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.rest.messages.checkpoints.SubtaskCheckpointStatistics
 
getIndex() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
getIndexInSubtaskGroup() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Returns the index of this subtask in the subtask group.
getInfoForCurrentThread() - Method in class org.apache.flink.runtime.query.KvStateEntry
 
getInitialCredit() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
getInitialRegistrationPause() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getInitialTableSize(int, int, int, int) - Static method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
getInProgressHandler() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobCancellationWithSavepointHandlers
 
getInput(int) - Method in class org.apache.flink.runtime.operators.BatchTask
 
getInput(int) - Method in interface org.apache.flink.runtime.operators.TaskContext
 
getInputChannelDeploymentDescriptor() - Method in class org.apache.flink.runtime.executiongraph.PartitionInfo
 
getInputChannelDeploymentDescriptors() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
 
getInputChannelId() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
getInputComparator(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getInputEdges(int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getInputGate(int) - Method in interface org.apache.flink.runtime.execution.Environment
 
getInputGate(int) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getInputGateById(IntermediateDataSetID) - Method in class org.apache.flink.runtime.taskmanager.Task
 
getInputGates() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
 
getInputLocalStrategy(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getInputNum() - Method in class org.apache.flink.runtime.executiongraph.ExecutionEdge
 
getInputs() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getInputs() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
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
 
getInputSplitSource() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
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.clusterframework.messages.GetClusterStatus
Gets the singleton instance.
getInstance() - Static method in class org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListener
Gets the singleton instance.
getInstance() - Static method in class org.apache.flink.runtime.clusterframework.messages.StopClusterSuccessful
 
getInstance() - Method in exception org.apache.flink.runtime.instance.InstanceDiedException
 
getInstance(ResourceID) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
getInstance() - Static method in class org.apache.flink.runtime.jobmaster.slotpool.LocationPreferenceSchedulingStrategy
 
getInstance() - Static method in class org.apache.flink.runtime.jobmaster.slotpool.PreviousAllocationSchedulingStrategy
 
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.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.LogFileHandlerSpecification
 
getInstance() - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.StdoutFileHandlerSpecification
 
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.TaskCheckpointStatisticsHeaders
 
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.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.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.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.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.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.JobPlanHeaders
 
getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
 
getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobTerminationHeaders
 
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.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.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.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.YarnCancelJobTerminationHeaders
Deprecated.
 
getInstance() - Static method in class org.apache.flink.runtime.rest.messages.YarnStopJobTerminationHeaders
Deprecated.
 
getInstance() - Static method in class org.apache.flink.runtime.util.clock.SystemClock
 
getInstanceId() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
getInstanceId() - Method in class org.apache.flink.runtime.messages.StackTrace
 
getInstanceID() - Method in class org.apache.flink.runtime.resourcemanager.registration.TaskExecutorConnection
 
getInstanceId() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
getInstancesByHost() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
getIntermediateDataSetID() - Method in class org.apache.flink.runtime.executiongraph.PartitionInfo
 
getIntermediateResult() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
 
getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.DirectoryKeyedStateHandle
 
getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
 
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.KeyGroupsStateHandle
 
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.
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.OperatorMetricGroup
Returns the OperatorIOMetricGroup for this operator.
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.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
 
getIsSolutionSetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getIsSolutionSetUpdateWithoutReprobe() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
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
 
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 interface org.apache.flink.runtime.operators.sort.Sorter
 
getIterator() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
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
 
getJob() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
 
getJobAccumulators() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
 
getJobCheckpointingConfiguration() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
Returns the job's checkpointing configuration which is derived from the CheckpointConfig.
getJobClientActor() - Method in class org.apache.flink.runtime.client.JobListeningContext
 
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.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
 
getJobExecutionResult() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
 
getJobGraph() - Method in class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
Returns the submitted JobGraph.
getJobGraph() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
 
getJobID() - Method in class org.apache.flink.runtime.accumulators.AccumulatorSnapshot
 
getJobId() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
getJobId() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
getJobID() - Method in exception org.apache.flink.runtime.client.JobExecutionException
 
getJobID() - Method in class org.apache.flink.runtime.client.JobListeningContext
 
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.clusterframework.types.TaskManagerSlot
 
getJobId() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
Returns the task's job ID.
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 JobID for this execution graph.
getJobID() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getJobID() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
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.io.network.partition.ResultPartition
 
getJobID() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Returns the ID of the job.
getJobId() - Method in class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
Returns the JobID of the submitted JobGraph.
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.query.KvStateMessage.LookupKvStateLocation
Returns the JobID the KvState instance belongs to.
getJobId() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
Returns the JobID the KvState instance belongs to.
getJobId() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
Returns the JobID the KvState instance belongs to.
getJobID() - Method in class org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
 
getJobId() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
getJobId() - Method in class org.apache.flink.runtime.resourcemanager.SlotRequest
Get the JobID of the slot requested for.
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 exception org.apache.flink.runtime.taskexecutor.exceptions.SlotOccupiedException
 
getJobID() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getJobId() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
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
 
getJobID() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
The ID of the job the task belongs to
getJobIds() - Method in class org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
 
getJobIds() - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
 
getJobIds() - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
Get all job ids of submitted job graphs to the submitted job graph store.
getJobIds() - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
 
getJobInfo() - Method in class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
Returns the JobInfo of the client who submitted the JobGraph.
getJobInformationOrBlobKey() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getJobLeaderIdService() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
 
getJobLeaderService() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getJobManager() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
Deprecated.
Use semantically equivalent MetricStore.getJobManagerMetricStore().
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
 
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 class org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getJobManagerJobFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
 
getJobManagerLeaderElectionService(JobID) - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
Gets the leader election service for the given job.
getJobManagerLeaderElectionService(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
 
getJobManagerLeaderElectionService(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
 
getJobManagerLeaderElectionService(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
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, 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) - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
 
getJobManagerLeaderRetriever(JobID, String) - 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.nonha.standalone.StandaloneHaServices
 
getJobManagerLeaderRetriever(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getJobManagerLeaderRetriever(JobID, String) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
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.
getJobManagerMetricStore() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
Returns the MetricStore.ComponentMetricStore for the JobManager.
getJobManagerMode() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
getJobManagerOwnedSnapshot() - Method in class org.apache.flink.runtime.state.SnapshotResult
 
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
 
getJobManagerTable() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getJobMasterId() - Method in class org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
 
getJobMasterId() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getJobMetricStore(String) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
Returns the MetricStore.ComponentMetricStore for 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.ExecutionGraph
 
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
 
getJobResultFuture() - Method in class org.apache.flink.runtime.client.JobListeningContext
 
getJobs() - Method in class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
 
getJobs() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
 
getJobSchedulingStatus(JobID) - Method in class org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
 
getJobSchedulingStatus(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
 
getJobSchedulingStatus(JobID) - Method in interface org.apache.flink.runtime.highavailability.RunningJobsRegistry
Gets the scheduling status of a job.
getJobSchedulingStatus(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperRunningJobsRegistry
 
getJobState() - Method in class org.apache.flink.runtime.client.JobStatusMessage
 
getJobStatus() - Method in class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview.JobIdWithStatus
 
getJobStatus(JobID) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
 
getJobStatus() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
getJobsWithStatus() - Method in class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview
 
getJobTerminationFuture() - Method in class org.apache.flink.runtime.dispatcher.MiniDispatcher
 
getJobTimeout() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
 
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.ExecutionGraph
 
getJobVertex() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getJobVertex() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getJobVertexID() - Method in class org.apache.flink.runtime.checkpoint.TaskState
Deprecated.
 
getJobVertexId() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the ID of the operator the statistics belong to.
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 JobVertexID for this job vertex.
getJobVertexId() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
 
getJobVertexId() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getJobvertexId() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getJobVertexId() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
 
getJobVertexId() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
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.query.KvStateMessage.NotifyKvStateRegistered
Returns the JobVertexID the KvState instance belongs to.
getJobVertexId() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
Returns the JobVertexID the KvState instance belongs to.
getJobVertexID() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
getJobVertexId() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getJobVertexId() - Method in class org.apache.flink.runtime.taskmanager.Task
 
getJobVertexIds() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
getJobVertexInfos() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
getJobVertexMetrics() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
getJobVerticesPerState() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
getJson() - Method in class org.apache.flink.runtime.webmonitor.history.ArchivedJson
 
getJsonArchivists() - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
 
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.ExecutionGraph
 
getJsonPlan() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
getJsonPlan() - Method in class org.apache.flink.runtime.rest.messages.JobPlanInfo
 
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.rest.messages.ClusterConfigurationInfoEntry
 
getKey() - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
Returns the key of this parameter, e.g.
getKey() - Method in interface org.apache.flink.runtime.state.heap.StateEntry
Returns the key of this entry.
getKeyA(A) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
getKeyB(B) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
getKeyedStateHandles(Collection<? extends KeyedStateHandle>, KeyGroupRange) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
Determine the subset of KeyGroupsStateHandles with correct key group index for the given subtask KeyGroupRange.
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
 
getKeyedStateStreamFuture() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
 
getKeyGroupCompressionDecorator() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
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()[.
getKeyGroupId() - Method in class org.apache.flink.runtime.state.KeyGroupStatePartitionStreamProvider
Returns the key group that corresponds to the data in the provided stream.
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(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.query.KvStateMessage.NotifyKvStateRegistered
Returns the key group index the KvState instance belongs to.
getKeyGroupRange() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
Returns the key group index the KvState instance belongs to.
getKeyGroupRange() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
getKeyGroupRange() - Method in class org.apache.flink.runtime.state.DirectoryKeyedStateHandle
 
getKeyGroupRange() - Method in interface org.apache.flink.runtime.state.heap.InternalKeyContext
Returns the key groups for this backend.
getKeyGroupRange() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
 
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
 
getKeys(N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
getKeys(String, N) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
getKeys(N) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
getKeys(N) - Method in class org.apache.flink.runtime.state.heap.StateTable
 
getKeys(String, N) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
 
getKeySerializer() - Method in class org.apache.flink.runtime.query.KvStateInfo
 
getKeySerializer() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
getKeySerializer() - Method in class org.apache.flink.runtime.state.heap.HeapAggregatingState
 
getKeySerializer() - Method in class org.apache.flink.runtime.state.heap.HeapFoldingState
Deprecated.
 
getKeySerializer() - Method in class org.apache.flink.runtime.state.heap.HeapListState
 
getKeySerializer() - Method in class org.apache.flink.runtime.state.heap.HeapMapState
 
getKeySerializer() - Method in class org.apache.flink.runtime.state.heap.HeapReducingState
 
getKeySerializer() - Method in class org.apache.flink.runtime.state.heap.HeapValueState
 
getKeySerializer() - Method in interface org.apache.flink.runtime.state.heap.InternalKeyContext
TypeSerializer for the state backend key type.
getKeySerializer() - Method in interface org.apache.flink.runtime.state.internal.InternalKvState
Returns the TypeSerializer for the type of key this state is associated to.
getKeySerializer() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
getKeySerializer() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo
 
getKeySerializer() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo.Snapshot
 
getKeySerializerConfigSnapshot() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
getKeySerializerConfigSnapshot() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo.Snapshot
 
getKeytab() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
 
getKrb5LoginModuleName() - Static method in class org.apache.flink.runtime.security.KerberosUtils
 
getKvState(KvStateID) - Method in class org.apache.flink.runtime.query.KvStateRegistry
Returns the KvStateEntry containing the requested instance as identified by the given KvStateID, along with its KvStateInfo or null if none is registered.
getKvStateID(int) - Method in class org.apache.flink.runtime.query.KvStateLocation
Returns the registered KvStateID for the key group index or null if none is registered yet.
getKvStateId() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
Returns the ID of the registered KvState instance.
getKvStateLocation(String) - Method in class org.apache.flink.runtime.query.KvStateLocationRegistry
Returns the KvStateLocation for the registered KvState instance or null if 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.ExecutionGraph
 
getKvStateProxy() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
getKvStateRegistry() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
getKvStateServer() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
getKvStateServerAddress(int) - Method in class org.apache.flink.runtime.query.KvStateLocation
Returns the registered server address for the key group index or null if none is registered yet.
getKvStateServerAddress() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
Returns the server address where to find the KvState instance.
getLast() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
Returns the last checkpoint ID (current - 1).
getLastHeartBeat() - Method in class org.apache.flink.runtime.instance.Instance
Gets the timestamp of 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.HeartbeatManagerImpl
 
getLastOutputCollector() - Method in class org.apache.flink.runtime.operators.BatchTask
 
getLastTasksConfig() - Method in class org.apache.flink.runtime.operators.BatchTask
 
getLastUpdateTime() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
 
getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the latest acknowledged subtask stats or null if none was acknowledged yet.
getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
 
getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
 
getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
 
getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the latest acknowledged subtask stats or null if none was acknowledged yet.
getLatestAckTimestamp() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the ack timestamp of the latest acknowledged subtask or -1 if none was acknowledged yet.
getLatestAckTimestamp() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the ack timestamp of the latest acknowledged subtask or -1 if none was acknowledged yet.
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 CompletedCheckpoint instance or null if none was added.
getLatestCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
getLatestCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
 
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
 
getLatestPriorAllocation() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getLatestPriorExecution() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getLatestPriorLocation() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
Gets the location where the latest completed/canceled/failed execution of the vertex's task happened.
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
 
getLeaderConnectionInfoFuture() - Method in class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderConnectionInfoListener
 
getLeaderFuture() - Method in class org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
Returns the current JobManagerGateway future.
getLeaderGatewayFuture() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
 
getLeaderId(JobID) - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
 
getLeaderID() - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerServices
Gets the current leader id assigned at the ResourceManager.
getLeaderNow() - Method in class org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
Returns the current leader information if available.
getLeaderSessionID() - Method in class org.apache.flink.runtime.akka.FlinkUntypedActor
Returns the current leader session ID associated with this actor.
getLeaderSessionID() - Method in class org.apache.flink.runtime.client.JobClientActor
 
getLeaderSessionID() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
 
getLeaderSessionID() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
Returns the current leader session ID or null, if the contender is not the leader.
getLeaderSessionID() - Method in class org.apache.flink.runtime.util.LeaderConnectionInfo
 
getLength() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileSegment
 
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.VoidNamespaceSerializer
 
getLibraryCacheManager() - Method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
 
getLibraryCacheManager() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
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
 
getListState(ListStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
 
getListState(ListStateDescriptor<S>) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
getLocality() - Method in class org.apache.flink.runtime.instance.SharedSlot
 
getLocality() - Method in class org.apache.flink.runtime.instance.SimpleSlot
Gets the locality information attached to this slot.
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.SlotAndLocality
 
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 LocalRecoveryConfig for this task local state store.
getLocalRecoveryConfig() - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
 
getLocalRecoveryStateRootDirectories() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getLocalStateDirectoryProvider() - Method in class org.apache.flink.runtime.state.LocalRecoveryConfig
 
getLocation() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Gets the location assigned to this slot.
getLocation() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointInfo
 
getLocationConstraint() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getLocationConstraint(int) - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
 
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
 
getLockPath(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Returns the path for the lock node relative to the given path.
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, 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) - Method in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
 
getLogicalScope(CharacterFilter, char) - Method in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
 
getLogicalScope(CharacterFilter, char) - Method in class org.apache.flink.runtime.metrics.groups.GenericValueMetricGroup
 
getLoginContextNames() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
 
getMainThreadExecutor() - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerServices
Gets the executor which executes in the main thread of the ResourceManager
getMainThreadExecutor() - Method in class org.apache.flink.runtime.rpc.FencedRpcEndpoint
Returns a main thread executor which is bound to the currently valid fencing token.
getMainThreadExecutor() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Gets the main thread execution context.
getManagedKeyedState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
Returns a handle to the managed keyed state.
getManagedKeyedState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
 
getManagedKeyedStateHandles(OperatorState, KeyGroupRange) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
Collect managedKeyedStateHandles which have intersection with given KeyGroupRange from operatorState
getManagedOperatorState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
Returns a handle to the managed operator state.
getManagedOperatorState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
 
getMapFor(Map<String, String>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.AbstractMetricsHandler
Returns a Map containing the metrics belonging to the entity pointed to by the path parameters.
getMapFor(Map<String, String>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.JobManagerMetricsHandler
 
getMapFor(Map<String, String>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.JobMetricsHandler
 
getMapFor(Map<String, String>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.JobVertexMetricsHandler
Deprecated.
 
getMapFor(Map<String, String>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.SubtaskMetricsHandler
 
getMapFor(Map<String, String>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.TaskManagerMetricsHandler
 
getMapState(MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
 
getMasterHooks() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
getMasterHookStates() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
getMasterStates() - Method in interface org.apache.flink.runtime.checkpoint.savepoint.Savepoint
Gets the checkpointed states generated by the master.
getMasterStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
 
getMasterStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
getMatchesFor(PT) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
getMatchFor(PT, BT) - Method in class org.apache.flink.runtime.operators.hash.AbstractHashTableProber
 
getMatchFor(PT) - 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) - 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.
getMatchFor(PT) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
 
getMax() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
 
getMax() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
 
getMaxBackPressureRatio() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
Returns the maximum back pressure ratio of all sub tasks.
getMaxCapacity() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
Returns the maximum size of the buffer, i.e.
getMaxCapacity() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
 
getMaxCapacity() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
getMaxCapacity() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
getMaxCheckpointStatisticCacheEntries() - Method in class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
 
getMaxConcurrentCheckpoints() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
 
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.MinMaxAvgStats
Returns the maximum seen value.
getMaximum() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
 
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.
getMaxNumberOfMemorySegments() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
Returns the maximum number of memory segments this buffer pool should use
getMaxNumberOfRetainedCheckpoints() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
Returns the max number of retained checkpoints.
getMaxNumberOfRetainedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
getMaxNumberOfRetainedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
 
getMaxNumberOfSubtaks() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
 
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.JobVertex
Gets the maximum parallelism for the task.
getMaxRegistrationDuration() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getMaxRegistrationPause() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getMaxStateSize() - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
Gets the size (in bytes) that a individual chunk of state may have at most.
getMaxStateSize() - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
Gets the maximum size that an individual state can have, as configured in the constructor (by default 5242880).
getMean() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
 
getMemoryFraction() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
Get the total memory needed in MB.
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.TaskManagerServices
 
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.NetworkBuffer
 
getMemorySegment() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
Returns the underlying memory segment.
getMemorySegment() - Method in class org.apache.flink.runtime.operators.util.BloomFilter.BitSet
 
getMemorySegmentOffset() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
Deprecated.
getMemorySegmentOffset() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
getMemorySegmentOffset() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
getMemorySegmentSize() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
Returns the size of the underlying memory segments.
getMemorySegmentSize() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
getMemorySize() - Method in class org.apache.flink.runtime.memory.MemoryManager
Returns the total size of memory handled by this memory manager.
getMemoryType() - Method in class org.apache.flink.runtime.memory.MemoryManager
Gets the type of memory (heap / off-heap) managed by this memory manager.
getMemoryType() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
Returns the memory type to use.
getMemoryUsageStatsAsString(MemoryMXBean) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
Gets the memory footprint of the JVM in a string representation.
getMergingIterator(List<UnilateralSortMerger.ChannelWithBlockCount>, List<List<MemorySegment>>, List<FileIOChannel>, MutableObjectIterator<E>) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Returns an iterator that iterates over the merged result from all given channels.
getMessage() - Method in exception org.apache.flink.runtime.io.network.partition.PartitionNotFoundException
 
getMessageHeaders() - Method in class org.apache.flink.runtime.rest.handler.AbstractRestHandler
 
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
 
getMetaDataState() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
 
getMetaInfo() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
getMetaInfo() - Method in class org.apache.flink.runtime.state.heap.StateTable
 
getMetaStateHandle() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
 
getMethodName() - Method in class org.apache.flink.runtime.rpc.messages.LocalRpcInvocation
 
getMethodName() - Method in class org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation
 
getMethodName() - Method in interface org.apache.flink.runtime.rpc.messages.RpcInvocation
Returns the method's name.
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.operators.BatchTask
 
getMetricGroup() - Method in interface org.apache.flink.runtime.operators.TaskContext
 
getMetricGroup() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getMetricGroup() - Method in class org.apache.flink.runtime.taskmanager.Task
 
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, 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, int) - 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".
getMetricIdentifier(String) - Method in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
 
getMetricIdentifier(String, CharacterFilter) - 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.ProxyMetricGroup
 
getMetricQueryServicePath() - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
Returns the path of the MetricQueryService or null, if none is started.
getMetricQueryServicePath() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
Returns the address under which the MetricQueryService is reachable.
getMetricQueryServicePath() - Method in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
 
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
 
getMetricStore() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricFetcher
Returns the MetricStore containing all stored metrics.
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
 
getMinFileSizeThreshold() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
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.MinMaxAvgStats
Returns the minimum seen value.
getMinimum() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
 
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
 
getMinPauseBetweenCheckpoints() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
 
getMinResources() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Gets the minimum resource for the task.
getMultipartFileUploads(ChannelHandlerContext) - Static method in class org.apache.flink.runtime.rest.FileUploadHandler
 
getMutableObjectMode() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getName() - Method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
 
getName() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
 
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.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.state.RegisteredBroadcastBackendStateMetaInfo
 
getName() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo.Snapshot
 
getName() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
 
getName() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo.Snapshot
 
getName() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo
 
getName() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo.Snapshot
 
getNamespace() - Method in interface org.apache.flink.runtime.state.heap.StateEntry
Returns the namespace of this entry.
getNamespaceSerializer() - Method in class org.apache.flink.runtime.query.KvStateInfo
 
getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.heap.HeapAggregatingState
 
getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.heap.HeapFoldingState
Deprecated.
 
getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.heap.HeapListState
 
getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.heap.HeapMapState
 
getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.heap.HeapReducingState
 
getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.heap.HeapValueState
 
getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.heap.StateTable
 
getNamespaceSerializer() - Method in interface org.apache.flink.runtime.state.internal.InternalKvState
Returns the TypeSerializer for the type of namespace this state is associated to.
getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
 
getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo.Snapshot
 
getNamespaceSerializerConfigSnapshot() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo.Snapshot
 
getNativeMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
Get the native memory needed in MB.
getNetRuntime() - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
 
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.
getNetRuntime() - Method in class org.apache.flink.runtime.jobmaster.JobResult
 
getNettyHttpMethod() - Method in enum org.apache.flink.runtime.rest.HttpMethodWrapper
 
getNetworkBufferPool() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
getNetworkConfig() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getNetworkEnvironment() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getNetworkMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
Get the memory needed for task to communicate with its upstreams and downstreams in MB.
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
 
getNewSlotForSharingGroup(ExecutionVertex, Iterable<TaskManagerLocation>, SlotSharingGroupAssignment, CoLocationConstraint, boolean) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
Tries to allocate a new slot for a vertex that is part of a slot sharing group.
getNextBuffer() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
 
getNextBuffer() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
Returns the next Buffer instance of this queue iterator.
getNextBufferOrEvent() - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGate
Blocking call waiting for next BufferOrEvent.
getNextBufferOrEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
getNextBufferOrEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
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(ClassLoader) - Method in class org.apache.flink.runtime.taskmanager.TaskInputSplitProvider
 
getNextPathNum() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
 
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.
getNioBuffer(int, int) - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
Gets a new ByteBuffer instance wrapping this buffer's bytes.
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 ByteBuffer instance wrapping this buffer's readable bytes, i.e.
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
 
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
 
getNow() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
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
 
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 class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
 
getNumberFreeSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
getNumberFreeSlotsOf(InstanceID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
 
getNumberInProgressCheckpoints() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
 
getNumberLeaves() - Method in class org.apache.flink.runtime.instance.SharedSlot
 
getNumberLeaves() - Method in class org.apache.flink.runtime.instance.SimpleSlot
 
getNumberLeaves() - Method in class org.apache.flink.runtime.instance.Slot
Gets the number of simple slots that are at the leaves of the tree of slots.
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.FailedCheckpointStats
 
getNumberOfAcknowledgedSubtasks() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
 
getNumberOfAcknowledgedSubtasks() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the number of acknowledged subtasks.
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.
getNumberOfAllocatedSlots() - Method in class org.apache.flink.runtime.instance.Instance
 
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
 
getNumberOfAvailableInstances() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
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.NetworkBufferPool
 
getNumberOfAvailableSlots() - Method in class org.apache.flink.runtime.instance.Instance
 
getNumberOfAvailableSlots() - Method in class org.apache.flink.runtime.instance.InstanceManager
 
getNumberOfAvailableSlots() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
NOTE: In the presence of multi-threaded operations, this number may be inexact.
getNumberOfAvailableSlotsForGroup(AbstractID) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
Gets the number of shared slots into which the given group can place subtasks or nested task groups.
getNumberOfCachedJobs() - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
 
getNumberOfChainedStubs() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getNumberOfCompletedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
Returns the number of completed checkpoints.
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
 
getNumberOfExecutionJobVertices() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Gets the number of job vertices currently held by this execution graph.
getNumberOfFailedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
Returns the number of failed checkpoints.
getNumberOfFullRestarts() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Gets the number of full restarts that the execution graph went through.
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.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.
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
 
getNumberOfInstancesWithAvailableSlots() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
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.heap.InternalKeyContext
Returns the number of key-groups aka max parallelism.
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.
getNumberOfLocalizedAssignments() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
getNumberOfNonAcknowledgedTasks() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
getNumberOfNonLocalizedAssignments() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
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.state.OperatorStateCheckpointOutputStream
 
getNumberOfPendingCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
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.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.ResultPartition
 
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.instance.InstanceManager
 
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.
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.
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 class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
getNumberOfRetainedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
 
getNumberOfRetainedSuccessfulCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
getNumberOfSlots() - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
Gets the number of slots that are currently governed by this assignment group.
getNumberOfSlots() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
getNumberOfSlots() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getNumberOfSpillingDirectories() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
Gets the number of directories across which the I/O manager rotates its files.
getNumberOfStartedTaskManagers() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Gets the number of currently started TaskManagers.
getNumberOfSubpartitions() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
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
 
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
Returns the number of subtasks.
getNumberOfSubtasks() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
 
getNumberOfSubTasks() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
Returns the number of sub tasks.
getNumberOfUnconstrainedAssignments() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
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.
getNumberPendingSlotRequests() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
getNumberPendingSlotRequests() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
 
getNumberRegisteredSlots() - Method in class org.apache.flink.runtime.resourcemanager.ResourceOverview
 
getNumberRegisteredSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
 
getNumberRegisteredSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
getNumberRegisteredSlotsOf(InstanceID) - Method in class 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.
getNumBytesInLocal() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumBytesInLocalCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumBytesInLocalPerSecond() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumBytesInLocalRateMeter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumBytesInRemote() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumBytesInRemoteCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumBytesInRemotePerSecond() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumBytesInRemoteRateMeter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumBytesInTotal() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumBytesOut() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumBytesOutCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumBytesOutPerSecond() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumBytesOutRateMeter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumFuturesCompleted() - Method in class org.apache.flink.runtime.concurrent.FutureUtils.ConjunctFuture
Gets the number of Futures in the conjunction that are already complete.
getNumFuturesTotal() - Method in class org.apache.flink.runtime.concurrent.FutureUtils.ConjunctFuture
Gets the total number of Futures in the conjunction.
getNumInputs() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
 
getNumInputs() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
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.
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
 
getNumRecordsIn() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumRecordsInCounter() - Method in class org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
 
getNumRecordsInCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumRecordsInPerSecond() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumRecordsInRateMeter() - Method in class org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
 
getNumRecordsOut() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumRecordsOutCounter() - Method in class org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
 
getNumRecordsOutCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumRecordsOutPerSecond() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumRecordsOutRate() - Method in class org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
 
getNumRegisteredKeyGroups() - Method in class org.apache.flink.runtime.query.KvStateLocation
Returns the current number of registered key groups.
getNumRequiredComparators() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
 
getNumSlotsAvailable() - Method in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
 
getNumSlotsTotal() - Method in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
 
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
 
getNumTaskManagersConnected() - Method in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
 
getNumTasks() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
 
getNumWorkerRequestsPending() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Gets the number of requested workers that have not yet been granted.
getNumWorkerRequestsPending() - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
getNumWorkersPendingRegistration() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Gets the number of containers that have been started, but where the TaskManager has not yet registered at the job manager.
getNumWorkersPendingRegistration() - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
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
 
getOffsetForKeyGroup(int) - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
 
getOffsets() - Method in class org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
 
getOpenFileHandlesLimit() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
Tries to retrieve the maximum number of open file handles.
getOperationKey(HandlerRequest<EmptyRequestBody, M>) - 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, RescalingStatusMessageParameters>) - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingStatusHandler
 
getOperationKey(HandlerRequest<EmptyRequestBody, SavepointDisposalStatusMessageParameters>) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalStatusHandler
 
getOperationKey(HandlerRequest<EmptyRequestBody, SavepointStatusMessageParameters>) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointStatusHandler
 
getOperatorBackPressureStats(ExecutionJobVertex) - Method in interface org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTracker
Returns back pressure statistics for a operator.
getOperatorBackPressureStats(ExecutionJobVertex) - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTrackerImpl
Returns back pressure statistics for a operator.
getOperatorBackPressureStats() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStatsResponse
 
getOperatorDescription() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
getOperatorFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
 
getOperatorID() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
 
getOperatorId() - Method in class org.apache.flink.runtime.jobgraph.OperatorInstanceID
 
getOperatorIDs() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
Returns a list containing the IDs 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.jobgraph.JobVertex
 
getOperatorPrettyName() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
getOperatorsMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
Get the memory the operators needed in MB.
getOperatorState(ListStateDescriptor<S>) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
Deprecated.
This was deprecated as part of a refinement to the function names. Please use DefaultOperatorStateBackend.getListState(ListStateDescriptor) instead.
getOperatorStateMetaInfoSnapshots() - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
 
getOperatorStateReaderForVersion(int, ClassLoader) - Static method in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters
 
getOperatorStates() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
getOperatorStates() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
getOperatorStates() - Method in interface org.apache.flink.runtime.checkpoint.savepoint.Savepoint
Returns the snapshotted operator states.
getOperatorStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
 
getOperatorStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
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
 
getOperatorStateWriterForVersion(int, RegisteredOperatorBackendStateMetaInfo.Snapshot<S>) - Static method in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters
 
getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, V>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
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.
getOutputCollector() - Method in class org.apache.flink.runtime.operators.BatchTask
 
getOutputCollector(AbstractInvokable, TaskConfig, ClassLoader, List<RecordWriter<?>>, int, int) - Static method in class org.apache.flink.runtime.operators.BatchTask
Creates the Collector for the given task, as described by the given configuration.
getOutputCollector() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
getOutputCollector() - Method in interface org.apache.flink.runtime.operators.TaskContext
 
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
 
getOutputPartitioner(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getOutputSerializer(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getOutputShipStrategy(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
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.instance.Slot
Gets the owner of this slot.
getOwningJob(AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Returns the owning job of the TaskSlot identified by the given AllocationID.
getPackages() - Method in class org.apache.flink.runtime.util.DependencyVisitor
 
getPageSize() - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGate
 
getPageSize() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
getPageSize() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
getPageSize() - Method in class org.apache.flink.runtime.memory.MemoryManager
Gets the size of the pages handled by the memory manager.
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.jobgraph.JobVertex
Gets the parallelism of the task.
getParallelism() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
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
 
getParameterTypes() - Method in class org.apache.flink.runtime.rpc.messages.LocalRpcInvocation
 
getParameterTypes() - Method in class org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation
 
getParameterTypes() - Method in interface org.apache.flink.runtime.rpc.messages.RpcInvocation
Returns the method's parameter types
getParent() - Method in class org.apache.flink.runtime.instance.Slot
Gets the parent slot of this slot.
getPartitionById(IntermediateResultPartitionID) - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
Returns the partition with the given ID.
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(StateDescriptor<S, ?>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
 
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.
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 exception org.apache.flink.runtime.io.network.partition.PartitionNotFoundException
 
getPartitionId() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
 
getPartitionId() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionID
 
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.
getPartitionNumber() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
 
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.
getPartitionRequestInitialBackoff() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
getPartitionRequestMaxBackoff() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
getPartitions() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
 
getPartitionStateChecker() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getPartitionStateSerializer() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo
 
getPartitionStateSerializer() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo.Snapshot
 
getPartitionStateSerializerConfigSnapshot() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo.Snapshot
 
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.
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.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.jobmanager.ZooKeeperSubmittedJobGraphStore
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 MessagePathParameter for 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.TaskCheckpointMessageParameters
 
getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.EmptyMessageParameters
 
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.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.JobMessageParameters
 
getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.JobTerminationMessageParameters
 
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 MessagePathParameter that the request supports.
getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMessageParameters
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointConfigHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsDetailsHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsDetailsSubtasksHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.ClusterConfigHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.ClusterOverviewHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.CurrentJobIdsHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.DashboardConfigHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobAccumulatorsHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobCancellationHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobConfigHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobDetailsHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobExceptionsHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobPlanHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobsOverviewHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobStoppingHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexAccumulatorsHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexBackPressureHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexDetailsHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexTaskManagersHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.AggregatingJobsMetricsHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.AggregatingSubtasksMetricsHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.AggregatingTaskManagersMetricsHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.JobManagerMetricsHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.JobMetricsHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.JobVertexMetricsHandler
Deprecated.
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.SubtaskMetricsHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.TaskManagerMetricsHandler
 
getPaths() - Method in interface org.apache.flink.runtime.rest.handler.legacy.RequestHandler
Returns an array of REST URL's under which this handler can be registered.
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtaskCurrentAttemptDetailsHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptAccumulatorsHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptDetailsHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtasksAllAccumulatorsHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtasksTimesHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.TaskManagerLogHandler
 
getPaths() - Method in class org.apache.flink.runtime.rest.handler.legacy.TaskManagersHandler
 
getPaths() - Method in interface org.apache.flink.runtime.rest.handler.WebHandler
Returns an array of REST URL's under which this handler can be registered.
getPayload() - Method in class org.apache.flink.runtime.instance.SharedSlot
 
getPayload() - Method in class org.apache.flink.runtime.instance.SimpleSlot
 
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
 
getPayload() - Method in interface org.apache.flink.runtime.rpc.messages.FencedMessage
 
getPayload() - Method in class org.apache.flink.runtime.rpc.messages.LocalFencedMessage
 
getPayload() - Method in class org.apache.flink.runtime.rpc.messages.RemoteFencedMessage
 
getPayload() - Method in class org.apache.flink.runtime.rpc.messages.UnfencedMessage
 
getPendingCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointTriggerResult
 
getPendingCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
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.
getPhysicalSlotNumber() - Method in class org.apache.flink.runtime.instance.SharedSlot
 
getPhysicalSlotNumber() - Method in class org.apache.flink.runtime.instance.SimpleSlot
 
getPhysicalSlotNumber() - Method in class org.apache.flink.runtime.instance.SimpleSlotContext
 
getPhysicalSlotNumber() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
Gets the slot number on the TaskManager.
getPhysicalSlotNumber() - Method in interface org.apache.flink.runtime.jobmaster.SlotContext
Gets the number of the slot.
getPhysicalSlotNumber() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
 
getPipelineBreakingExchange(ExecutionMode) - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
 
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.minicluster.StandaloneMiniCluster
 
getPort() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
getPort() - Method in interface org.apache.flink.runtime.rpc.RpcService
Return the port under which the rpc service is reachable.
getPort() - Method in class org.apache.flink.runtime.util.LeaderConnectionInfo
 
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.FsCheckpointMetadataOutputStream
 
getPos() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
 
getPos() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
 
getPosition() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileSegment
 
getPreferredLocations() - Method in class org.apache.flink.runtime.clusterframework.types.SlotProfile
Returns the preferred locations for the slot.
getPreferredLocations() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
Gets the overall preferred execution location for this vertex's current execution.
getPreferredLocationsBasedOnInputs() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
Gets the location preferences of the vertex's current task execution, as determined by the locations of the predecessors from which it receives input data.
getPreferredLocationsBasedOnState() - 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.
getPreferredResources() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Gets the preferred resource for the task.
getPreProcessingOperationName() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
Gets the name of the pro-processing operation for this input.
getPreviousGlobalAggregate(String) - Method in class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
 
getPrincipal() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
 
getPriorAllocations() - Method in class org.apache.flink.runtime.clusterframework.types.SlotProfile
Returns the desired allocation ids for the slot.
getPriorExecutionAttempt(int) - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
Returns the execution for the given attempt number.
getPriorExecutionAttempt(int) - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
getPriorExecutionAttempt(int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
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.
getPrivateState() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
 
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
 
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
 
getProducedPartitions() - Method in class org.apache.flink.runtime.taskmanager.Task
 
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
 
getProducerId() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionID
 
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.metrics.DescriptiveStatisticsHistogramStatistics
 
getQueryableStateConfig() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getQueryParameter(Class<QP>) - Method in class org.apache.flink.runtime.rest.handler.HandlerRequest
Returns the value of the MessageQueryParameter for the given class.
getQueryParameter(HandlerRequest<R, M>, Class<P>) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRequestUtils
Returns the value of a query parameter, or null if the query parameter is not set.
getQueryParameter(HandlerRequest<R, M>, 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.EmptyMessageParameters
 
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.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.JobMessageParameters
 
getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.JobTerminationMessageParameters
 
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 MessageQueryParameter that the request supports.
getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMessageParameters
 
getQueryService() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
 
getQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
Returns the metric query service scope for this group.
getRatio() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
 
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
Returns a handle to the raw keyed state.
getRawKeyedState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
 
getRawKeyedStateHandles(OperatorState, KeyGroupRange) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
Collect rawKeyedStateHandles which have intersection with given KeyGroupRange from operatorState
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
Returns a handle to the raw operator state.
getRawOperatorState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
 
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
 
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).
getReaderForVersion(int, ClassLoader) - Static method in class org.apache.flink.runtime.state.KeyedBackendStateMetaInfoSnapshotReaderWriters
 
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.NetworkBuffer
 
getReaderIndex() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
getReadingThread(ExceptionHandler<IOException>, MutableObjectIterator<E>, UnilateralSortMerger.CircularQueues<E>, LargeRecordHandler<E>, AbstractInvokable, TypeSerializer<E>, long) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Creates the reading thread.
getReadPosition() - Method in class org.apache.flink.runtime.io.disk.RandomAccessInputView
 
getReason() - Method in class org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint
Gets the reason why the checkpoint was declined.
getReason() - Method in class org.apache.flink.runtime.registration.RegistrationResponse.Decline
Gets the reason for the rejection.
getReceiverId() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
 
getRecord(int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
getRecord(T, 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(T, 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.NormalizedKeySorter
 
getRecordCount() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
number of records in partition including garbage
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
 
getRecoveryMode(Configuration) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
Gets the recovery mode as configured, based on HighAvailabilityOptions.HA_MODE.
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.NetworkBuffer
 
getRecycler() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
getRedirectAddress(String, RestfulGateway, Time) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRedirectUtils
 
getRedirectResponse(String, String) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRedirectUtils
 
getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
 
getReference() - Method in class org.apache.flink.runtime.state.SharedStateRegistry.Result
 
getReferenceBytes() - Method in class org.apache.flink.runtime.state.CheckpointStorageLocationReference
Gets the reference bytes.
getReferenceCount() - Method in class org.apache.flink.runtime.state.SharedStateRegistry.Result
 
getRefreshInterval() - Method in class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
 
getRefreshInterval() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
 
getRefusedRegistrationPause() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getRegisteredBroadcastStateNames() - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
getRegisteredExecutions() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getRegisteredInstance(ResourceID) - Method in class org.apache.flink.runtime.instance.InstanceManager
 
getRegisteredInstanceById(InstanceID) - Method in class org.apache.flink.runtime.instance.InstanceManager
 
getRegisteredStateNames() - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
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.
getRegistrationName() - Method in class org.apache.flink.runtime.query.KvStateMessage.LookupKvStateLocation
Returns the name under which the KvState has been registered.
getRegistrationName() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
Returns the name under which the KvState has been registered.
getRegistrationName() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
Returns the name under which the KvState has been registered.
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
 
getRelativeSolutionSetMemory() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
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.
getReporterConfigurations() - Method in class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
 
getReporters() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
 
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.TaskCheckpointStatisticsHeaders
 
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.DashboardConfigurationHeaders
 
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.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.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.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.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.JobPlanHeaders
 
getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
 
getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobTerminationHeaders
 
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.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.TaskManagerDetailsHeaders
 
getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
 
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 interface org.apache.flink.runtime.rest.messages.UntypedResponseMessageHeaders
Returns the class of the request message.
getRequestFuture() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
getRequiredClasspaths() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Returns a list of classpaths referring to the directories/JAR files required to run this job.
getRequiredClasspaths() - Method in class org.apache.flink.runtime.jobmaster.message.ClassloadingProps
 
getRequiredClasspathURLs() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
 
getRequiredJarFileBlobKeys() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
 
getRequiredJarFiles() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Returns a list of BLOB keys referring to the JAR files required to run this job.
getRequiredJarFiles() - Method in class org.apache.flink.runtime.jobmaster.message.ClassloadingProps
 
getResolvedRootSlots() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager
Returns a collection of all resolved root slots.
getResourceID() - Method in class org.apache.flink.runtime.clusterframework.messages.NotifyResourceStarted
 
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.jobmaster.JMTMRegistrationSuccess
 
getResourceID() - Method in class org.apache.flink.runtime.resourcemanager.registration.TaskExecutorConnection
 
getResourceId() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
 
getResourceID() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getResourceID() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
getResourceID() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
Gets the ID of the resource in which the TaskManager is started.
getResourceIdString() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceID
Gets the Resource Id as string
getResourceManageGateway() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRunner
 
getResourceManagerBindAddress() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
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.
getResourceManagerLeaderElectionService() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
Gets the leader election service for the cluster's resource manager.
getResourceManagerLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
 
getResourceManagerLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
 
getResourceManagerLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
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
 
getResourceManagerLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getResourceManagerProps(Class<? extends FlinkResourceManager>, Configuration, LeaderRetrievalService) - Static method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
 
getResourceManagerResourceId() - Method in class org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess
 
getResourceProfile() - Method in class org.apache.flink.runtime.clusterframework.types.SlotProfile
Returns the desired resource profile for the slot.
getResourceProfile() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
getResourceProfile() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
getResourceProfile() - Method in class org.apache.flink.runtime.resourcemanager.SlotRequest
Get the resource profile of the desired slot
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
getResources() - Method in class org.apache.flink.runtime.instance.Instance
 
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.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.DashboardConfigurationHeaders
 
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.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.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.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.JobPlanHeaders
 
getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
 
getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobTerminationHeaders
 
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.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.TaskManagersHeaders
 
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.TaskCheckpointStatisticsHeaders
 
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.DashboardConfigurationHeaders
 
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.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.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.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.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.JobPlanHeaders
 
getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
 
getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobTerminationHeaders
 
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.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.TaskManagersHeaders
 
getResponseTypeParameters() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationStatusMessageHeaders
 
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
 
getRestAddress() - Method in interface org.apache.flink.runtime.webmonitor.WebMonitor
Returns the REST address of this WebMonitor.
getRestartStrategy() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getRestartStrategyFactory() - Method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
 
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.
getRestBindPort() - Method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
Returns the port that the REST server endpoint should listen on.
getRestoreCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.JobManagerTaskRestore
 
getRestoredCheckpointStatistics() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
 
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.ClusterConfiguration
 
getResultFuture() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
 
getResultId() - Method in class org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor
 
getResultId() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
getResultOptimizerProperties() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
getResultPartitionConsumableNotifier() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getResultPartitionManager() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
getResultType() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
 
getResultType() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
 
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.
getRoot() - Method in class org.apache.flink.runtime.instance.Slot
Gets the root slot of the tree containing this slot.
getRootSlotNumber() - Method in class org.apache.flink.runtime.instance.Slot
Gets the number of the root slot.
getRpcGateway() - Method in class org.apache.flink.runtime.rpc.messages.RemoteHandshakeMessage
 
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.rpc.RpcEndpoint
Gets the endpoint's RPC service.
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.minicluster.MiniClusterConfiguration
 
getRpcUrl(String, int, String, HighAvailabilityServicesUtils.AddressResolution, Configuration) - Static method in class org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
 
getRpcUrl(String, int, String, HighAvailabilityServicesUtils.AddressResolution, AkkaRpcServiceUtils.AkkaProtocol) - Static method in class org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
 
getRunnable() - Method in class org.apache.flink.runtime.rpc.messages.RunAsync
 
getRunningJobsRegistry() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
Gets the registry that holds information about whether jobs are currently running.
getRunningJobsRegistry() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
getRunningJobsRegistry() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getSampleId() - Method in class org.apache.flink.runtime.messages.StackTraceSampleResponse
 
getSampleId() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
Returns the ID of the sample.
getSampleId() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSample
Returns the ID of the sample.
getSamples() - Method in class org.apache.flink.runtime.messages.StackTraceSampleResponse
 
getSavepointPath() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalRequest
 
getSavepointPath() - Method in class org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
Gets the directory where savepoints are stored by default (when no custom path is given to the savepoint trigger command).
getSavepointRestoreSettings() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Returns the configured savepoint restore setting.
getSavepointStatistics() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
 
getScheduledExecutor() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
getScheduledExecutor() - Method in interface org.apache.flink.runtime.rpc.RpcService
Gets a scheduled executor from the RPC service.
getScheduledExecutorService() - Method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
 
getScheduleMode() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getScheduleMode() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
 
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
 
getSecurityConfig() - Method in class org.apache.flink.runtime.security.modules.HadoopModule
 
getSecurityModuleFactories() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
 
getSegmentsForReaders(List<List<MemorySegment>>, List<MemorySegment>, int) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Divides the given collection of memory buffers among numChannels sublists.
getSegmentSize() - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
Gets the size of the segments used by this view.
getSelfGateway(Class<C>) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Returns a self gateway of the specified type which can be used to issue asynchronous calls against the RpcEndpoint.
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
 
getSequenceNumber() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
 
getSerializableListState(String) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
Deprecated.
Using Java serialization for persisting state is not encouraged. Please use DefaultOperatorStateBackend.getListState(ListStateDescriptor) instead.
getSerializedAccumulatorResults() - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
 
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.TaskDeploymentDescriptor
Return the sub task's serialized job information.
getSerializedTaskInformation() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
Return the sub task's serialized task information.
getSerializedThrowable() - Method in class org.apache.flink.runtime.jobmaster.JobResult
Returns an empty Optional if the job finished successfully, otherwise the Optional will carry the failure cause.
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<List<V>>) - Method in class org.apache.flink.runtime.state.heap.HeapListState
 
getSerializedValue(byte[], TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<Map<UK, UV>>) - Method in class org.apache.flink.runtime.state.heap.HeapMapState
 
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(T) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializers
Returns the SavepointSerializer for the given savepoint.
getSerializer(int) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializers
Returns the SavepointSerializer for the given savepoint version.
getServerAddress() - Method in interface org.apache.flink.runtime.query.KvStateServer
Returns the address the 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
 
getServerPort() - Method in interface org.apache.flink.runtime.webmonitor.WebMonitor
Gets the port that the web server actually binds to.
getSessionTimeout() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Gets the timeout after which the corresponding ExecutionGraph is removed at the job manager after it has been executed.
getSharedSlot() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Gets the shared slot into which this constraint's tasks are places.
getSharedSlotForTask(AbstractID, Iterable<TaskManagerLocation>, boolean) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
 
getSharedState() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
 
getSharedStateDirectory() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
 
getSharedStateHandleIDs() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
 
getSharedStateRegistry() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
 
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", ...
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.
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.rpc.messages.RemoteRpcInvocation
Size (#bytes of the serialized data) of the rpc invocation message.
getSizeLimit() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
 
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.
getSizeUnsafe() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
Returns the size of the written data, i.e.
getSizeUnsafe() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
getSizeUnsafe() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
getSlot() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotAndLocality
 
getSlotContext() - Method in class org.apache.flink.runtime.instance.Slot
Gets the allocated slot that this slot refers to.
getSlotForTask(JobVertexID, Iterable<TaskManagerLocation>) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
Gets a slot suitable for the given task vertex.
getSlotForTask(CoLocationConstraint, Iterable<TaskManagerLocation>) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
Gets a slot for a task that has a co-location constraint.
getSlotId() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
getSlotID() - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
Get the unique identification of this slot
getSlotIndex() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotOffer
 
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
 
getSlotNumber() - Method in class org.apache.flink.runtime.instance.Slot
Gets the number of the slot.
getSlotOwner() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
Gets the slot owner implementation for this pool.
getSlotProvider() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getSlotProvider() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
Gets the slot provider implementation for this pool.
getSlotRequestId() - Method in class org.apache.flink.runtime.instance.SharedSlot
 
getSlotRequestId() - Method in class org.apache.flink.runtime.instance.SimpleSlot
 
getSlotRequestId() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Returns the currently assigned slot request id identifying the slot to which tasks belonging to this co-location constraint will be deployed to.
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.SingleLogicalSlot
 
getSlotRequestId() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.TaskSlot
 
getSlotRequestTimeout() - Method in class org.apache.flink.runtime.jobmaster.JobMasterConfiguration
 
getSlotRequestTimeout() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
 
getSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
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.
getSlotSharingGroupId() - Method in class org.apache.flink.runtime.instance.SharedSlot
 
getSlotSharingGroupId() - Method in class org.apache.flink.runtime.instance.SimpleSlot
 
getSlotSharingGroupId() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
getSlotSharingGroupId() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
getSlotSharingGroupId() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
Gets the slot sharing group id to which this slot belongs.
getSlotSharingGroupId() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
 
getSnapshot() - Method in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
Creates a snapshot of this accumulator registry.
getSolutionSetComparator(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getSolutionSetSerializer(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getSortingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
getSource() - Method in class org.apache.flink.runtime.executiongraph.ExecutionEdge
 
getSource() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
Returns the data set at the source of the edge.
getSourceId() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
Gets the ID of the consumed data set.
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.
getSpillingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable, MemoryManager, IOManager, TypeSerializerFactory<E>, TypeComparator<E>, List<MemorySegment>, List<MemorySegment>, int) - Method in class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger
 
getSpillingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable, MemoryManager, IOManager, TypeSerializerFactory<E>, TypeComparator<E>, List<MemorySegment>, List<MemorySegment>, int) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
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
 
getSSLEnabled() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
getSSLEnabled(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
Retrieves the global ssl flag from configuration.
getSslEngineFactory() - Method in class org.apache.flink.runtime.rest.RestClientConfiguration
Returns the SSLEngine that the REST client endpoint should use.
getSslEngineFactory() - Method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
Returns the SSLEngine that the REST server endpoint should use.
getStackTrace() - Method in class org.apache.flink.runtime.messages.StackTrace
 
getStackTraces() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSample
Returns the a map of stack traces by execution ID.
getStartCommand(String, Map<String, String>) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
Replaces placeholders in the template start command with values from startCommandValues.
getStartedTaskManagers() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Gets the currently registered resources.
getStartKeyGroup() - Method in class org.apache.flink.runtime.state.KeyGroupRange
 
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.handler.legacy.backpressure.StackTraceSample
Returns the time stamp, when the sample was triggered.
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
 
getState(int) - Method in class org.apache.flink.runtime.checkpoint.OperatorState
 
getState(int) - Method in class org.apache.flink.runtime.checkpoint.TaskState
Deprecated.
 
getState() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
getState() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
Returns the current ExecutionState for this execution.
getState() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the current JobStatus for 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.Execution
 
getState() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getState() - Method in class org.apache.flink.runtime.executiongraph.failover.FailoverRegion
 
getState() - Method in class org.apache.flink.runtime.query.KvStateEntry
 
getState(ValueStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
 
getState() - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
Returns the internal data structure.
getState() - Method in interface org.apache.flink.runtime.state.heap.StateEntry
Returns the state of this entry.
getStateMetaInfo() - Method in interface org.apache.flink.runtime.state.BackendWritableBroadcastState
 
getStateMetaInfo() - Method in class org.apache.flink.runtime.state.HeapBroadcastState
 
getStateMetaInfoSnapshots() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
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
 
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.CopyOnWriteStateTable
 
getStateSerializer() - Method in class org.apache.flink.runtime.state.heap.StateTable
 
getStateSerializer() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
 
getStateSerializer() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo.Snapshot
 
getStateSerializerConfigSnapshot() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo.Snapshot
 
getStateServerPortRange() - Method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
Returns the port range where the queryable state client proxy 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.FailedCheckpointStats
 
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.StateObjectCollection
 
getStateSize() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
 
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
Returns the total checkpoint state size over all subtasks.
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.ChainedStateHandle
 
getStateSize() - Method in class org.apache.flink.runtime.state.DirectoryKeyedStateHandle
 
getStateSize() - Method in class org.apache.flink.runtime.state.DirectoryStateHandle
 
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
 
getStateSize() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
 
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.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.TaskStateStats.TaskStateStatsSummary
Returns the summary stats for the state size.
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.RegisteredKeyedBackendStateMetaInfo
 
getStateType() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo.Snapshot
 
getStateValueSerializer() - Method in class org.apache.flink.runtime.query.KvStateInfo
 
getStatistics() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogram
 
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.messages.webmonitor.JobDetails
 
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
 
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.ExecutionGraph
 
getStdDev() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
 
getStopException() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
Returns a potential exception that might have been observed while stopping the operation.
getStopException() - Method in interface org.apache.flink.runtime.io.async.AsyncStoppable
Delivers Exception that might happen during AsyncStoppable.stop()
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.ArchivedExecutionGraphStore
Return the JobsOverview for all stored/past jobs.
getStoredJobsOverview() - Method in class org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
 
getStoredJobsOverview() - Method in class org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
 
getStores(MetricStore, Map<String, String>, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.AggregatingJobsMetricsHandler
 
getStores(MetricStore, Map<String, String>, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.AggregatingSubtasksMetricsHandler
 
getStores(MetricStore, Map<String, String>, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.AggregatingTaskManagersMetricsHandler
 
getStrategyName() - Method in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategy
Gets the name of the failover strategy, for logging purposes.
getStrategyName() - Method in class org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy
 
getStrategyName() - Method in class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
 
getStrategyName() - Method in class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
 
getStream() - Method in class org.apache.flink.runtime.state.StatePartitionStreamProvider
Returns a stream with the data of one state partition.
getStrictObjectMapper() - Static method in class org.apache.flink.runtime.rest.util.RestMapperUtils
Returns a preconfigured ObjectMapper.
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.ChainedTerminationCriterionDriver
 
getStub() - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
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
 
getSubmittedJobGraphStore() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
Gets the submitted job graph store for the job manager
getSubmittedJobGraphStore() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
getSubmittedJobGraphStore() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getSubtask() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
 
getSubtaskCheckpointStatistics() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails
 
getSubtaskId() - Method in class org.apache.flink.runtime.jobgraph.OperatorInstanceID
 
getSubtaskIndex() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
Returns the subtask index.
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.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
getSubtaskMetricStore(String, String, int) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
Returns the MetricStore.ComponentMetricStore for the given job/task ID and subtask index.
getSubtaskMetricStore(int) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.TaskMetricStore
 
getSubtasks() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
 
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.MinMaxAvgStats
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
 
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
Returns the summary of the subtask stats.
getSuperstep() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
 
getSyncCheckpointDuration() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
Returns the duration of the synchronous part of the checkpoint.
getSyncCheckpointDurationStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
Returns the summary stats for the sync checkpoint duration.
getSyncDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
 
getSyncDurationMillis() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
getSynchronousDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
 
getSystemProperties() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
Get the system properties.
getTarget() - Method in class org.apache.flink.runtime.executiongraph.ExecutionEdge
 
getTarget() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
Returns the vertex connected to this edge.
getTargetAddress() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
 
getTargetAddress() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
getTargetAddress() - Method in class org.apache.flink.runtime.resourcemanager.SlotRequest
 
getTargetDirectory() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerRequestBody
 
getTargetGateway() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
Gets the RegisteredGateway.
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.LogFileHandlerSpecification
 
getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.handler.legacy.files.StdoutFileHandlerSpecification
 
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.TaskCheckpointStatisticsHeaders
 
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.DashboardConfigurationHeaders
 
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.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.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.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.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.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.JobPlanHeaders
 
getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
 
getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobTerminationHeaders
 
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.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.TaskManagerDetailsHeaders
 
getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
 
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.YarnCancelJobTerminationHeaders
Deprecated.
 
getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.YarnStopJobTerminationHeaders
Deprecated.
 
getTargetSlotNumber() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
Gets the number of the slot into which the task is to be deployed.
getTask(ExecutionAttemptID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Get the task for the given execution attempt id.
getTaskAssignment() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
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
 
getTaskEventDispatcher() - Method in interface org.apache.flink.runtime.execution.Environment
 
getTaskEventDispatcher() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
getTaskEventDispatcher() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getTaskExecutionId() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
 
getTaskExecutorGateway() - Method in class org.apache.flink.runtime.resourcemanager.registration.TaskExecutorConnection
 
getTaskFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
 
getTaskInfo() - Method in interface org.apache.flink.runtime.execution.Environment
Returns the TaskInfo object associated with this subtask
getTaskInfo() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getTaskInfo() - Method in class org.apache.flink.runtime.taskmanager.Task
 
getTaskInformationOrBlobKey() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getTaskKvStateRegistry() - Method in interface org.apache.flink.runtime.execution.Environment
Returns the registry for InternalKvState instances.
getTaskKvStateRegistry() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getTaskLocalSnapshot() - Method in class org.apache.flink.runtime.state.SnapshotResult
 
getTaskManagerActions() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getTaskManagerAddress() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getTaskManagerBindAddress() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
getTaskManagerConnection() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
getTaskManagerConnection() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
getTaskManagerFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
 
getTaskManagerGateway() - Method in class org.apache.flink.runtime.instance.Instance
Returns the InstanceGateway of this Instance.
getTaskManagerGateway() - Method in class org.apache.flink.runtime.instance.SimpleSlotContext
 
getTaskManagerGateway() - Method in class org.apache.flink.runtime.instance.Slot
Gets the actor gateway that can be used to send messages to the TaskManager.
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.instance.Instance
 
getTaskManagerID() - Method in class org.apache.flink.runtime.instance.Slot
Gets the ID of the TaskManager that offers this slot.
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.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
 
getTaskManagerLocation() - Method in class org.apache.flink.runtime.instance.Instance
 
getTaskManagerLocation() - Method in class org.apache.flink.runtime.instance.SimpleSlotContext
 
getTaskManagerLocation() - Method in class org.apache.flink.runtime.instance.Slot
Gets the location info of the TaskManager that offers this slot.
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.SlotContext
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.taskexecutor.TaskManagerServices
 
getTaskManagerLocationFuture() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
getTaskManagerLogPath() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getTaskManagerMetricStore(String) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
Returns the MetricStore.TaskManagerMetricStore for the given taskmanager ID.
getTaskManagerRequestTimeout() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
 
getTaskManagers() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
 
getTaskManagerShellCommand(Configuration, ContaineredTaskManagerParameters, String, String, boolean, boolean, boolean, Class<?>) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
Generates the shell command to start a task manager.
getTaskManagerStateStore() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getTaskManagerStdoutPath() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getTaskManagerTimeout() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
 
getTaskMetricStore(String, String) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
Returns the MetricStore.ComponentMetricStore for 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 class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
 
getTaskName() - Method in exception org.apache.flink.runtime.operators.chaining.ExceptionInChainedStubException
 
getTaskName() - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
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
 
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 by ExecutionVertex.getParallelSubtaskIndex()+ 1, and 'y' is the total number of tasks, as returned by ExecutionVertex.getTotalNumberOfParallelSubtasks().
getTaskOwnedStateDirectory() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
 
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 class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Return an iterator over all tasks for a given job.
getTaskSlotTable() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
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
 
getTaskStates() - Method in interface org.apache.flink.runtime.checkpoint.savepoint.Savepoint
Deprecated.
Only kept for backwards-compatibility with versionS < 1.3. Will be removed in the future.
getTaskStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
 
getTaskStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
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 null if no task with such an ID is available.
getTaskToExecute() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
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
 
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 class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
getTerminationFuture() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Returns the termination future of this ExecutionGraph.
getTerminationFuture() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
getTerminationFuture() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Return a future which is completed with true when the rpc endpoint has been terminated.
getTerminationFuture() - Method in interface org.apache.flink.runtime.rpc.RpcServer
Return a future which is completed when the rpc endpoint has been terminated.
getTerminationFuture() - Method in interface org.apache.flink.runtime.rpc.RpcService
Returns a future indicating when the RPC service has been shut down.
getTerminationFuture() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
getTimeNanos() - Method in class org.apache.flink.runtime.rpc.messages.RunAsync
 
getTimeout() - Method in class org.apache.flink.runtime.client.JobListeningContext
 
getTimeout() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerConfiguration
 
getTimeout() - Method in class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
 
getTimeout() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getTimerServiceShutdownTimeout() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
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.io.network.api.CheckpointBarrier
 
getTimestamp() - Method in class org.apache.flink.runtime.messages.checkpoint.NotifyCheckpointComplete
 
getTimestamp() - Method in class org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
 
getTimestamps() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
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.jobmaster.JobMasterConfiguration
 
getTmpDirPaths() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getTotalFields() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
 
getTotalNumberCheckpoints() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
 
getTotalNumberOfBuffers() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
getTotalNumberOfBytes() - 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
 
getTotalNumberOfSlots() - Method in class org.apache.flink.runtime.instance.Instance
 
getTotalNumberOfSlots() - Method in class org.apache.flink.runtime.instance.InstanceManager
 
getTotalNumberOfSlots() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
getTotalNumberOfVertices() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getTotalNumPages() - Method in class org.apache.flink.runtime.memory.MemoryManager
Gets the total number of memory pages managed by this memory manager.
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.
getTransportType() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
getTriggerHandler() - Method in class org.apache.flink.runtime.rest.handler.legacy.JobCancellationWithSavepointHandlers
 
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
 
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
 
getType() - Method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
 
getType() - Method in exception org.apache.flink.runtime.broadcast.InitializationTypeConflictException
 
getType() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
 
getTypeClass() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
 
getUdfRuntimeContext() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
getUnannouncedCredit() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
Gets the currently unannounced credit.
getUnavailableResponse() - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRedirectUtils
 
getUnfencedMainThreadExecutor() - Method in class org.apache.flink.runtime.rpc.FencedRpcEndpoint
Returns a main thread executor which is not bound to the fencing token.
getUnionListState(ListStateDescriptor<S>) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
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.TaskCheckpointStatisticsHeaders
 
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.DashboardConfigurationHeaders
 
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.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.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.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.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.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.JobPlanHeaders
 
getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
 
getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobTerminationHeaders
 
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.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.TaskManagerDetailsHeaders
 
getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
 
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 interface org.apache.flink.runtime.rest.messages.UntypedResponseMessageHeaders
Returns a new MessageParameters object.
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
 
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.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
 
getUserClassLoader() - Method in interface org.apache.flink.runtime.execution.Environment
Returns the user code class loader
getUserClassLoader() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getUserClassLoader() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
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
 
getUserCodeClassLoaderInfo(ClassLoader) - Static method in class org.apache.flink.runtime.util.ClassLoaderUtil
Gets information about URL class loaders.
getUserDefinedOperatorIDs() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
Returns a list containing the alternative IDs of all operators contained in this execution job vertex.
getUserDefinedOperatorIDs() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
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.
getUserMap() - Method in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
Gets the map for user-defined accumulators.
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.NumberOfFullRestartsGauge
 
getValue() - Method in class org.apache.flink.runtime.executiongraph.metrics.RestartTimeGauge
 
getValue() - Method in class org.apache.flink.runtime.executiongraph.metrics.UpTimeGauge
 
getValue() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoEntry
 
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 null if it isn't resolved yet.
getValue() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
 
getValue() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperVersionedValue
 
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.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 class org.apache.flink.runtime.state.heap.HeapAggregatingState
 
getValueSerializer() - Method in class org.apache.flink.runtime.state.heap.HeapFoldingState
Deprecated.
 
getValueSerializer() - Method in class org.apache.flink.runtime.state.heap.HeapListState
 
getValueSerializer() - Method in class org.apache.flink.runtime.state.heap.HeapMapState
 
getValueSerializer() - Method in class org.apache.flink.runtime.state.heap.HeapReducingState
 
getValueSerializer() - Method in class org.apache.flink.runtime.state.heap.HeapValueState
 
getValueSerializer() - Method in interface org.apache.flink.runtime.state.internal.InternalKvState
Returns the TypeSerializer for the type of value this state holds.
getValueSerializer() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo
 
getValueSerializer() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo.Snapshot
 
getValueSerializerConfigSnapshot() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo.Snapshot
 
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.savepoint.SavepointV1
 
getVersion() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
getVersion() - Method in class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
 
getVersion() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
getVersion() - Method in class org.apache.flink.runtime.rpc.messages.RemoteHandshakeMessage
 
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.
getVersionedValue() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
 
getVertex() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
getVertexId() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
 
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.
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
 
getVerticesToAcknowledge() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
getVerticesToConfirm() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
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.ExecutionGraph
 
getVerticesToTrigger() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
getWaitForSolutionSetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getWebMonitorLeaderElectionService() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
 
getWebMonitorLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
 
getWebMonitorLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
 
getWebMonitorLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getWebMonitorLeaderRetriever() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
 
getWebMonitorLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
 
getWebMonitorLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
 
getWebMonitorLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getWebUiDir() - Method in class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
 
getWebUIPort() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
getWorker() - Method in class org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
 
getWorkerIndex() - Method in class org.apache.flink.runtime.iterative.event.WorkerDoneEvent
 
getWrappedException() - Method in exception org.apache.flink.runtime.operators.chaining.ExceptionInChainedStubException
 
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(int) - Method in interface org.apache.flink.runtime.execution.Environment
 
getWriter(int) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getWriterForVersion(int, RegisteredKeyedBackendStateMetaInfo.Snapshot<N, S>) - Static method in class org.apache.flink.runtime.state.KeyedBackendStateMetaInfoSnapshotReaderWriters
 
getWriters() - Method in class org.apache.flink.runtime.operators.shipping.OutputCollector
List of writers that are associated with this output collector
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
 
GlobalModVersionMismatch - Exception in org.apache.flink.runtime.executiongraph
An exception that indicates a mismatch between the expected global modification version of the execution graph, and the actual modification version.
GlobalModVersionMismatch(long, long) - Constructor for exception org.apache.flink.runtime.executiongraph.GlobalModVersionMismatch
 
go() - Method in class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger.CombiningSpillingThread
Entry point of the thread.
go() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ReadingThread
The entry point for the thread.
go() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SortingThread
Entry point of the thread.
go() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Entry point of the thread.
go() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
Equivalent to the run() method.
grantLeadership(UUID) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
Callback method when current resourceManager is granted leadership.
grantLeadership(UUID) - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
 
grantLeadership(UUID) - Method in interface org.apache.flink.runtime.leaderelection.LeaderContender
Callback method which is called by the LeaderElectionService upon selecting this instance as the new leader.
grantLeadership(UUID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
Callback method when current resourceManager is granted leadership.
grantLeadership(UUID) - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
 
GroupCombineChainedDriver<IN,OUT> - Class in org.apache.flink.runtime.operators.chaining
Chained variant of the GroupReduceCombineDriver Acts like a combiner with a custom output type OUT.
GroupCombineChainedDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
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

HadoopConfOverlay - Class in org.apache.flink.runtime.clusterframework.overlays
Overlays a Hadoop configuration into a container, based on a supplied Hadoop configuration directory.
HadoopConfOverlay(File) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.HadoopConfOverlay
 
HadoopConfOverlay.Builder - Class in org.apache.flink.runtime.clusterframework.overlays
A builder for the HadoopConfOverlay.
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
 
HadoopUserOverlay - Class in org.apache.flink.runtime.clusterframework.overlays
Overlays a Hadoop user context into a container.
HadoopUserOverlay(UserGroupInformation) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.HadoopUserOverlay
 
HadoopUserOverlay.Builder - Class in org.apache.flink.runtime.clusterframework.overlays
A builder for the HadoopUserOverlay.
handIn(String, V) - Method in class org.apache.flink.runtime.iterative.concurrent.Broker
Hand in the object to share.
handleCheckpointRequest(HandlerRequest<EmptyRequestBody, M>, AbstractCheckpointStats) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.AbstractCheckpointHandler
Called for each request with the corresponding AbstractCheckpointStats instance.
handleCheckpointRequest(HandlerRequest<EmptyRequestBody, CheckpointMessageParameters>, AbstractCheckpointStats) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointStatisticDetailsHandler
 
handleCheckpointRequest(HandlerRequest<EmptyRequestBody, TaskCheckpointMessageParameters>, AbstractCheckpointStats) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.TaskCheckpointStatisticDetailsHandler
 
handleCustomMessage(Object) - Method in class org.apache.flink.runtime.client.JobAttachmentClientActor
 
handleCustomMessage(Object) - Method in class org.apache.flink.runtime.client.JobClientActor
Hook to handle custom client message which are not handled by the base class.
handleCustomMessage(Object) - Method in class org.apache.flink.runtime.client.JobSubmissionClientActor
 
handleError(Exception) - Method in class org.apache.flink.runtime.client.JobClientActor
 
handleError(Exception) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
Handles error occurring in the leader election service.
handleError(Exception) - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
 
handleError(Exception) - Method in interface org.apache.flink.runtime.leaderelection.LeaderContender
Callback method which is called by LeaderElectionService in 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 LeaderRetrievalService in case of an exception.
handleError(Exception) - Method in class org.apache.flink.runtime.minicluster.OneTimeLeaderListenerFuture
 
handleError(Exception) - Method in class org.apache.flink.runtime.net.ConnectionUtils.LeaderConnectingAddressListener
 
handleError(Throwable) - Method in interface org.apache.flink.runtime.resourcemanager.JobLeaderIdActions
Callback to report occurring errors.
handleError(Exception) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
Handles error occurring in the leader election service.
handleError(Throwable) - Method in interface org.apache.flink.runtime.taskexecutor.JobLeaderListener
Callback for errors which might occur in the JobLeaderService.
handleError(Exception) - Method in class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderConnectionInfoListener
 
handleError(Exception) - Method in class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderGatewayListener
 
handleError(Exception) - Method in class org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
 
handleError(Exception) - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
 
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).
handleException(E) - Method in interface org.apache.flink.runtime.operators.sort.ExceptionHandler
This method is called when the handler should deal with an exception.
handleJsonRequest(Map<String, String>, Map<String, String>, JobManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.legacy.AbstractExecutionGraphRequestHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, JobManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.legacy.AbstractJsonRequestHandler
Core method that handles the request and generates the response.
handleJsonRequest(Map<String, String>, Map<String, String>, JobManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsDetailsSubtasksHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, JobManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.legacy.ClusterConfigHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, JobManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.legacy.ClusterOverviewHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, JobManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.legacy.CurrentJobIdsHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, JobManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.legacy.DashboardConfigHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, JobManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobCancellationHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, JobManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobsOverviewHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, JobManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobStoppingHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, JobManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.AbstractMetricsHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, JobManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.legacy.TaskManagersHandler
 
handleMessage(Object) - Method in class org.apache.flink.runtime.akka.FlinkUntypedActor
This method contains the actor logic which defines how to react to incoming messages.
handleMessage(Object) - Method in class org.apache.flink.runtime.client.JobClientActor
 
handleMessage(Object) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
This method receives the actor messages after they have been filtered for a match with the leader session.
handleMessage(Object) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
handleProcessedBuffer(T, IOException) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
Handles a processed Buffer.
handleRequest(HandlerRequest<R, M>, T) - Method in class org.apache.flink.runtime.rest.handler.AbstractRestHandler
This method is called for every incoming request and returns a CompletableFuture containing a the response.
handleRequest(HandlerRequest<EmptyRequestBody, M>, T) - Method in class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.StatusHandler
 
handleRequest(HandlerRequest<B, M>, T) - Method in class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.TriggerHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, EmptyMessageParameters>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.cluster.ClusterConfigHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, EmptyMessageParameters>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.cluster.ClusterOverviewHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, EmptyMessageParameters>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.cluster.DashboardConfigHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, EmptyMessageParameters>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.cluster.ShutdownHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, M>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.AbstractExecutionGraphHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, M>, AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.AbstractExecutionGraphHandler
Called for each request after the corresponding AccessExecutionGraph has been retrieved from the ExecutionGraphCache.
handleRequest(HandlerRequest<EmptyRequestBody, M>, AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.AbstractJobVertexHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, M>, AccessExecutionJobVertex) - Method in class org.apache.flink.runtime.rest.handler.job.AbstractJobVertexHandler
Called for each request after the corresponding AccessExecutionJobVertex has been retrieved from the AccessExecutionGraph.
handleRequest(HandlerRequest<EmptyRequestBody, M>, AccessExecutionVertex) - Method in class org.apache.flink.runtime.rest.handler.job.AbstractSubtaskAttemptHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, M>, AccessExecution) - Method in class org.apache.flink.runtime.rest.handler.job.AbstractSubtaskAttemptHandler
Called for each request after the corresponding AccessExecution has been retrieved from the AccessExecutionVertex.
handleRequest(HandlerRequest<EmptyRequestBody, M>, AccessExecutionJobVertex) - Method in class org.apache.flink.runtime.rest.handler.job.AbstractSubtaskHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, M>, AccessExecutionVertex) - Method in class org.apache.flink.runtime.rest.handler.job.AbstractSubtaskHandler
Called for each request after the corresponding AccessExecutionVertex has been retrieved from the AccessExecutionJobVertex.
handleRequest(HandlerRequest<EmptyRequestBody, M>, AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.AbstractCheckpointHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobMessageParameters>, AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointConfigHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobMessageParameters>, AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointingStatisticsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobAccumulatorsMessageParameters>, AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobAccumulatorsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobMessageParameters>, AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobConfigHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobMessageParameters>, AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobDetailsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobMessageParameters>, AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobExceptionsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobMessageParameters>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.JobExecutionResultHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, EmptyMessageParameters>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.JobIdsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobMessageParameters>, AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobPlanHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, EmptyMessageParameters>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.JobsOverviewHandler
 
handleRequest(HandlerRequest<JobSubmitRequestBody, EmptyMessageParameters>, DispatcherGateway) - Method in class org.apache.flink.runtime.rest.handler.job.JobSubmitHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobTerminationMessageParameters>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.JobTerminationHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobVertexMessageParameters>, AccessExecutionJobVertex) - Method in class org.apache.flink.runtime.rest.handler.job.JobVertexAccumulatorsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobVertexMessageParameters>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.JobVertexBackPressureHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobVertexMessageParameters>, AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobVertexDetailsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobVertexMessageParameters>, AccessExecutionGraph) - Method in class org.apache.flink.runtime.rest.handler.job.JobVertexTaskManagersHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, P>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.AbstractAggregatingMetricsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, M>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.AbstractMetricsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, SubtaskMessageParameters>, AccessExecutionVertex) - Method in class org.apache.flink.runtime.rest.handler.job.SubtaskCurrentAttemptDetailsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, SubtaskAttemptMessageParameters>, AccessExecution) - Method in class org.apache.flink.runtime.rest.handler.job.SubtaskExecutionAttemptAccumulatorsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, SubtaskAttemptMessageParameters>, AccessExecution) - Method in class org.apache.flink.runtime.rest.handler.job.SubtaskExecutionAttemptDetailsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobVertexMessageParameters>, AccessExecutionJobVertex) - Method in class org.apache.flink.runtime.rest.handler.job.SubtasksAllAccumulatorsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, JobVertexMessageParameters>, AccessExecutionJobVertex) - Method in class org.apache.flink.runtime.rest.handler.job.SubtasksTimesHandler
 
handleRequest(AccessExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.AbstractExecutionGraphRequestHandler
 
handleRequest(AccessExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.AbstractJobVertexRequestHandler
 
handleRequest(AccessExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.AbstractJobVertexRequestHandler
 
handleRequest(Map<String, String>, Map<String, String>, JobManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.legacy.AbstractJsonRequestHandler
 
handleRequest(AccessExecutionVertex, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.AbstractSubtaskAttemptRequestHandler
 
handleRequest(AccessExecution, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.AbstractSubtaskAttemptRequestHandler
 
handleRequest(AccessExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.AbstractSubtaskRequestHandler
 
handleRequest(AccessExecutionVertex, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.AbstractSubtaskRequestHandler
 
handleRequest(AccessExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointConfigHandler
 
handleRequest(AccessExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsDetailsHandler
 
handleRequest(AccessExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsDetailsSubtasksHandler
 
handleRequest(AccessExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.checkpoints.CheckpointStatsHandler
 
handleRequest(AccessExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobAccumulatorsHandler
 
handleRequest(AccessExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobConfigHandler
 
handleRequest(AccessExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobDetailsHandler
 
handleRequest(AccessExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobExceptionsHandler
 
handleRequest(AccessExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobPlanHandler
 
handleRequest(AccessExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexAccumulatorsHandler
 
handleRequest(AccessExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexBackPressureHandler
 
handleRequest(AccessExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexDetailsHandler
 
handleRequest(AccessExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.JobVertexTaskManagersHandler
 
handleRequest(Map<String, String>, Map<String, String>, JobManagerGateway) - Method in interface org.apache.flink.runtime.rest.handler.legacy.RequestHandler
Core method that handles the request and generates the response.
handleRequest(AccessExecutionVertex, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtaskCurrentAttemptDetailsHandler
 
handleRequest(AccessExecution, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptAccumulatorsHandler
 
handleRequest(AccessExecution, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptDetailsHandler
 
handleRequest(AccessExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtasksAllAccumulatorsHandler
 
handleRequest(AccessExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.rest.handler.legacy.SubtasksTimesHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, M>, T) - Method in interface org.apache.flink.runtime.rest.handler.LegacyRestHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, M>, T) - Method in class org.apache.flink.runtime.rest.handler.LegacyRestHandlerAdapter
 
handleRequest(HandlerRequest<EmptyRequestBody, TaskManagerMessageParameters>, ResourceManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerDetailsHandler
 
handleRequest(HandlerRequest<EmptyRequestBody, EmptyMessageParameters>, ResourceManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagersHandler
 
handleRpcMessage(Object) - Method in class org.apache.flink.runtime.rpc.akka.FencedAkkaRpcActor
 
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,M extends MessageParameters> - Class in org.apache.flink.runtime.rest.handler
Simple container for the request to a handler, that contains the RequestBody and path/query parameters.
HandlerRequest(R, M) - Constructor for class org.apache.flink.runtime.rest.handler.HandlerRequest
 
HandlerRequest(R, M, Map<String, String>, Map<String, List<String>>) - Constructor for class org.apache.flink.runtime.rest.handler.HandlerRequest
 
HandlerRequest(R, M, Map<String, String>, Map<String, List<String>>, Collection<File>) - Constructor for class org.apache.flink.runtime.rest.handler.HandlerRequest
 
HandlerRequestException - Exception in org.apache.flink.runtime.rest.handler
Base class for all HandlerRequest related exceptions.
HandlerRequestException(String) - Constructor for exception org.apache.flink.runtime.rest.handler.HandlerRequestException
 
HandlerRequestException(Throwable) - Constructor for exception org.apache.flink.runtime.rest.handler.HandlerRequestException
 
HandlerRequestException(String, 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
 
handleStateChange(ConnectionState) - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
handleStateChange(ConnectionState) - Method in class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
 
HandshakeException - Exception in org.apache.flink.runtime.rpc.exceptions
Exception which signals a handshake failure.
HandshakeException(String) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.HandshakeException
 
HandshakeException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.HandshakeException
 
HandshakeException(Throwable) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.HandshakeException
 
HandshakeSuccessMessage - Enum in org.apache.flink.runtime.rpc.messages
Handshake success response.
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.
hasAllocatedSlots(JobID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Check whether the job has allocated (not active) slots.
hasArray() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
hasBackPressure() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
 
hasBroadcastVariable(String) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
 
hasChildren() - Method in class org.apache.flink.runtime.instance.SharedSlot
Checks whether this shared slot has any sub slots.
hasClassLoader(JobID) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
hasClassLoader(JobID) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
True if the LibraryCacheManager has a user code class loader registered for the given job id.
hasData() - Method in class org.apache.flink.runtime.operators.sort.LargeRecordHandler
 
hasDefaultSavepointLocation() - Method in interface org.apache.flink.runtime.state.CheckpointStorage
Checks whether the storage has a default savepoint location configured.
hasDefaultSavepointLocation() - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
 
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.
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.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.OperatorState
 
hashCode() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
 
hashCode() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
 
hashCode() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
 
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.messages.CheckAndAllocateContainers
 
hashCode() - Method in class org.apache.flink.runtime.clusterframework.messages.GetClusterStatus
 
hashCode() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListener
 
hashCode() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListenerSuccessful
 
hashCode() - Method in class org.apache.flink.runtime.clusterframework.messages.SetWorkerPoolSize
 
hashCode() - Method in class org.apache.flink.runtime.clusterframework.messages.UnRegisterInfoMessageListener
 
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.instance.HardwareDescription
 
hashCode() - Method in class org.apache.flink.runtime.instance.Slot
Slots must always has based on reference identity.
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.EndOfPartitionEvent
 
hashCode() - Method in class org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
 
hashCode() - Method in class org.apache.flink.runtime.io.network.ConnectionID
 
hashCode() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionID
 
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 exception org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
 
hashCode() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
hashCode() - Method in class org.apache.flink.runtime.jobmaster.ResourceManagerAddress
 
hashCode() - Method in class org.apache.flink.runtime.leaderelection.LeaderAddressAndId
 
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.checkpoint.NotifyCheckpointComplete
 
hashCode() - Method in class org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
 
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.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.query.KvStateInfo
 
hashCode() - Method in class org.apache.flink.runtime.query.KvStateLocation
 
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.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.MinMaxAvgStatistics
 
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.ClusterConfigurationInfoEntry
 
hashCode() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
 
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.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.JobExceptionsInfo.ExecutionExceptionInfo
 
hashCode() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsInfo
 
hashCode() - Method in class org.apache.flink.runtime.rest.messages.JobPlanInfo
 
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.JobVertexDetailsInfo.VertexTaskDetail
 
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.SubtasksTimesInfo
 
hashCode() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
 
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.state.ArrayListSerializer
 
hashCode() - Method in class org.apache.flink.runtime.state.ChainedStateHandle
 
hashCode() - Method in class org.apache.flink.runtime.state.CheckpointStorageLocationReference
 
hashCode() - Method in class org.apache.flink.runtime.state.DirectoryKeyedStateHandle
 
hashCode() - Method in class org.apache.flink.runtime.state.DirectoryStateHandle
 
hashCode() - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
 
hashCode() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
This method should only be called in tests! This should never serve as key in a hash map.
hashCode() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
 
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.RegisteredBroadcastBackendStateMetaInfo
 
hashCode() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo.Snapshot
 
hashCode() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
 
hashCode() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo.Snapshot
 
hashCode() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo
 
hashCode() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo.Snapshot
 
hashCode() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
 
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.SlotOffer
 
hashCode() - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
 
hashCode() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
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.OperatorSubtaskDescriptionText
 
hashCode() - Method in class org.apache.flink.runtime.webmonitor.history.ArchivedJson
 
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
 
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
Iterator over the build side entries of a HashPartition.
HashPartitionIterator(Iterator<HashPartition<BT, PT>>, TypeSerializer<BT>) - Constructor for class org.apache.flink.runtime.iterative.io.HashPartitionIterator
 
HashTableProber(TypeComparator<PT>, TypePairComparator<PT, T>) - Constructor for class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
 
hasLeadership(UUID) - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
 
hasLeadership(UUID) - Method in interface org.apache.flink.runtime.leaderelection.LeaderElectionService
Returns true if the LeaderContender with which the service has been started owns currently the leadership under the given leader session id.
hasLeadership(UUID) - Method in class org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
 
hasLeadership(UUID) - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
hasMemoryAddress() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
hasNewNetworkBufConf(Configuration) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
Returns whether the new network buffer memory configuration is present in the configuration object, i.e.
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 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
 
hasNoConnectedInputs() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
hasQuarantined(String, ActorSystem) - Method in class org.apache.flink.runtime.akka.DefaultQuarantineHandler
 
hasQuarantined(String, ActorSystem) - Method in interface org.apache.flink.runtime.akka.QuarantineHandler
Callback when the given actor system has quarantined the given remote actor system.
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
 
hasResourcesAvailable() - Method in class org.apache.flink.runtime.instance.Instance
 
hasSerializedData() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
 
hasSerializedData() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
 
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 OperatorSubtaskState in subtaskStatesByOperatorID has state.
hasStubWrapper() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
hasUnfinishedData() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
 
hasUnfinishedData() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
 
hasUsercodeJarFiles() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Checks whether the JobGraph has user code JAR files attached.
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
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.disk.iomanager.ChannelWriterOutputView
The length of the header put into the blocks.
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 DataInputView that is backed by a BlockChannelReader, 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.
HeapAggregatingState<K,N,IN,ACC,OUT> - Class in org.apache.flink.runtime.state.heap
Heap-backed partitioned AggregatingState that is snapshotted into files.
HeapAggregatingState(StateTable<K, N, ACC>, TypeSerializer<K>, TypeSerializer<ACC>, TypeSerializer<N>, ACC, AggregateFunction<IN, ACC, OUT>) - Constructor for class org.apache.flink.runtime.state.heap.HeapAggregatingState
Creates a new key/value state for the given hash map of key/value pairs.
HeapBroadcastState<K,V> - Class in org.apache.flink.runtime.state
A Broadcast State backed a heap-based Map.
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
 
HeapFoldingState<K,N,T,ACC> - Class in org.apache.flink.runtime.state.heap
Deprecated.
will be removed in a future version
HeapFoldingState(StateTable<K, N, ACC>, TypeSerializer<K>, TypeSerializer<ACC>, TypeSerializer<N>, ACC, FoldFunction<T, ACC>) - Constructor for class org.apache.flink.runtime.state.heap.HeapFoldingState
Deprecated.
Creates a new key/value state for the given hash map of key/value pairs.
HeapKeyedStateBackend<K> - Class in org.apache.flink.runtime.state.heap
A AbstractKeyedStateBackend that keeps state on the Java Heap and will serialize state to streams provided by a CheckpointStreamFactory upon checkpointing.
HeapKeyedStateBackend(TaskKvStateRegistry, TypeSerializer<K>, ClassLoader, int, KeyGroupRange, boolean, ExecutionConfig, LocalRecoveryConfig) - Constructor for class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
HeapListState<K,N,V> - Class in org.apache.flink.runtime.state.heap
Heap-backed partitioned ListState that is snapshotted into files.
HeapListState(StateTable<K, N, List<V>>, TypeSerializer<K>, TypeSerializer<List<V>>, TypeSerializer<N>, List<V>) - Constructor for class org.apache.flink.runtime.state.heap.HeapListState
Creates a new key/value state for the given hash map of key/value pairs.
HeapMapState<K,N,UK,UV> - Class in org.apache.flink.runtime.state.heap
Heap-backed partitioned MapState that is snapshotted into files.
HeapMapState(StateTable<K, N, Map<UK, UV>>, TypeSerializer<K>, TypeSerializer<Map<UK, UV>>, TypeSerializer<N>, Map<UK, UV>) - Constructor for class org.apache.flink.runtime.state.heap.HeapMapState
Creates a new key/value state for the given hash map of key/value pairs.
HeapReducingState<K,N,V> - Class in org.apache.flink.runtime.state.heap
Heap-backed partitioned ReducingState that is snapshotted into files.
HeapReducingState(StateTable<K, N, V>, TypeSerializer<K>, TypeSerializer<V>, TypeSerializer<N>, V, ReduceFunction<V>) - Constructor for class org.apache.flink.runtime.state.heap.HeapReducingState
Creates a new key/value state for the given hash map of key/value pairs.
HeapSort - Class in org.apache.flink.runtime.operators.sort
 
HeapSort() - Constructor for class org.apache.flink.runtime.operators.sort.HeapSort
 
HeapValueState<K,N,V> - Class in org.apache.flink.runtime.state.heap
Heap-backed partitioned ValueState that is snapshotted into files.
HeapValueState(StateTable<K, N, V>, TypeSerializer<K>, TypeSerializer<V>, TypeSerializer<N>, V) - Constructor for class org.apache.flink.runtime.state.heap.HeapValueState
Creates a new key/value state for the given hash map of key/value pairs.
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) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
heartbeatFromJobManager(ResourceID) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Heartbeat request from the job manager.
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.
heartbeatFromTaskManager(ResourceID, AccumulatorReport) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
heartbeatFromTaskManager(ResourceID, AccumulatorReport) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Sends the heartbeat to job manager from task manager.
heartbeatFromTaskManager(ResourceID, SlotReport) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
heartbeatFromTaskManager(ResourceID, SlotReport) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Sends the heartbeat to resource manager from task manager
heartbeatInterval - Variable in class org.apache.flink.runtime.heartbeat.HeartbeatServices
Heartbeat interval for the created services.
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.
HeartbeatManagerImpl<I,O> - Class in org.apache.flink.runtime.heartbeat
Heartbeat manager implementation.
HeartbeatManagerImpl(long, ResourceID, HeartbeatListener<I, O>, Executor, ScheduledExecutor, Logger) - Constructor for class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
 
HeartbeatManagerSenderImpl<I,O> - Class in org.apache.flink.runtime.heartbeat
HeartbeatManager implementation which regularly requests a heartbeat response from its monitored HeartbeatTarget.
HeartbeatManagerSenderImpl(long, long, ResourceID, HeartbeatListener<I, O>, Executor, ScheduledExecutor, Logger) - Constructor for class org.apache.flink.runtime.heartbeat.HeartbeatManagerSenderImpl
 
HeartbeatServices - Class in org.apache.flink.runtime.heartbeat
HeartbeatServices gives access to all services needed for heartbeating.
HeartbeatServices(long, long) - Constructor for class org.apache.flink.runtime.heartbeat.HeartbeatServices
 
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.
heartbeatTimeout - Variable in class org.apache.flink.runtime.heartbeat.HeartbeatServices
Heartbeat timeout for the created services.
hierarchy() - Method in class org.apache.flink.runtime.instance.Slot
 
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.
HighAvailabilityServicesUtils - Class in org.apache.flink.runtime.highavailability
Utils class to instantiate HighAvailabilityServices implementations.
HighAvailabilityServicesUtils() - Constructor for class org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
 
HighAvailabilityServicesUtils.AddressResolution - Enum in org.apache.flink.runtime.highavailability
 
histogram(int, H) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
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
 
histogram(int, 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 AccessExecutionGraph.
hostname() - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
hostname() - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
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.
HttpMethodWrapper - Enum in org.apache.flink.runtime.rest
This class wraps netty's HttpMethods into an enum, allowing us to use them in switches.

I

id - Variable in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
The ID of the underlying channel.
ID(File, int) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
 
ID(File, int, Random) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
 
IllegalExecutionStateException - Exception in org.apache.flink.runtime.executiongraph
A special IllegalStateException indicating a mismatch in the expected and actual ExecutionState of an Execution.
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.
immutableEntries() - Method in class org.apache.flink.runtime.state.HeapBroadcastState
 
includeAlternativeOperatorIDs(Map<OperatorID, ExecutionJobVertex>) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
includeLegacyJobVertexIDs(Map<JobVertexID, ExecutionJobVertex>) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
includeSerializedAccumulatorsParameter - Variable in class org.apache.flink.runtime.rest.messages.JobAccumulatorsMessageParameters
 
increaseBackoff() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
Increases the current backoff and returns whether the operation was successful.
increaseBuffersInBacklog(BufferConsumer) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
Increases the number of non-event buffers by one after adding a non-event buffer into this subpartition.
increment() - Method in class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
Increments the reference count and returns whether it was successful.
IncrementalKeyedStateHandle - Class in org.apache.flink.runtime.state
The handle to states of an incremental snapshot.
IncrementalKeyedStateHandle(UUID, KeyGroupRange, long, Map<StateHandleID, StreamStateHandle>, Map<StateHandleID, StreamStateHandle>, StreamStateHandle) - Constructor for class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
 
IncrementalLocalKeyedStateHandle - Class in org.apache.flink.runtime.state
State handle for local copies of IncrementalKeyedStateHandle.
IncrementalLocalKeyedStateHandle(UUID, long, DirectoryStateHandle, KeyGroupRange, StreamStateHandle, Set<StateHandleID>) - Constructor for class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
 
incrementIterationCounter() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
index - Variable in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
The index of the subpartition at the parent partition.
IndexedSortable - Interface in org.apache.flink.runtime.operators.sort
 
IndexedSorter - Interface in org.apache.flink.runtime.operators.sort
 
INDIVIDUAL_RESTART_STRATEGY_NAME - Static variable in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategyLoader
Config name for the RestartIndividualStrategy
INF_TIMEOUT - Static variable in class org.apache.flink.runtime.rpc.RpcUtils
HACK: Set to 21474835 seconds, Akka's maximum delay (Akka 2.4.20).
inFirstIteration() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
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_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 - Class in org.apache.flink.runtime.clusterframework.messages
A simple informational message sent by the resource master to the client.
InfoMessage(String) - Constructor for class org.apache.flink.runtime.clusterframework.messages.InfoMessage
 
InfoMessage(String, Date) - Constructor for class org.apache.flink.runtime.clusterframework.messages.InfoMessage
 
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.
InfoMessageListenerRpcGateway - Interface in org.apache.flink.runtime.resourcemanager
A gateway to listen for info messages from ResourceManager
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.
InitializationTypeConflictException - Exception in org.apache.flink.runtime.broadcast
Indicates that a broadcast variable was initialized with a DefaultBroadcastVariableInitializer as a non-List type, and later accessed using RuntimeContext.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.clusterframework.FlinkResourceManager
Initializes the framework specific components.
initialize() - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
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.ResourceManager
Initializes the framework specific components.
initialize() - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
 
initializeBroadcastVariable(Iterable<T>) - Method in class org.apache.flink.runtime.broadcast.DefaultBroadcastVariableInitializer
 
initializeBufferMetrics(Task) - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
Initialize Buffer Metrics for a task.
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
 
initializeLocationForCheckpoint(long) - Method in interface org.apache.flink.runtime.state.CheckpointStorage
Initializes a storage location for new checkpoint with the given ID.
initializeLocationForCheckpoint(long) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
 
initializeLocationForCheckpoint(long) - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
 
initializeLocationForSavepoint(long, String) - Method in interface org.apache.flink.runtime.state.CheckpointStorage
Initializes a storage location for new savepoint with the given ID.
initializeLocationForSavepoint(long, String) - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
Creates a file system based storage location for a savepoint.
initializeOnMaster(ClassLoader) - Method in class org.apache.flink.runtime.jobgraph.InputFormatVertex
 
initializeOnMaster(ClassLoader) - 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.
initializeOnMaster(ClassLoader) - Method in class org.apache.flink.runtime.jobgraph.OutputFormatVertex
 
initializeServices(Configuration) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
initialPartitionBuffersCount - Variable in class org.apache.flink.runtime.operators.hash.ReOpenableHashPartition
 
initInputReaders() - Method in class org.apache.flink.runtime.operators.BatchTask
Creates the record readers for the number of inputs as defined by BatchTask.getNumTaskInputs().
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, ClassLoader, 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.
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
 
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
 
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! (Even using getMatchFor of a prober!)
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.
inProgress() - Static method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationResult
 
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.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
 
InputChannel - Class in org.apache.flink.runtime.io.network.partition.consumer
An input channel consumes a single ResultSubpartitionView.
InputChannel(SingleInputGate, int, ResultPartitionID, int, int, 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 Buffer and a flag indicating availability of further buffers, and the backlog length indicating how many non-event buffers are available in the subpartition.
InputChannelDeploymentDescriptor - Class in org.apache.flink.runtime.deployment
Deployment descriptor for a single input channel instance.
InputChannelDeploymentDescriptor(ResultPartitionID, ResultPartitionLocation) - Constructor for class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
 
InputChannelID - Class in org.apache.flink.runtime.io.network.partition.consumer
 
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
 
inputComparators - Variable in class org.apache.flink.runtime.operators.BatchTask
The comparators for the central driver.
InputEndOfStreamException - Exception in org.apache.flink.runtime.checkpoint.decline
Exception indicating that a checkpoint was declined because one of the input stream reached its end before the alignment was complete.
InputEndOfStreamException() - Constructor for exception org.apache.flink.runtime.checkpoint.decline.InputEndOfStreamException
 
InputFormatVertex - Class in org.apache.flink.runtime.jobgraph
 
InputFormatVertex(String) - Constructor for class org.apache.flink.runtime.jobgraph.InputFormatVertex
 
InputFormatVertex(String, JobVertexID) - Constructor for class org.apache.flink.runtime.jobgraph.InputFormatVertex
 
InputFormatVertex(String, JobVertexID, List<JobVertexID>, List<OperatorID>, List<OperatorID>) - Constructor for class org.apache.flink.runtime.jobgraph.InputFormatVertex
 
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 - Interface in org.apache.flink.runtime.io.network.partition.consumer
An input gate consumes one or more partitions of a single produced intermediate result.
InputGateDeploymentDescriptor - Class in org.apache.flink.runtime.deployment
Deployment descriptor for a single input gate instance.
InputGateDeploymentDescriptor(IntermediateDataSetID, ResultPartitionType, int, InputChannelDeploymentDescriptor[]) - Constructor for class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
 
InputGateListener - Interface in org.apache.flink.runtime.io.network.partition.consumer
Listener interface implemented by consumers of InputGate instances that want to be notified of availability of buffer or event instances.
InputGateMetrics - Class in org.apache.flink.runtime.io.network.partition.consumer
Collects metrics of an input gate.
inputIterators - Variable in class org.apache.flink.runtime.operators.BatchTask
The inputs reader, wrapped in an iterator.
inputReaders - Variable in class org.apache.flink.runtime.operators.BatchTask
The input readers of this task.
inputs - Variable in class org.apache.flink.runtime.operators.BatchTask
The inputs to the operator.
inputSerializers - Variable in class org.apache.flink.runtime.operators.BatchTask
The serializers for the input data type.
InputSplitProvider - Interface in org.apache.flink.runtime.jobgraph.tasks
An input split provider can be successively queried to provide a series of InputSplit objects 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
 
InputViewIterator<E> - Class in org.apache.flink.runtime.io.disk
 
InputViewIterator(DataInputView, TypeSerializer<E>) - Constructor for class org.apache.flink.runtime.io.disk.InputViewIterator
 
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) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
instance() - Static method in class org.apache.flink.runtime.broadcast.DefaultBroadcastVariableInitializer
 
INSTANCE - Static variable in class org.apache.flink.runtime.checkpoint.RoundRobinOperatorStateRepartitioner
 
INSTANCE - Static variable in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
Instance - Class in org.apache.flink.runtime.instance
An instance represents a TaskManager registered at a JobManager and ready to receive work.
Instance(TaskManagerGateway, TaskManagerLocation, InstanceID, HardwareDescription, int) - Constructor for class org.apache.flink.runtime.instance.Instance
Constructs an instance reflecting a registered TaskManager.
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.EndOfSuperstepEvent
The singleton instance of this event.
INSTANCE - Static variable in class org.apache.flink.runtime.io.network.buffer.FreeingBufferRecycler
 
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 - Static variable in class org.apache.flink.runtime.iterative.event.TerminationEvent
 
INSTANCE - Static variable in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
 
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.util.FatalExitExceptionHandler
 
instanceDied(Instance) - Method in interface org.apache.flink.runtime.instance.InstanceListener
Called when an instance died.
instanceDied(Instance) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
InstanceDiedException - Exception in org.apache.flink.runtime.instance
A special instance signaling that an attempted operation on an instance is not possible, because the instance has died.
InstanceDiedException(Instance) - Constructor for exception org.apache.flink.runtime.instance.InstanceDiedException
 
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
 
InstanceListener - Interface in org.apache.flink.runtime.instance
Classes implementing the InstanceListener interface can be notified about the availability disappearance of instances.
InstanceManager - Class in org.apache.flink.runtime.instance
Simple manager that keeps track of which TaskManager are available and alive.
InstanceManager() - Constructor for class org.apache.flink.runtime.instance.InstanceManager
Creates an new instance manager.
instantiateJobManagerMetricGroup(MetricRegistry, String) - Static method in class org.apache.flink.runtime.metrics.util.MetricUtils
 
instantiateStatusMetrics(MetricGroup) - Static method in class org.apache.flink.runtime.metrics.util.MetricUtils
 
instantiateTaskManagerMetricGroup(MetricRegistry, TaskManagerLocation, NetworkEnvironment) - 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
 
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
 
IntermediateDataSetID() - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateDataSetID
Creates an new random intermediate data set ID.
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.
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.
IntermediateResult - Class in org.apache.flink.runtime.executiongraph
 
IntermediateResult(IntermediateDataSetID, ExecutionJobVertex, int, ResultPartitionType) - Constructor for class org.apache.flink.runtime.executiongraph.IntermediateResult
 
IntermediateResultPartition - Class in org.apache.flink.runtime.executiongraph
 
IntermediateResultPartition(IntermediateResult, ExecutionVertex, int) - Constructor for class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
 
IntermediateResultPartitionID - Class in org.apache.flink.runtime.jobgraph
 
IntermediateResultPartitionID() - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
Creates an new random intermediate result partition ID.
IntermediateResultPartitionID(long, long) - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
 
InternalAggregatingState<K,N,IN,SV,OUT> - Interface in org.apache.flink.runtime.state.internal
The peer to the AggregatingState in the internal state type hierarchy.
InternalAppendingState<K,N,IN,SV,OUT> - Interface in org.apache.flink.runtime.state.internal
The peer to the AppendingState in the internal state type hierarchy.
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
 
InternalFoldingState<K,N,T,ACC> - Interface in org.apache.flink.runtime.state.internal
Deprecated.
will be removed in a future version
internalHandleException(IOException) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
Internally handles an exception and makes sure that this method returns without a problem.
InternalKeyContext<K> - Interface in org.apache.flink.runtime.state.heap
This interface is the current context of a keyed state.
InternalKvState<K,N,V> - Interface in org.apache.flink.runtime.state.internal
The InternalKvState is the root of the internal state type hierarchy, similar to the State being the root of the public API state hierarchy.
InternalListState<K,N,T> - Interface in org.apache.flink.runtime.state.internal
The peer to the ListState in the internal state type hierarchy.
InternalMapState<K,N,UK,UV> - Interface in org.apache.flink.runtime.state.internal
The peer to the MapState in the internal state type hierarchy.
InternalMergingState<K,N,IN,SV,OUT> - Interface in org.apache.flink.runtime.state.internal
The peer to the MergingState in the internal state type hierarchy.
internalNioBuffer(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
InternalReducingState<K,N,T> - Interface in org.apache.flink.runtime.state.internal
The peer to the ReducingState in the internal state type hierarchy.
InternalValueState<K,N,T> - Interface in org.apache.flink.runtime.state.internal
The peer to the ValueState in the internal state type hierarchy.
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
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(Object, Method, Object[]) - Method in class org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
 
invokeRegistration(G, F, long) - Method in class org.apache.flink.runtime.registration.RetryingRegistration
 
IO_CURRENT_INPUT_1_WATERMARK - Static variable in class org.apache.flink.runtime.metrics.MetricNames
 
IO_CURRENT_INPUT_2_WATERMARK - Static variable in class org.apache.flink.runtime.metrics.MetricNames
 
IO_CURRENT_INPUT_WATERMARK - 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_NUM_BYTES_IN - Static variable in class org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BYTES_IN_LOCAL - Static variable in class org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BYTES_IN_LOCAL_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BYTES_IN_REMOTE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BYTES_IN_REMOTE_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
 
IOManager - Class in org.apache.flink.runtime.io.disk.iomanager
The facade for the provided I/O manager services.
IOManager(String[]) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.IOManager
Constructs a new IOManager.
ioManager - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The I/O manager used to instantiate writers for the spilled partitions.
ioManager - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
IOManager.IOMode - Enum in org.apache.flink.runtime.io.disk.iomanager
 
IOManagerAsync - Class in org.apache.flink.runtime.io.disk.iomanager
A version of the IOManager that uses asynchronous I/O.
IOManagerAsync() - Constructor for class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
Constructs a new asynchronous I/O manger, 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 manger, writing file to the given directory.
IOManagerAsync(String[]) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
Constructs a new asynchronous I/O manger, writing file round robin across the given directories.
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(Meter, Meter, Meter, Meter, Meter) - Constructor for class org.apache.flink.runtime.executiongraph.IOMetrics
 
IOMetrics(long, long, long, long, long, double, double, double, double, double) - 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) - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
 
ioMode() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
isAcknowledgedBy(ExecutionAttemptID) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
isActive(JobID, AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
isAlive() - Method in class org.apache.flink.runtime.instance.Instance
 
isAlive() - Method in class org.apache.flink.runtime.instance.Slot
Checks of the slot is still alive, i.e.
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
 
isAllocated(JobID, AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
isAllocated(int, JobID, AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Check whether the slot for the given index is allocated for the given job and allocation id.
isArchived() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns whether this execution graph was archived.
isArchived() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
isArchived() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
isAssigned() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Checks whether the location of this constraint has been assigned.
isAssigned() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
isAssignedAndAlive() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Deprecated.
Should only be called by legacy code (if using Scheduler)
isAvailable() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
Checks whether this reader is available or not.
isAvailable() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
 
isBasicType() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
 
isBlocking() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
 
isBounded() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
Whether this partition uses a limited number of (network) buffers or not.
isBuffer() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileSegment
 
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.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
 
isCalled() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
True once the async method was called.
isCanceled() - Method in class org.apache.flink.runtime.instance.Slot
Checks of the slot has been cancelled.
isCanceled() - Method in class org.apache.flink.runtime.registration.RetryingRegistration
Checks if the registration was canceled.
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.
isCancelJob() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerRequestBody
 
isCancelled() - Method in class org.apache.flink.runtime.state.DoneFuture
 
isClientConnected() - Method in class org.apache.flink.runtime.client.JobClientActor
 
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.metrics.groups.AbstractMetricGroup
 
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
 
isCompacted() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
 
isCompleted() - Method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
Returns whether the checkpoint has completed successfully.
isConnected() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
 
isConsumable() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
 
isConverged(int, LongValue) - Method in class org.apache.flink.runtime.iterative.convergence.WorksetEmptyConvergenceCriterion
 
isCreditBased() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
isCreditBasedEnabled() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
isDefaultReference() - Method in class org.apache.flink.runtime.state.CheckpointStorageLocationReference
Returns true, if this object is the default reference.
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.NetworkBufferPool
 
isDirect() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
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.PendingCheckpoint
 
isDiscarded() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.CompletedCheckpointStatistics
 
isDisposed() - Method in class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
Returns whether the reference count has reached the disposed state.
isDone() - Method in class org.apache.flink.runtime.state.DoneFuture
 
isEmpty() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
 
isEmpty() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
 
isEmpty() - Method in class org.apache.flink.runtime.jobmaster.SerializedInputSplit
 
isEmpty() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager
 
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.state.ChainedStateHandle
Check if there are any states handles present.
isEmpty() - Method in class org.apache.flink.runtime.state.heap.StateTable
Returns whether this NestedMapsStateTable is empty.
isEmpty() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
isEmpty() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
 
isEmpty() - Method in class org.apache.flink.runtime.util.IntArrayList
 
isEmpty() - Method in class org.apache.flink.runtime.util.LongArrayList
 
isEndOfSuperstep() - Method in class org.apache.flink.runtime.iterative.task.SyncEventHandler
 
isEvent(Buffer, Class<?>) - Static method in class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
Identifies whether the given buffer encodes the given event.
isEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
isExactlyOnce() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
 
isFailed() - Method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
Returns whether the checkpoint has failed.
isFailure() - Method in class org.apache.flink.runtime.checkpoint.CheckpointTriggerResult
 
isFinished() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
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 class org.apache.flink.runtime.io.network.buffer.BufferBuilder
 
isFinished() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
 
isFinished() - Method in interface 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
 
isFree() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
isFull() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
 
isFullBuffer() - Method in enum org.apache.flink.runtime.io.network.api.serialization.RecordSerializer.SerializationResult
Whether the target buffer is full after the serialization process.
isFullRecord() - Method in enum org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
 
isFullRecord() - Method in enum org.apache.flink.runtime.io.network.api.serialization.RecordSerializer.SerializationResult
Whether the full record was serialized and completely written to a target buffer.
isFullyAcknowledged() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
isGloballyTerminalState() - Method in enum org.apache.flink.runtime.jobgraph.JobStatus
Checks whether this state is globally terminal.
isHighAvailabilityModeActivated(Configuration) - Static method in enum org.apache.flink.runtime.jobmanager.HighAvailabilityMode
Returns true if the defined recovery mode supports high availability.
isIdle() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
isIdReference() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
 
isImmutableType() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
isImmutableType() - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
 
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
 
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
 
isInputVertex() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
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
 
isLeader() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
isLocal() - Method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
 
isLocalRecoveryEnabled() - Method in class org.apache.flink.runtime.state.LocalRecoveryConfig
 
isLocalRecoveryEnabled() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
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 class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
Check whether required resource profile can be matched 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
 
isMaxParallelismConfigured() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
isMoreAvailable() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition.BufferAndBacklog
 
isNetworkStrategy() - Method in enum org.apache.flink.runtime.operators.shipping.ShipStrategyType
 
isNullOrEmpty(ChainedStateHandle<?>) - Static method in class org.apache.flink.runtime.state.ChainedStateHandle
 
isNumBytesInLocalComplete() - Method in class org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
 
isNumBytesInRemoteComplete() - 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
 
isOutputVertex() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
isPeriodicCheckpointingConfigured() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Returns whether periodic checkpointing has been configured.
isPipelined() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
 
isPreAllocated() - Method in class org.apache.flink.runtime.memory.MemoryManager
Checks whether this memory manager pre-allocates the memory.
isPreAllocateMemory() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
isProperlyShutDown() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
Utility method to check whether the IO manager has been properly shut down.
isProperlyShutDown() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
Utility method to check whether the IO manager has been properly shut down.
isQueuedSchedulingAllowed() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
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
 
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.NetworkBuffer
 
isRecycled() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
isRegistered(InstanceID) - Method in class org.apache.flink.runtime.instance.InstanceManager
 
isRegistered(ResourceID) - Method in class org.apache.flink.runtime.instance.InstanceManager
 
isRegisteredAsAvailable() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
 
isReleased() - Method in class org.apache.flink.runtime.instance.Slot
Checks of the slot has been released.
isReleased() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
 
isReleased() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
isReleased() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
isReleased() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
 
isReleasing() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
isRemote() - Method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
 
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
 
isRootAndEmpty() - Method in class org.apache.flink.runtime.instance.SharedSlot
Checks whether this slot is a root slot that has not yet added any child slots.
isRunning() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
Checks if the mini cluster was started and is running.
isRunning() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
Checks whether this thread is still alive.
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.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
 
isSavepoint() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
 
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.AbstractNonHaServices
 
isShutdown() - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
 
isShutdown() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
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.
isSlotFree(int) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Check whether the task slot with the given index is free.
isSnapshotCompleted() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
Returns true if 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
 
isStarted(ResourceID) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Gets the started worker for a given resource ID, if one is available.
isStarted() - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
Checks whether the service has been started.
isStillAlive(long, long) - Method in class org.apache.flink.runtime.instance.Instance
Checks whether the last heartbeat occurred within the last n milliseconds before the given timestamp now.
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.ExecutionGraph
 
isStoppable() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
isStoppable() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
 
isStopped() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
Check if the IO operation is stopped
isStopped() - Method in interface org.apache.flink.runtime.io.async.AsyncStoppable
Check whether the operation is stopped
isSuccess() - Method in class org.apache.flink.runtime.checkpoint.CheckpointTriggerResult
 
isSuccess() - Method in class org.apache.flink.runtime.jobmaster.JobResult
Returns true if the job finished successfully.
isSynchronous() - Method in enum org.apache.flink.runtime.io.disk.iomanager.IOManager.IOMode
 
isTerminal() - Method in enum org.apache.flink.runtime.execution.ExecutionState
 
isTerminalState() - Method in enum org.apache.flink.runtime.jobgraph.JobStatus
Checks whether this state is locally terminal.
isTupleType() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
 
isUnknown() - Method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
 
isUsingAsynchronousSnapshots() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
Gets whether the key/value data structures are asynchronously snapshotted.
isUsingAsynchronousSnapshots() - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
Gets whether the key/value data structures are asynchronously snapshotted.
isUsingKeyGroupCompression() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
isValid(K, UUID) - Method in class 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).
isValidTimeout(JobID, UUID) - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
 
isValidTimeout(AllocationID, UUID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Check whether the timeout with ticket is valid for the given allocation id.
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.ZOOKEEPER is configured.
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 TaskEvent transmitting 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 Driver inside.
IterationHeadTask(Environment) - Constructor for class org.apache.flink.runtime.iterative.task.IterationHeadTask
Create an Invokable task and set its environment.
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 Driver inside.
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() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
 
iterator() - Method in class org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
 
iterator() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
iterator() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable
 
iterator() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
 
iterator - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The iterator to be returned by the sort-merger.
iterator() - Method in class org.apache.flink.runtime.operators.util.metrics.CountingIterable
 
iterator() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
iterator() - Method in class org.apache.flink.runtime.state.heap.HeapMapState
 
iterator() - Method in class org.apache.flink.runtime.state.HeapBroadcastState
 
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.taskexecutor.SlotReport
 
iterator() - Method in class org.apache.flink.runtime.util.EmptyIterator
 
iterator() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
 
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
 
iterator1 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
iterator2 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
iteratorException - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The exception that is set, if the iterator cannot be created.
iteratorLock - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The monitor which guards the iterator field.

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
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.
JarFileCreator - Class in org.apache.flink.runtime.util
This is an auxiliary program which creates a jar file from a set of classes.
JarFileCreator(File) - Constructor for class org.apache.flink.runtime.util.JarFileCreator
Constructs a new jar file creator.
jarFileNames - Variable in class org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody
 
JMTMRegistrationSuccess - Class in org.apache.flink.runtime.jobmaster
Message indicating a successful JobMaster and TaskExecutor registration.
JMTMRegistrationSuccess(ResourceID) - Constructor for class org.apache.flink.runtime.jobmaster.JMTMRegistrationSuccess
 
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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, JobAccumulatorsInfo, JobAccumulatorsMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobAccumulatorsHandler
 
JobAccumulatorsHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Request handler that returns the aggregated user accumulators of a job.
JobAccumulatorsHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.JobAccumulatorsHandler
 
JobAccumulatorsHandler.JobAccumulatorsJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy
Archivist for the 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.
JobAccumulatorsJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.JobAccumulatorsHandler.JobAccumulatorsJsonArchivist
 
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
 
JobAttachmentClientActor - Class in org.apache.flink.runtime.client
Actor which handles Job attachment process and provides Job updates until completion.
JobAttachmentClientActor(LeaderRetrievalService, FiniteDuration, boolean) - Constructor for class org.apache.flink.runtime.client.JobAttachmentClientActor
 
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
 
JobCancellationHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Request handler for the cancel request.
JobCancellationHandler(Executor, Time) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.JobCancellationHandler
 
JobCancellationWithSavepointHandlers - Class in org.apache.flink.runtime.rest.handler.legacy
Request handler for JobManagerMessages.CancelJobWithSavepoint messages.
JobCancellationWithSavepointHandlers(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.JobCancellationWithSavepointHandlers
 
JobCancellationWithSavepointHandlers(ExecutionGraphCache, Executor, String) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.JobCancellationWithSavepointHandlers
 
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, and which vertices need to participate.
JobCheckpointingSettings(List<JobVertexID>, List<JobVertexID>, List<JobVertexID>, CheckpointCoordinatorConfiguration, SerializedValue<StateBackend>) - Constructor for class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
JobCheckpointingSettings(List<JobVertexID>, List<JobVertexID>, List<JobVertexID>, CheckpointCoordinatorConfiguration, SerializedValue<StateBackend>, SerializedValue<MasterTriggerRestoreHook.Factory[]>) - Constructor for class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
JobClient - Class in org.apache.flink.runtime.client
The JobClient bridges between the JobManager's asynchronous actor messages and the synchronous method calls to trigger.
JobClient() - Constructor for class org.apache.flink.runtime.client.JobClient
 
JobClientActor - Class in org.apache.flink.runtime.client
Actor which constitutes the bridge between the non-actor code and the JobManager.
JobClientActor(LeaderRetrievalService, FiniteDuration, boolean) - Constructor for class org.apache.flink.runtime.client.JobClientActor
 
JobClientActorConnectionTimeoutException - Exception in org.apache.flink.runtime.client
Exception which is thrown when the JobClientActor wants to submit a job to the job manager but has not found one after a given timeout interval.
JobClientActorConnectionTimeoutException(String) - Constructor for exception org.apache.flink.runtime.client.JobClientActorConnectionTimeoutException
 
JobClientActorConnectionTimeoutException(String, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobClientActorConnectionTimeoutException
 
JobClientActorRegistrationTimeoutException - Exception in org.apache.flink.runtime.client
Exception which is thrown by the JobClientActor if it has not heard back from the job manager after it has attempted to register for a job within a given timeout interval.
JobClientActorRegistrationTimeoutException(String) - Constructor for exception org.apache.flink.runtime.client.JobClientActorRegistrationTimeoutException
 
JobClientActorRegistrationTimeoutException(String, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobClientActorRegistrationTimeoutException
 
JobClientActorSubmissionTimeoutException - Exception in org.apache.flink.runtime.client
Exception which is thrown by the JobClientActor if it has not heard back from the job manager after it has submitted a job to it within a given timeout interval.
JobClientActorSubmissionTimeoutException(String) - Constructor for exception org.apache.flink.runtime.client.JobClientActorSubmissionTimeoutException
 
JobClientActorSubmissionTimeoutException(String, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobClientActorSubmissionTimeoutException
 
JobClusterEntrypoint - Class in org.apache.flink.runtime.entrypoint
Base class for per-job cluster entry points.
JobClusterEntrypoint(Configuration) - Constructor for class org.apache.flink.runtime.entrypoint.JobClusterEntrypoint
 
JobConfigHandler - Class in org.apache.flink.runtime.rest.handler.job
Handler serving the job configuration.
JobConfigHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, JobConfigInfo, JobMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobConfigHandler
 
JobConfigHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Request handler that returns the execution config of a job.
JobConfigHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.JobConfigHandler
 
JobConfigHandler.JobConfigJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy
Archivist for the 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.
JobConfigJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.JobConfigHandler.JobConfigJsonArchivist
 
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.JobDetailsDeserializer - Class in org.apache.flink.runtime.messages.webmonitor
 
JobDetails.JobDetailsSerializer - Class in org.apache.flink.runtime.messages.webmonitor
 
JobDetailsDeserializer() - Constructor for class org.apache.flink.runtime.messages.webmonitor.JobDetails.JobDetailsDeserializer
 
JobDetailsHandler - Class in org.apache.flink.runtime.rest.handler.job
Handler returning the details for the specified job.
JobDetailsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, JobDetailsInfo, JobMessageParameters>, ExecutionGraphCache, Executor, MetricFetcher<?>) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobDetailsHandler
 
JobDetailsHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Request handler that returns details about a job.
JobDetailsHandler(ExecutionGraphCache, Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.JobDetailsHandler
 
JobDetailsHandler.JobDetailsJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy
Archivist for the 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, long, long, long, long, Map<JobStatus, Long>, Collection<JobDetailsInfo.JobVertexDetailsInfo>, Map<ExecutionState, Integer>, String) - 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.
JobDetailsJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.JobDetailsHandler.JobDetailsJsonArchivist
 
JobDetailsSerializer() - Constructor for class org.apache.flink.runtime.messages.webmonitor.JobDetails.JobDetailsSerializer
 
JobEdge - Class in org.apache.flink.runtime.jobgraph
This class represent edges (communication channels) in a job graph.
JobEdge(IntermediateDataSet, JobVertex, DistributionPattern) - Constructor for class org.apache.flink.runtime.jobgraph.JobEdge
Constructs a new job edge, that connects an intermediate result to a consumer task.
JobEdge(IntermediateDataSetID, JobVertex, DistributionPattern) - Constructor for class org.apache.flink.runtime.jobgraph.JobEdge
Constructs a new job edge that refers to an intermediate result via the Id, rather than directly through the intermediate data set structure.
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
 
JobExceptionsHandler - Class in org.apache.flink.runtime.rest.handler.job
Handler serving the job exceptions.
JobExceptionsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, JobExceptionsInfo, JobMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobExceptionsHandler
 
JobExceptionsHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Request handler that returns the configuration of a job.
JobExceptionsHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.JobExceptionsHandler
 
JobExceptionsHandler.JobExceptionsJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy
Archivist for the JobExceptionsHandler.
JobExceptionsHeaders - Class in org.apache.flink.runtime.rest.messages
Message headers for the JobExceptionsHandler.
JobExceptionsInfo - Class in org.apache.flink.runtime.rest.messages
Response type of the JobExceptionsHandler.
JobExceptionsInfo(String, Long, List<JobExceptionsInfo.ExecutionExceptionInfo>, boolean) - Constructor for class org.apache.flink.runtime.rest.messages.JobExceptionsInfo
 
JobExceptionsInfo.ExecutionExceptionInfo - Class in org.apache.flink.runtime.rest.messages
Nested class to encapsulate the task execution exception.
JobExceptionsJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.JobExceptionsHandler.JobExceptionsJsonArchivist
 
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, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobExecutionException
Constructs a new job execution exception.
JobExecutionException(JobID, String) - Constructor for exception org.apache.flink.runtime.client.JobExecutionException
 
JobExecutionException(JobID, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobExecutionException
 
JobExecutionResultHandler - Class in org.apache.flink.runtime.rest.handler.job
Returns the JobExecutionResult for a given JobID.
JobExecutionResultHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, 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
ResponseBody that carries a QueueStatus and a JobResult.
JobExecutionResultResponseBody(QueueStatus, JobResult) - Constructor for class org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
 
JobExecutor - Interface in org.apache.flink.runtime.minicluster
Interface for JobGraph executors.
JobExecutorService - Interface in org.apache.flink.runtime.minicluster
Interface to control JobExecutor.
jobFinishedByOther() - Method in interface org.apache.flink.runtime.jobmanager.OnCompletionActions
Job was finished by another JobMaster.
jobFinishedByOther() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
Job completion notification triggered by self.
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 null is passed), the given name and the given execution configuration (see ExecutionConfig).
JobGraph(JobVertex...) - Constructor for class org.apache.flink.runtime.jobgraph.JobGraph
Constructs a new job graph with no name, a random job ID, the given ExecutionConfig, and the given job vertices.
JobGraph(String, JobVertex...) - Constructor for class org.apache.flink.runtime.jobgraph.JobGraph
Constructs a new job graph with the given name, the given ExecutionConfig, a random job ID, and the given job vertices.
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.
jobGraphFileName - Variable in class org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody
 
jobID - Variable in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
 
jobId() - Method in class org.apache.flink.runtime.clusterframework.messages.ShutdownClusterAfterJob
 
jobId(JobID) - Method in class org.apache.flink.runtime.jobmaster.JobResult.Builder
 
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.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 - Variable in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerMessageParameters
 
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
 
jobIdfromPath(String) - Static method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
Returns the JobID from the given path in ZooKeeper.
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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, 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
 
JobIdWithStatus(JobID, JobStatus) - Constructor for class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview.JobIdWithStatus
 
JobInformation - Class in org.apache.flink.runtime.executiongraph
Container class for job information which is stored in the ExecutionGraph.
JobInformation(JobID, String, SerializedValue<ExecutionConfig>, Configuration, Collection<PermanentBlobKey>, Collection<URL>) - Constructor for class org.apache.flink.runtime.executiongraph.JobInformation
 
JobLeaderIdActions - Interface in org.apache.flink.runtime.resourcemanager
Interface for actions called by the JobLeaderIdService.
JobLeaderIdService - 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).
JobLeaderIdService(HighAvailabilityServices, ScheduledExecutor, Time) - Constructor for class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
 
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 - Class 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.
JobLeaderService(TaskManagerLocation) - Constructor for class org.apache.flink.runtime.taskexecutor.JobLeaderService
 
JobListeningContext - Class in org.apache.flink.runtime.client
The JobListeningContext holds the state necessary to monitor a running job and receive its results.
JobListeningContext(JobID, Future<Object>, ActorRef, FiniteDuration, ClassLoader, HighAvailabilityServices) - Constructor for class org.apache.flink.runtime.client.JobListeningContext
Constructor to use when the class loader is available.
JobListeningContext(JobID, Future<Object>, ActorRef, FiniteDuration, ActorSystem, Configuration, HighAvailabilityServices) - Constructor for class org.apache.flink.runtime.client.JobListeningContext
Constructor to use when the class loader is not available.
jobManager - Variable in class org.apache.flink.runtime.client.JobClientActor
ActorRef to the current leader
jobManager() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterResourceManagerSuccessful
 
jobManagerAddress() - Method in class org.apache.flink.runtime.clusterframework.messages.TriggerRegistrationAtJobManager
 
JobManagerCliOptions - Class in org.apache.flink.runtime.jobmanager
The command line parameters passed to the JobManager.
JobManagerCliOptions() - Constructor for class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
JobManagerConnection - Class in org.apache.flink.runtime.taskexecutor
Container class for JobManager specific communication utils used by the TaskExecutor.
JobManagerConnection(JobID, ResourceID, JobMasterGateway, TaskManagerActions, CheckpointResponder, LibraryCacheManager, ResultPartitionConsumableNotifier, PartitionProducerStateChecker) - Constructor for class org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
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
 
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.
JobManagerGateway - Interface in org.apache.flink.runtime.jobmaster
Public JobManager gateway.
JobManagerJobMetricGroup - Class in org.apache.flink.runtime.metrics.groups
Special MetricGroup representing everything belonging to a specific job, running on the JobManager.
JobManagerJobMetricGroup(MetricRegistry, JobManagerMetricGroup, JobID, String) - Constructor for class org.apache.flink.runtime.metrics.groups.JobManagerJobMetricGroup
 
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
 
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 MetricGroup representing a JobManager.
JobManagerMetricGroup(MetricRegistry, String) - Constructor for class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
JobManagerMetricsHandler - Class in org.apache.flink.runtime.rest.handler.job.metrics
Handler that returns JobManager metrics.
JobManagerMetricsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.JobManagerMetricsHandler
 
JobManagerMetricsHandler - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
Request handler that returns for the job manager a list of all available metrics or the values for a set of metrics.
JobManagerMetricsHandler(Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.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
 
JobManagerMode - Enum in org.apache.flink.runtime.jobmanager
The startup mode for the JobManager.
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
 
JobManagerRunner - Class in org.apache.flink.runtime.jobmaster
The runner for the job manager.
JobManagerRunner(ResourceID, JobGraph, Configuration, RpcService, HighAvailabilityServices, HeartbeatServices, BlobServer, JobManagerSharedServices, JobManagerJobMetricGroupFactory, FatalErrorHandler) - Constructor for class org.apache.flink.runtime.jobmaster.JobManagerRunner
Exceptions that occur while creating the JobManager or JobManagerRunner are directly thrown and not reported to the given FatalErrorHandler.
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, LibraryCacheManager, RestartStrategyFactory, StackTraceSampleCoordinator, BackPressureStatsTracker) - Constructor for class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
 
JobManagerTable - Class in org.apache.flink.runtime.taskexecutor
Container for multiple JobManagerConnection registered under their respective job id.
JobManagerTable() - Constructor for class org.apache.flink.runtime.taskexecutor.JobManagerTable
 
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
 
JobMaster - Class in org.apache.flink.runtime.jobmaster
JobMaster implementation.
JobMaster(RpcService, JobMasterConfiguration, ResourceID, JobGraph, HighAvailabilityServices, SlotPoolFactory, JobManagerSharedServices, HeartbeatServices, BlobServer, JobManagerJobMetricGroupFactory, OnCompletionActions, FatalErrorHandler, ClassLoader) - Constructor for class org.apache.flink.runtime.jobmaster.JobMaster
 
JobMasterConfiguration - Class in org.apache.flink.runtime.jobmaster
Configuration for the JobMaster.
JobMasterConfiguration(Time, Time, String, Configuration) - Constructor for class org.apache.flink.runtime.jobmaster.JobMasterConfiguration
 
JobMasterException - Exception in org.apache.flink.runtime.jobmaster.exceptions
Base class for all JobMaster related exceptions.
JobMasterException(String) - Constructor for exception org.apache.flink.runtime.jobmaster.exceptions.JobMasterException
 
JobMasterException(Throwable) - Constructor for exception org.apache.flink.runtime.jobmaster.exceptions.JobMasterException
 
JobMasterException(String, Throwable) - Constructor for exception org.apache.flink.runtime.jobmaster.exceptions.JobMasterException
 
JobMasterException - Exception in org.apache.flink.runtime.jobmaster
Base class for JobMaster related exceptions.
JobMasterException(String) - Constructor for exception org.apache.flink.runtime.jobmaster.JobMasterException
 
JobMasterException(Throwable) - Constructor for exception org.apache.flink.runtime.jobmaster.JobMasterException
 
JobMasterException(String, Throwable) - Constructor for exception org.apache.flink.runtime.jobmaster.JobMasterException
 
jobMasterFailed(Throwable) - Method in interface org.apache.flink.runtime.jobmanager.OnCompletionActions
The JobMaster failed while executing the job.
jobMasterFailed(Throwable) - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
 
JobMasterGateway - Interface in org.apache.flink.runtime.jobmaster
JobMaster rpc gateway interface.
JobMasterId - Class in org.apache.flink.runtime.jobmaster
The JobMaster fencing token.
JobMasterId(UUID) - Constructor for class org.apache.flink.runtime.jobmaster.JobMasterId
Creates a JobMasterId that takes the bits from the given UUID.
JobMasterRegistrationSuccess - Class in org.apache.flink.runtime.jobmaster
Base class for responses from the ResourceManager to a registration attempt by a JobMaster.
JobMasterRegistrationSuccess(long, ResourceManagerId, ResourceID) - Constructor for class org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess
 
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 MetricGroup representing 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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.JobMetricsHandler
 
JobMetricsHandler - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
Request handler that returns for a given job a list of all available metrics or the values for a set of metrics.
JobMetricsHandler(Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.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
 
JobModificationException - Exception in org.apache.flink.runtime.jobmaster.exceptions
Base class for all exception which originate from a failed job modification.
JobModificationException(String) - Constructor for exception org.apache.flink.runtime.jobmaster.exceptions.JobModificationException
 
JobModificationException(Throwable) - Constructor for exception org.apache.flink.runtime.jobmaster.exceptions.JobModificationException
 
JobModificationException(String, Throwable) - Constructor for exception org.apache.flink.runtime.jobmaster.exceptions.JobModificationException
 
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
 
jobNotFinished(JobID) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
jobNotFinished(JobID) - Method in class org.apache.flink.runtime.dispatcher.MiniDispatcher
 
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.JobMessageParameters
 
jobPathParameter - Variable in class org.apache.flink.runtime.rest.messages.JobTerminationMessageParameters
 
JobPlanHandler - Class in org.apache.flink.runtime.rest.handler.job
Handler serving the job execution plan.
JobPlanHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, JobPlanInfo, JobMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobPlanHandler
 
JobPlanHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Request handler that returns the JSON program plan of a job graph.
JobPlanHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.JobPlanHandler
 
JobPlanHandler.JobPlanJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy
Archivist for the 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.Deserializer - Class in org.apache.flink.runtime.rest.messages
Json deserializer for the JobPlanInfo.
JobPlanInfo.Serializer - Class in org.apache.flink.runtime.rest.messages
Json serializer for the JobPlanInfo.
JobPlanJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.JobPlanHandler.JobPlanJsonArchivist
 
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(ArchivedExecutionGraph) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
jobReachedGloballyTerminalState(ArchivedExecutionGraph) - Method in class org.apache.flink.runtime.dispatcher.MiniDispatcher
 
jobReachedGloballyTerminalState(ArchivedExecutionGraph) - Method in interface org.apache.flink.runtime.jobmanager.OnCompletionActions
Job reached a globally terminal state.
jobReachedGloballyTerminalState(ArchivedExecutionGraph) - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
Job completion notification triggered by JobManager.
JobResult - Class in org.apache.flink.runtime.jobmaster
Similar to JobExecutionResult but with an optional SerializedThrowable when the job failed.
JobResult.Builder - Class in org.apache.flink.runtime.jobmaster
Builder for JobResult.
JobResult.WrappedJobException - Exception in org.apache.flink.runtime.jobmaster
Exception which indicates that the job has finished with an Exception.
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
 
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
 
JobRetrievalException - Exception in org.apache.flink.runtime.client
Exception used to indicate that a job couldn't be retrieved from the JobManager
JobRetrievalException(JobID, String, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobRetrievalException
 
JobRetrievalException(JobID, String) - Constructor for exception org.apache.flink.runtime.client.JobRetrievalException
 
JobRetrievalException(JobID, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobRetrievalException
 
JobsFilterQueryParameter - Class in org.apache.flink.runtime.rest.messages.job.metrics
MessageQueryParameter for selecting jobs when aggregating metrics.
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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, MultipleJobsDetails, EmptyMessageParameters>) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobsOverviewHandler
 
JobsOverviewHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Request handler that returns a summary of the job status.
JobsOverviewHandler(Executor, Time) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.JobsOverviewHandler
 
JobsOverviewHandler.CurrentJobsOverviewJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy
Archivist for the CurrentJobsOverviewHandler.
JobsOverviewHeaders - Class in org.apache.flink.runtime.rest.messages
Message headers for JobsOverviewHandler.
JobStatus - Enum in org.apache.flink.runtime.jobgraph
Possible states of a job once it has been accepted by the job manager.
jobStatusChanges(JobID, JobStatus, long, Throwable) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinatorDeActivator
 
jobStatusChanges(JobID, JobStatus, long, Throwable) - Method in interface org.apache.flink.runtime.executiongraph.JobStatusListener
This method is called whenever the status of the job changes.
jobStatusChanges(JobID, JobStatus, long, Throwable) - Method in class org.apache.flink.runtime.executiongraph.StatusListenerMessenger
 
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
 
JobStoppingHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Request handler for the STOP request.
JobStoppingHandler(Executor, Time) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.JobStoppingHandler
 
JobSubmissionClientActor - Class in org.apache.flink.runtime.client
Actor which handles Job submission process and provides Job updates until completion.
JobSubmissionClientActor(LeaderRetrievalService, FiniteDuration, boolean, Configuration) - Constructor for class org.apache.flink.runtime.client.JobSubmissionClientActor
 
JobSubmissionException - Exception in org.apache.flink.runtime.client
This exception denotes an error while submitting a job to the JobManager.
JobSubmissionException(JobID, String, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobSubmissionException
 
JobSubmissionException(JobID, String) - 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(CompletableFuture<String>, GatewayRetriever<? extends DispatcherGateway>, Time, Map<String, String>, Executor) - 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>) - Constructor for class org.apache.flink.runtime.rest.messages.job.JobSubmitRequestBody
 
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
 
JobTerminationHandler - Class in org.apache.flink.runtime.rest.handler.job
Request handler for the cancel and stop request.
JobTerminationHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, EmptyResponseBody, JobTerminationMessageParameters>, TerminationModeQueryParameter.TerminationMode) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobTerminationHandler
 
JobTerminationHeaders - Class in org.apache.flink.runtime.rest.messages
Message headers for the JobCancellationHandler.
JobTerminationMessageParameters - Class in org.apache.flink.runtime.rest.messages
Parameters for job related REST handlers.
JobTerminationMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.JobTerminationMessageParameters
 
JobTimeoutException - Exception in org.apache.flink.runtime.client
An exception which is thrown by the JobClient if the job manager is no longer reachable.
JobTimeoutException(JobID, String, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobTimeoutException
 
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<JobVertexID>, List<OperatorID>, List<OperatorID>) - Constructor for class org.apache.flink.runtime.jobgraph.JobVertex
Constructs a new job vertex and assigns it with the given name.
JobVertexAccumulatorsHandler - Class in org.apache.flink.runtime.rest.handler.job
Request handler for the job vertex accumulators.
JobVertexAccumulatorsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, JobVertexAccumulatorsInfo, JobVertexMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobVertexAccumulatorsHandler
 
JobVertexAccumulatorsHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Request handler that returns the accummulators for a given vertex.
JobVertexAccumulatorsHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.JobVertexAccumulatorsHandler
 
JobVertexAccumulatorsHandler.JobVertexAccumulatorsJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy
Archivist for 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
 
JobVertexAccumulatorsJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.JobVertexAccumulatorsHandler.JobVertexAccumulatorsJsonArchivist
 
JobVertexBackPressureHandler - Class in org.apache.flink.runtime.rest.handler.job
Request handler for the job vertex back pressure.
JobVertexBackPressureHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, JobVertexBackPressureInfo, JobVertexMessageParameters>) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobVertexBackPressureHandler
 
JobVertexBackPressureHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Request handler that returns back pressure stats for a single job vertex and all its sub tasks.
JobVertexBackPressureHandler(ExecutionGraphCache, Executor, BackPressureStatsTrackerImpl, int) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, JobVertexDetailsInfo, JobVertexMessageParameters>, ExecutionGraphCache, Executor, MetricFetcher<? extends RestfulGateway>) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobVertexDetailsHandler
 
JobVertexDetailsHandler - Class in org.apache.flink.runtime.rest.handler.legacy
A request handler that provides the details of a job vertex, including id, name, parallelism, and the runtime and metrics of all its subtasks.
JobVertexDetailsHandler(ExecutionGraphCache, Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.JobVertexDetailsHandler
 
JobVertexDetailsHandler.JobVertexDetailsJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy
Archivist for the 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(JobVertexID, String, int, ExecutionState, long, long, long, Map<ExecutionState, Integer>, IOMetricsInfo) - Constructor for class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
 
JobVertexDetailsInfo - Class in org.apache.flink.runtime.rest.messages
Response type of the JobVertexDetailsHandler.
JobVertexDetailsInfo(JobVertexID, String, int, long, List<JobVertexDetailsInfo.VertexTaskDetail>) - Constructor for class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
 
JobVertexDetailsInfo.VertexTaskDetail - Class in org.apache.flink.runtime.rest.messages
Vertex task detail class.
JobVertexDetailsJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.JobVertexDetailsHandler.JobVertexDetailsJsonArchivist
 
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 JobVertexID used 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 - Class in org.apache.flink.runtime.rest.messages
Path parameter specifying a JobVertexID.
JobVertexIdPathParameter() - Constructor for class org.apache.flink.runtime.rest.messages.JobVertexIdPathParameter
 
jobVertexIdPathParameter - Variable in class org.apache.flink.runtime.rest.messages.JobVertexMessageParameters
 
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
 
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 SubtaskMetricsHandler and is only kept for backwards-compatibility.
JobVertexMetricsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.JobVertexMetricsHandler
Deprecated.
 
JobVertexMetricsHandler - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
Deprecated.
This class is subsumed by SubtaskMetricsHandler and is only kept for backwards-compatibility.
JobVertexMetricsHandler(Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.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
 
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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, JobVertexTaskManagersInfo, JobVertexMessageParameters>, ExecutionGraphCache, Executor, MetricFetcher<?>) - Constructor for class org.apache.flink.runtime.rest.handler.job.JobVertexTaskManagersHandler
 
JobVertexTaskManagersHandler - Class in org.apache.flink.runtime.rest.handler.legacy
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(ExecutionGraphCache, Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.JobVertexTaskManagersHandler
 
JobVertexTaskManagersHandler.JobVertexTaskManagersJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy
Archivist for 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.
JobVertexTaskManagersJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.JobVertexTaskManagersHandler.JobVertexTaskManagersJsonArchivist
 
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
 
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.
JsonPlanGenerator - Class in org.apache.flink.runtime.jobgraph.jsonplan
 
JsonPlanGenerator() - Constructor for class org.apache.flink.runtime.jobgraph.jsonplan.JsonPlanGenerator
 
JvmShutdownSafeguard - Class in org.apache.flink.runtime.util
A utility that guards against blocking shutdown hooks that block JVM shutdown.

K

keepBuildSidePartitions - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
If true, build side partitions are kept for multiple probe steps.
KerberosUtils - Class in org.apache.flink.runtime.security
Provides vendor-specific Kerberos AppConfigurationEntry instances.
KerberosUtils() - Constructor for class org.apache.flink.runtime.security.KerberosUtils
 
KEY - Static variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointIdPathParameter
 
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.JobIDPathParameter
 
KEY - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexIdPathParameter
 
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.taskmanager.TaskManagerIdPathParameter
 
KEY - Static variable in class org.apache.flink.runtime.rest.messages.TriggerIdPathParameter
 
keyContext - Variable in class org.apache.flink.runtime.state.heap.StateTable
The key context view on the backend.
KeyedBackendSerializationProxy<K> - Class in org.apache.flink.runtime.state
Serialization proxy for all meta data in keyed state backends.
KeyedBackendSerializationProxy(ClassLoader, boolean) - Constructor for class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
KeyedBackendSerializationProxy(TypeSerializer<K>, List<RegisteredKeyedBackendStateMetaInfo.Snapshot<?, ?>>, boolean) - Constructor for class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
KeyedBackendStateMetaInfoSnapshotReaderWriters - Class in org.apache.flink.runtime.state
Readers and writers for different versions of the RegisteredKeyedBackendStateMetaInfo.Snapshot.
KeyedBackendStateMetaInfoSnapshotReaderWriters() - Constructor for class org.apache.flink.runtime.state.KeyedBackendStateMetaInfoSnapshotReaderWriters
 
KeyedBackendStateMetaInfoSnapshotReaderWriters.KeyedBackendStateMetaInfoReader<N,S> - Interface in org.apache.flink.runtime.state
 
KeyedBackendStateMetaInfoSnapshotReaderWriters.KeyedBackendStateMetaInfoWriter - Interface in org.apache.flink.runtime.state
 
keyedStateBackend - Variable in class org.apache.flink.runtime.state.DefaultKeyedStateStore
 
KeyedStateBackend<K> - Interface in org.apache.flink.runtime.state
A keyed state backend provides methods for managing keyed state.
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(CheckpointStreamFactory.CheckpointStateOutputStream, KeyGroupRange) - Constructor for class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
 
KeyedStateFunction<K,S extends org.apache.flink.api.common.state.State> - Class in org.apache.flink.runtime.state
A function to be applied to all keyed states.
KeyedStateFunction() - Constructor for class org.apache.flink.runtime.state.KeyedStateFunction
 
KeyedStateHandle - Interface in org.apache.flink.runtime.state
Base for the handles of the checkpointed states in keyed streams.
keyGroupCompressionDecorator - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
Decorates the input and output streams to write key-groups compressed.
KeyGroupedIterator<E> - Interface in org.apache.flink.runtime.util
 
keyGroupRange - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
Range of key-groups for which this backend is responsible
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(KeyGroupRange, long[]) - Constructor for class org.apache.flink.runtime.state.KeyGroupRangeOffsets
Creates key-group range with offsets from the given key-group range.
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(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(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.
KeyGroupsList - Interface in org.apache.flink.runtime.state
This interface offers ordered random read access to multiple key group ids.
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(IOException, int) - Constructor for class org.apache.flink.runtime.state.KeyGroupStatePartitionStreamProvider
 
KeyGroupStatePartitionStreamProvider(InputStream, int) - Constructor for class org.apache.flink.runtime.state.KeyGroupStatePartitionStreamProvider
 
keys() - Method in class org.apache.flink.runtime.state.heap.HeapMapState
 
keySerializer - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
TypeSerializer for our key.
keySerializer - Variable in class org.apache.flink.runtime.state.heap.AbstractHeapState
 
keySetA() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
keySetB() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
keytabEntry(String, String) - Static method in class org.apache.flink.runtime.security.KerberosUtils
 
KeytabOverlay - Class in org.apache.flink.runtime.clusterframework.overlays
Overlays cluster-level Kerberos credentials (i.e.
KeytabOverlay(File) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay
 
KeytabOverlay(Path) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay
 
KeytabOverlay.Builder - Class in org.apache.flink.runtime.clusterframework.overlays
A builder for the KeytabOverlay.
keyValueStatesByName - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
So that we can give out state when the user uses the same key.
Krb5ConfOverlay - Class in org.apache.flink.runtime.clusterframework.overlays
Overlays a Kerberos configuration file into a container.
Krb5ConfOverlay(File) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay
 
Krb5ConfOverlay(Path) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay
 
Krb5ConfOverlay.Builder - Class in org.apache.flink.runtime.clusterframework.overlays
A builder for the Krb5ConfOverlay.
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 InternalKvState along with its KvStateInfo.
KvStateEntry(InternalKvState<K, N, V>) - Constructor for class org.apache.flink.runtime.query.KvStateEntry
 
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 InternalKvState instance.
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 KvStateLocation in the cluster.
KvStateLocationRegistry - Class in org.apache.flink.runtime.query
Simple registry, which maps InternalKvState registration notifications to KvStateLocation instances.
KvStateLocationRegistry(JobID, Map<JobVertexID, ExecutionJobVertex>) - Constructor for class org.apache.flink.runtime.query.KvStateLocationRegistry
Creates the registry for the job.
KvStateMessage - Interface in org.apache.flink.runtime.query
Actor messages for InternalKvState lookup and registration.
KvStateMessage.LookupKvStateLocation - Class in org.apache.flink.runtime.query
Actor message for looking up KvStateLocation.
KvStateMessage.NotifyKvStateRegistered - Class in org.apache.flink.runtime.query
Actor message for notification of KvState registration.
KvStateMessage.NotifyKvStateUnregistered - Class in org.apache.flink.runtime.query
Actor message for notification of KvState unregistration.
KvStateRegistry - Class in org.apache.flink.runtime.query
A registry for InternalKvState instances per task manager.
KvStateRegistry() - Constructor for class org.apache.flink.runtime.query.KvStateRegistry
 
kvStateRegistry - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
KvStateRegistry helper for this task
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.

L

LargeRecordHandler<T> - Class in org.apache.flink.runtime.operators.sort
 
LargeRecordHandler(TypeSerializer<T>, TypeComparator<T>, IOManager, MemoryManager, List<MemorySegment>, AbstractInvokable, int) - Constructor for class org.apache.flink.runtime.operators.sort.LargeRecordHandler
 
LatestCheckpoints(CheckpointStatistics.CompletedCheckpointStatistics, CheckpointStatistics.CompletedCheckpointStatistics, CheckpointStatistics.FailedCheckpointStatistics, CheckpointingStatistics.RestoredCheckpointStatistics) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
 
lazyDestroy() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
Destroys this buffer pool.
leaderAddress() - Method in class org.apache.flink.runtime.clusterframework.messages.NewLeaderAvailable
 
leaderAddress() - Method in class org.apache.flink.runtime.leaderelection.LeaderAddressAndId
 
LeaderAddressAndId - Class in org.apache.flink.runtime.leaderelection
A combination of a leader address and leader id.
LeaderAddressAndId(String, UUID) - Constructor for class org.apache.flink.runtime.leaderelection.LeaderAddressAndId
 
LeaderConnectingAddressListener() - Constructor for class org.apache.flink.runtime.net.ConnectionUtils.LeaderConnectingAddressListener
 
LeaderConnectionInfo - Class in org.apache.flink.runtime.util
Wrapper class for a pair of connection address and leader session ID.
LeaderConnectionInfo(String, UUID) - Constructor for class org.apache.flink.runtime.util.LeaderConnectionInfo
 
LeaderConnectionInfoListener() - Constructor for class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderConnectionInfoListener
 
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.
LeaderElectionService - Interface in org.apache.flink.runtime.leaderelection
Interface for a service which allows to elect a leader among a group of contenders.
LeaderGatewayListener(ActorSystem, FiniteDuration) - Constructor for class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderGatewayListener
 
LeaderGatewayRetriever<T extends 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
 
leaderId() - Method in class org.apache.flink.runtime.leaderelection.LeaderAddressAndId
 
LeaderIdMismatchException - Exception in org.apache.flink.runtime.highavailability
An exception thrown when the leader session id attached to a message does not match the leader session id that the receiver expects.
LeaderIdMismatchException(UUID, UUID) - Constructor for exception org.apache.flink.runtime.highavailability.LeaderIdMismatchException
 
LeaderRetrievalException - Exception in org.apache.flink.runtime.leaderretrieval
This exception is thrown by the LeaderRetrievalUtils when the method retrieveLeaderGateway fails to retrieve the current leader's gateway.
LeaderRetrievalException(String) - Constructor for exception org.apache.flink.runtime.leaderretrieval.LeaderRetrievalException
 
LeaderRetrievalException(Throwable) - Constructor for exception org.apache.flink.runtime.leaderretrieval.LeaderRetrievalException
 
LeaderRetrievalException(String, Throwable) - Constructor for exception org.apache.flink.runtime.leaderretrieval.LeaderRetrievalException
 
LeaderRetrievalListener - Interface in org.apache.flink.runtime.leaderretrieval
Classes which want to be notified about a changing leader by the LeaderRetrievalService have 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 LeaderRetrievalService class.
LeaderRetrievalUtils.LeaderConnectionInfoListener - Class in org.apache.flink.runtime.util
Helper class which is used by the retrieveLeaderConnectionInfo method to retrieve the leader's akka URL and the current leader session ID.
LeaderRetrievalUtils.LeaderGatewayListener - Class in org.apache.flink.runtime.util
Helper class which is used by the retrieveLeaderGateway method as the LeaderRetrievalListener.
leaderRetriever - Variable in class org.apache.flink.runtime.rest.handler.RedirectHandler
 
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
 
leaderRetriever - Variable in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
 
leaderSessionID - Variable in class org.apache.flink.runtime.client.JobClientActor
leader session ID of the JobManager when this actor was created
leaderSessionId() - Method in class org.apache.flink.runtime.clusterframework.messages.NewLeaderAvailable
 
leaderSessionID() - Method in interface org.apache.flink.runtime.instance.ActorGateway
Returns the leaderSessionID associated with the remote actor or null.
leaderSessionID() - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
 
LeaderSessionMessageDecorator - Class in org.apache.flink.runtime.messages
Message decorator which wraps message which implement RequiresLeaderSessionID into a JobManagerMessages.LeaderSessionMessage.
LeaderSessionMessageDecorator(UUID) - Constructor for class org.apache.flink.runtime.messages.LeaderSessionMessageDecorator
Sets the leader session ID with which the messages will be decorated.
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
 
LegacyRestHandler<T extends RestfulGateway,R extends ResponseBody,M extends MessageParameters> - Interface in org.apache.flink.runtime.rest.handler
Interface which Flink's legacy REST handler have to implement in order to be usable via the LegacyRestHandlerAdapter.
LegacyRestHandlerAdapter<T extends RestfulGateway,R extends ResponseBody,M extends MessageParameters> - Class in org.apache.flink.runtime.rest.handler
Adapter for Flink's legacy REST handlers.
LegacyRestHandlerAdapter(CompletableFuture<String>, GatewayRetriever<T>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, R, M>, LegacyRestHandler<T, R, M>) - Constructor for class org.apache.flink.runtime.rest.handler.LegacyRestHandlerAdapter
 
LibraryCacheManager - Interface in org.apache.flink.runtime.execution.librarycache
 
LifoSetQueue<E> - Class in org.apache.flink.runtime.jobmanager.scheduler
A queue that returns elements in LIFO order and simultaneously maintains set characteristics, i.e., elements that are already in the queue may not be added another time.
LifoSetQueue() - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
 
ListeningBehaviour - Enum in org.apache.flink.runtime.akka
Defines the listening behaviour of the JobClientActor and thus the messages which are sent from the JobManger to the JobClientActor.
listJobs(Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
listJobs(Time) - Method in interface org.apache.flink.runtime.dispatcher.DispatcherGateway
List the current set of submitted jobs.
listJobs() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
 
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
 
listStatus() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
List the statuses of the files/directories in the snapshot directory.
loadAndValidateCheckpoint(JobID, Map<JobVertexID, ExecutionJobVertex>, CompletedCheckpointStorageLocation, ClassLoader, boolean) - Static method in class org.apache.flink.runtime.checkpoint.Checkpoints
 
loadBigData(PermanentBlobService) - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
Loads externalized data from the BLOB store back to the object.
loadCheckpointMetadata(DataInputStream, ClassLoader) - Static method in class org.apache.flink.runtime.checkpoint.Checkpoints
 
loadConfiguration(ClusterConfiguration) - Static method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
loadFailoverStrategy(Configuration, Logger) - Static method in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategyLoader
Loads a FailoverStrategy Factory from the given configuration.
loadStateBackend(Configuration, ClassLoader, Logger) - Static method in class org.apache.flink.runtime.checkpoint.Checkpoints
 
loadStateBackendFromConfig(Configuration, ClassLoader, Logger) - Static method in class org.apache.flink.runtime.state.StateBackendLoader
Loads the state backend from the configuration, from the parameter 'state.backend', as defined in CheckpointingOptions.STATE_BACKEND.
loadWebSubmissionExtension(GatewayRetriever<? extends DispatcherGateway>, CompletableFuture<String>, Time, Map<String, String>, Path, Executor, Configuration) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
Loads the WebMonitorExtension which enables web submission.
LOCAL_STATE_SUB_DIRECTORY_ROOT - Static variable in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
localAddressFuture - Variable in class org.apache.flink.runtime.rest.handler.RedirectHandler
 
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
 
LocalFencedMessage<F extends Serializable,P> - Class in org.apache.flink.runtime.rpc.messages
Local FencedMessage implementation.
LocalFencedMessage(F, P) - Constructor for class org.apache.flink.runtime.rpc.messages.LocalFencedMessage
 
LocalInputChannel - Class in org.apache.flink.runtime.io.network.partition.consumer
An input channel, which requests a local subpartition.
LocalInputChannel(SingleInputGate, int, ResultPartitionID, ResultPartitionManager, TaskEventDispatcher, TaskIOMetricGroup) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
 
LocalInputChannel(SingleInputGate, int, ResultPartitionID, ResultPartitionManager, TaskEventDispatcher, int, int, TaskIOMetricGroup) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
 
Locality - Enum in org.apache.flink.runtime.jobmanager.scheduler
 
LocalRecoveryConfig - Class in org.apache.flink.runtime.state
This class encapsulates the completed configuration for local recovery, i.e.
LocalRecoveryConfig(boolean, LocalRecoveryDirectoryProvider) - Constructor for class org.apache.flink.runtime.state.LocalRecoveryConfig
 
LocalRecoveryDirectoryProvider - Interface in org.apache.flink.runtime.state
Provides directories for local recovery.
LocalRecoveryDirectoryProviderImpl - Class in org.apache.flink.runtime.state
LocalRecoveryDirectoryProviderImpl(File, JobID, JobVertexID, int) - Constructor for class org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
 
LocalRecoveryDirectoryProviderImpl(File[], JobID, JobVertexID, int) - Constructor for class org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
 
LocalRpcInvocation - Class in org.apache.flink.runtime.rpc.messages
Local rpc invocation message containing the remote procedure name, its parameter types and the corresponding call arguments.
LocalRpcInvocation(String, Class<?>[], Object[]) - Constructor for class org.apache.flink.runtime.rpc.messages.LocalRpcInvocation
 
localStateStoreForSubtask(JobID, AllocationID, JobVertexID, int) - 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.
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
 
LocationPreferenceConstraint - Enum in org.apache.flink.runtime.jobmanager.scheduler
Defines the location preference constraint.
LocationPreferenceSchedulingStrategy - Class in org.apache.flink.runtime.jobmaster.slotpool
Default SchedulingStrategy which tries to match a slot with its location preferences.
lock - Variable in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
lockLocation() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Locks the location of this slot.
lockLocation(TaskManagerLocation) - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Locks the location of this slot.
LOG - Static variable in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
 
LOG - Variable in class org.apache.flink.runtime.akka.FlinkUntypedActor
 
log - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
The log object used for debugging.
LOG - Static variable in interface org.apache.flink.runtime.blob.BlobWriter
 
LOG - Static variable in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
log - Variable in class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
 
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
Logging
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 - 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.rest.AbstractHandler
 
log - Variable in class org.apache.flink.runtime.rest.RestServerEndpoint
 
log - Variable in class org.apache.flink.runtime.rpc.RpcEndpoint
 
LOG - Static variable in class org.apache.flink.runtime.security.DynamicConfiguration
 
LOG - Static variable in interface org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
 
log - Variable in class org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
 
LOG - Static variable in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
 
logAndPrintMessage(String) - Method in class org.apache.flink.runtime.client.JobClientActor
 
logAndThrowException(Exception, AbstractInvokable) - Static method in class org.apache.flink.runtime.operators.BatchTask
Prints an error message and throws the given exception.
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.
logFile - Variable in class org.apache.flink.runtime.webmonitor.WebMonitorUtils.LogFileLocation
 
LogFileHandlerSpecification - Class in org.apache.flink.runtime.rest.handler.legacy.files
Rest handler specification for the log file of the main cluster component.
logger - Variable in class org.apache.flink.runtime.rest.handler.RedirectHandler
 
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.
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
 
LookupKvStateLocation(JobID, String) - Constructor for class org.apache.flink.runtime.query.KvStateMessage.LookupKvStateLocation
Requests a KvStateLocation for the specified JobID and InternalKvState registration name.

M

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.zookeeper.FlinkZooKeeperQuorumPeer
 
MainThreadExecutable - Interface in org.apache.flink.runtime.rpc
Interface to execute Runnable and Callable in the main thread of the underlying RPC endpoint.
MainThreadValidatorUtil - Class in org.apache.flink.runtime.rpc
This utility exists to bridge between the visibility of the currentMainThread field in the RpcEndpoint.
MainThreadValidatorUtil(RpcEndpoint) - Constructor for class org.apache.flink.runtime.rpc.MainThreadValidatorUtil
 
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.
ManagedSnapshotContext - Interface in org.apache.flink.runtime.state
This interface provides a context in which operators that use managed state (i.e.
map(Tuple2<Integer, T>) - Method in class org.apache.flink.runtime.operators.udf.RemoveRangeIndex
 
map(EvictingBoundedList.Function<T, R>) - Method in class org.apache.flink.runtime.util.EvictingBoundedList
Creates a new list that replaces its elements with transformed elements.
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
 
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
 
MAPPER - Static variable in class org.apache.flink.runtime.rest.AbstractHandler
 
mark(int) - Method in class org.apache.flink.runtime.state.BoundedInputStream
 
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.
markDead() - Method in class org.apache.flink.runtime.instance.Instance
 
markFree() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Mark the slot as free.
markInactive() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Mark the slot as inactive/allocated.
markReleasing() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Mark this slot as releasing.
markSlotActive(AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Marks the slot under the given allocation id as active.
markSlotInactive(AllocationID, Time) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Marks the slot under the given allocation id as inactive.
markSupported() - Method in class org.apache.flink.runtime.state.BoundedInputStream
 
markSupported() - Method in class org.apache.flink.runtime.util.ForwardingInputStream
 
markUsed() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
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.
MaterializationExpiredException - Exception in org.apache.flink.runtime.broadcast
Indicates that the BroadcastVariableMaterialization has 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
 
max - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
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_FILE_STATE_THRESHOLD - Static variable in class org.apache.flink.runtime.state.filesystem.FsStateBackend
Maximum size of state that is stored with the metadata, rather than in files (1 MiByte).
MAX_NUM_WRITE_BUFFERS - Static variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The maximal number of buffers to use by the writers.
maxFanIn - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
MaybeOffloaded() - Constructor for class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.MaybeOffloaded
 
mean - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
median - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
MemCheckpointStreamFactory - Class in org.apache.flink.runtime.state.memory
CheckpointStreamFactory that 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 CheckpointStateOutputStream that writes into a byte array.
memManager - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
MEMORY_STATE_BACKEND_NAME - Static variable in class org.apache.flink.runtime.state.StateBackendLoader
The shortcut configuration name for the MemoryState backend that checkpoints to the JobManager
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, Throwable) - Constructor for exception org.apache.flink.runtime.memory.MemoryAllocationException
 
MemoryAllocationException(String) - Constructor for exception org.apache.flink.runtime.memory.MemoryAllocationException
 
MemoryAllocationException(Throwable) - Constructor for exception org.apache.flink.runtime.memory.MemoryAllocationException
 
MemoryArchivedExecutionGraphStore - Class in org.apache.flink.runtime.dispatcher
ArchivedExecutionGraphStore implementation which stores the ArchivedExecutionGraph in memory.
MemoryArchivedExecutionGraphStore() - Constructor for class org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
 
MemoryBackendCheckpointStorage - Class in org.apache.flink.runtime.state.memory
An implementation of a checkpoint storage for the MemoryStateBackend.
MemoryBackendCheckpointStorage(JobID, Path, Path, int) - Constructor for class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
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
 
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, ActorSystem) - Constructor for class org.apache.flink.runtime.taskmanager.MemoryLogger
Creates a new memory logger that logs in the given interval and lives as long as the given actor system.
MemoryManager - Class in org.apache.flink.runtime.memory
The memory manager governs the memory that Flink uses for sorting, hashing, and caching.
MemoryManager(long, int) - Constructor for class org.apache.flink.runtime.memory.MemoryManager
Creates a memory manager with the given capacity, using the default page size.
MemoryManager(long, int, int, MemoryType, boolean) - Constructor for class org.apache.flink.runtime.memory.MemoryManager
Creates a memory manager with the given capacity and given page size.
memoryManager - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
memoryManager - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
memoryManager - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The memory manager through which memory is allocated and released.
MemoryStateBackend - Class in org.apache.flink.runtime.state.memory
This state backend holds the working state in the memory (JVM heap) of the TaskManagers.
MemoryStateBackend() - Constructor for class org.apache.flink.runtime.state.memory.MemoryStateBackend
Creates a new memory state backend that accepts states whose serialized forms are up to the default state size (5 MB).
MemoryStateBackend(boolean) - Constructor for class org.apache.flink.runtime.state.memory.MemoryStateBackend
Creates a new memory state backend that accepts states whose serialized forms are up to the default state size (5 MB).
MemoryStateBackend(int) - Constructor for class org.apache.flink.runtime.state.memory.MemoryStateBackend
Creates a new memory state backend that accepts states whose serialized forms are up to the given number of bytes.
MemoryStateBackend(int, boolean) - Constructor for class org.apache.flink.runtime.state.memory.MemoryStateBackend
Creates a new memory state backend that accepts states whose serialized forms are up to the given number of bytes and that uses asynchronous snashots as configured.
MemoryStateBackend(String, String) - Constructor for class org.apache.flink.runtime.state.memory.MemoryStateBackend
Creates a new MemoryStateBackend, setting optionally the path to persist checkpoint metadata to, and to persist savepoints to.
MemoryStateBackend(String, String, int, TernaryBoolean) - Constructor for class org.apache.flink.runtime.state.memory.MemoryStateBackend
Creates a new MemoryStateBackend, setting optionally the paths to persist checkpoint metadata and savepoints to, as well as configuring state thresholds and asynchronous operations.
MemoryStateBackendFactory - Class in org.apache.flink.runtime.state.memory
A factory that creates an MemoryStateBackend from a configuration.
MemoryStateBackendFactory() - Constructor for class org.apache.flink.runtime.state.memory.MemoryStateBackendFactory
 
mergeChannelList(List<UnilateralSortMerger.ChannelWithBlockCount>, List<MemorySegment>, List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Merges the given sorted runs to a smaller number of sorted runs.
mergeChannels(List<UnilateralSortMerger.ChannelWithBlockCount>, List<List<MemorySegment>>, List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger.CombiningSpillingThread
Merges the sorted runs described by the given Channel IDs into a single sorted run.
mergeChannels(List<UnilateralSortMerger.ChannelWithBlockCount>, List<List<MemorySegment>>, List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Merges the sorted runs described by the given Channel IDs into a single sorted run.
mergeInto(CoLocationGroup) - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
 
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 class org.apache.flink.runtime.state.heap.AbstractHeapMergingState
 
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.
mergeReadMemory - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
mergeState(SV, SV) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapMergingState
 
mergeState(ACC, ACC) - Method in class org.apache.flink.runtime.state.heap.HeapAggregatingState
 
mergeState(List<V>, List<V>) - Method in class org.apache.flink.runtime.state.heap.HeapListState
 
mergeState(V, V) - Method in class org.apache.flink.runtime.state.heap.HeapReducingState
 
message() - Method in enum org.apache.flink.runtime.checkpoint.CheckpointDeclineReason
 
message() - Method in class org.apache.flink.runtime.clusterframework.messages.FatalErrorOccurred
 
message() - Method in class org.apache.flink.runtime.clusterframework.messages.InfoMessage
 
message() - Method in class org.apache.flink.runtime.clusterframework.messages.ResourceRemoved
Gets the optional message with details, for logging and debugging.
message() - Method in class org.apache.flink.runtime.clusterframework.messages.StopCluster
 
MessageDecorator - Interface in org.apache.flink.runtime.messages
Interface for message decorators
MessageHeaders<R extends RequestBody,P extends ResponseBody,M extends MessageParameters> - Interface in org.apache.flink.runtime.rest.messages
This class links RequestBodys to ResponseBodys 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
 
METADATA_FILE_NAME - Static variable in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
The name of the metadata files in checkpoints / savepoints.
metaInfo - Variable in class org.apache.flink.runtime.state.heap.StateTable
Combined meta information such as name and serializers for this state
meter(int, M) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
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
 
meter(int, 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
 
MethodVisitorImpl(int) - Constructor for class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
Metric - Class in org.apache.flink.runtime.rest.messages.job.metrics
Response type for a Metric and Metric-Value-Pair.
Metric(String, String) - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.Metric
Creates a new Metric with a possible value.
Metric(String) - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.Metric
Creates a new Metric without a 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_NAME - Static variable in class org.apache.flink.runtime.executiongraph.metrics.DownTimeGauge
 
METRIC_NAME - Static variable in class org.apache.flink.runtime.executiongraph.metrics.NumberOfFullRestartsGauge
 
METRIC_NAME - Static variable in class org.apache.flink.runtime.executiongraph.metrics.RestartTimeGauge
 
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 Gauge as 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 MetricDumps from a MetricDumpSerialization.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<T extends RestfulGateway> - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
The MetricFetcher can be used to fetch metrics from the JobManager and all registered TaskManagers.
MetricFetcher(GatewayRetriever<T>, MetricQueryServiceRetriever, Executor, Time) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricFetcher
 
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() - Constructor for class org.apache.flink.runtime.metrics.dump.MetricQueryService
 
MetricQueryServiceGateway - Interface in org.apache.flink.runtime.webmonitor.retriever
Gateway to communicate with a QueryService.
MetricQueryServiceRetriever - Interface in org.apache.flink.runtime.webmonitor.retriever
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, List<Tuple2<String, Configuration>>) - 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
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
 
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[], int, int, int, int) - Constructor for class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
 
MetricsFilterParameter - Class in org.apache.flink.runtime.rest.messages.job.metrics
MessageQueryParameter for filtering metrics provided by MetricStore.
MetricsFilterParameter() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.MetricsFilterParameter
 
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.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.
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_NUM_SORT_MEM_SEGMENTS - Static variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The minimum number of segments that are required for the sort to operate.
MIN_NUM_WRITE_BUFFERS - Static variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The minimal number of buffers to use by the writers.
MIN_PAGE_SIZE - Static variable in class org.apache.flink.runtime.memory.MemoryManager
The minimal memory page size.
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.
MiniClusterConfiguration - Class in org.apache.flink.runtime.minicluster
Configuration object for the MiniCluster.
MiniClusterConfiguration(Configuration, int, MiniClusterConfiguration.RpcServiceSharing, String) - Constructor for class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
MiniClusterConfiguration.Builder - Class in org.apache.flink.runtime.minicluster
Builder for the MiniClusterConfiguration.
MiniClusterConfiguration.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.
MiniDispatcher - Class in org.apache.flink.runtime.dispatcher
Mini Dispatcher which is instantiated as the dispatcher component by the JobClusterEntrypoint.
MiniDispatcher(RpcService, String, Configuration, HighAvailabilityServices, ResourceManagerGateway, BlobServer, HeartbeatServices, JobManagerMetricGroup, String, ArchivedExecutionGraphStore, Dispatcher.JobManagerRunnerFactory, FatalErrorHandler, String, HistoryServerArchivist, JobGraph, 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(RestServerEndpointConfiguration, GatewayRetriever<? extends RestfulGateway>, Configuration, RestHandlerConfiguration, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, Executor, MetricQueryServiceRetriever, LeaderElectionService, FatalErrorHandler) - Constructor for class org.apache.flink.runtime.jobmaster.MiniDispatcherRestEndpoint
 
MinMaxAvgStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
Minimum, maximum and average statistics.
MinMaxAvgStatistics(long, long, long) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
 
MinMaxAvgStats - Class in org.apache.flink.runtime.checkpoint
Helper for keeping track of min/max/average summaries.
mkdirs() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
 
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.HeartbeatManagerImpl
 
moreAvailable() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel.BufferAndAvailability
 
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
 
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 IOMetrics class 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.

N

name() - Method in class org.apache.flink.runtime.checkpoint.MasterState
 
name - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump
The name of the stored metric.
namespaceSerializer - Variable in class org.apache.flink.runtime.state.heap.AbstractHeapState
 
NestedMapsStateTable<K,N,S> - Class in org.apache.flink.runtime.state.heap
This implementation of StateTable uses nested HashMap objects.
NestedMapsStateTable(InternalKeyContext<K>, RegisteredKeyedBackendStateMetaInfo<N, S>) - Constructor for class org.apache.flink.runtime.state.heap.NestedMapsStateTable
Creates a new NestedMapsStateTable for the given key context and meta info.
netRuntime(long) - Method in class org.apache.flink.runtime.jobmaster.JobResult.Builder
 
NettyBufferPool - Class in org.apache.flink.runtime.io.network.netty
Extends around Netty's PooledByteBufAllocator with 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 - 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() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
NettyConnectionManager - Class in org.apache.flink.runtime.io.network.netty
 
NettyConnectionManager(NettyConfig) - Constructor for class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
 
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
 
NettyProtocol - Class in org.apache.flink.runtime.io.network.netty
Defines the server and client channel handlers, i.e.
NetworkBuffer - Class in org.apache.flink.runtime.io.network.buffer
Wrapper for pooled MemorySegment instances.
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, boolean) - 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, 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 writerIndex.
NetworkBufferPool - Class in org.apache.flink.runtime.io.network.buffer
The NetworkBufferPool is a fixed size pool of MemorySegment instances for the network stack.
NetworkBufferPool(int, int) - Constructor for class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
Allocates all MemorySegment instances managed by this pool.
networkBufferSize() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
networkBuffersPerChannel() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
networkBufFraction() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
networkBufMax() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
networkBufMin() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
NetworkClientHandler - Interface in org.apache.flink.runtime.io.network
Channel handler to read and write network messages on client side.
NetworkEnvironment - Class in org.apache.flink.runtime.io.network
Network I/O components of each TaskManager instance.
NetworkEnvironment(NetworkBufferPool, ConnectionManager, ResultPartitionManager, TaskEventDispatcher, KvStateRegistry, KvStateServer, KvStateClientProxy, IOManager.IOMode, int, int, int, int, boolean) - Constructor for class org.apache.flink.runtime.io.network.NetworkEnvironment
 
NetworkEnvironmentConfiguration - Class in org.apache.flink.runtime.taskmanager
Configuration object for the network stack.
NetworkEnvironmentConfiguration(float, long, long, int, IOManager.IOMode, int, int, int, int) - Constructor for class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
Constructor for a setup with purely local communication (no netty).
NetworkEnvironmentConfiguration(float, long, long, int, IOManager.IOMode, int, int, int, int, NettyConfig) - Constructor for class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
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.
newBuilder() - Static method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
newBuilder() - Static method in class org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay
 
newBuilder() - Static method in class org.apache.flink.runtime.clusterframework.overlays.HadoopConfOverlay
 
newBuilder() - Static method in class org.apache.flink.runtime.clusterframework.overlays.HadoopUserOverlay
 
newBuilder() - Static method in class org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay
 
newBuilder() - Static method in class org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay
 
newBuilder() - Static method in class org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay
 
newDynamicPropertiesOption() - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
Get an instance of the dynamic properties option.
newInstanceAvailable(Instance) - Method in interface org.apache.flink.runtime.instance.InstanceListener
Called when a new instance becomes available.
newInstanceAvailable(Instance) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
NewLeaderAvailable - Class in org.apache.flink.runtime.clusterframework.messages
Message sent to the Flink resource manager to indicate that a new leader is available.
NewLeaderAvailable(String, UUID) - Constructor for class org.apache.flink.runtime.clusterframework.messages.NewLeaderAvailable
 
newSlotAvailable(Instance) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
newSlotAvailable(Instance) - Method in interface org.apache.flink.runtime.jobmanager.scheduler.SlotAvailabilityListener
 
newThread(Runnable) - Method in class org.apache.flink.runtime.highavailability.ServicesThreadFactory
 
newThread(Runnable) - Method in class org.apache.flink.runtime.taskmanager.DispatcherThreadFactory
 
newThread(Runnable) - Method in class org.apache.flink.runtime.util.ExecutorThreadFactory
 
next(E) - Method in class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
 
next() - Method in class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
 
next(E) - Method in class org.apache.flink.runtime.io.disk.InputViewIterator
 
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(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() - 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(BT) - Method in class org.apache.flink.runtime.iterative.io.HashPartitionIterator
 
next() - Method in class org.apache.flink.runtime.iterative.io.HashPartitionIterator
 
next() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable.SimpleIterator
 
next(T) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable.EntryIterator
 
next() - 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() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.EntryIterator
 
next(BT) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.HashBucketIterator
 
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(BT) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.UnmatchedBuildIterator
 
next() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.UnmatchedBuildIterator
 
next(T) - Method in class org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
 
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(T) - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
next() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
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 TypeSerializer provided to this iterator.
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 TypeSerializer provided 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(IN) - Method in class org.apache.flink.runtime.operators.util.metrics.CountingMutableObjectIterator
 
next() - Method in class org.apache.flink.runtime.operators.util.metrics.CountingMutableObjectIterator
 
next(T) - Method in class org.apache.flink.runtime.operators.util.ReaderIterator
 
next() - Method in class org.apache.flink.runtime.operators.util.ReaderIterator
 
next() - Method in class org.apache.flink.runtime.util.EmptyIterator
Always throws a NoSuchElementException.
next(E) - Method in class org.apache.flink.runtime.util.EmptyMutableObjectIterator
Always returns null.
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(T) - Method in class org.apache.flink.runtime.util.RegularToMutableObjectIterator
 
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
 
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.
nextBufferIsEvent() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition.BufferAndBacklog
 
nextBufferIsEvent() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
Returns whether the next buffer is an event or not.
nextElement - Variable in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
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
 
nextRecord() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
nextSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.FileChannelInputView
 
nextSegment(MemorySegment, int) - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
 
nextSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
Gets the next segment from the asynchronous block reader.
nextSegment(MemorySegment, int) - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
 
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, int) - Method in class org.apache.flink.runtime.io.disk.RandomAccessOutputView
 
nextSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
 
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) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
The method by which concrete subclasses realize page crossing.
nextSegment(MemorySegment, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
This method must return a segment.
nextSegment() - Method in class org.apache.flink.runtime.memory.ListMemorySegmentSource
 
nextSegment(MemorySegment, int) - Method in class org.apache.flink.runtime.operators.hash.HashPartition.BuildSideBuffer
 
nextSegment(MemorySegment) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
 
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.
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_ALLOCATION_ID - Static variable in class org.apache.flink.runtime.instance.Slot
 
NO_CURRENT_KEY_GROUP - Static variable in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
 
NO_OFFSET_SET - Static variable in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
 
NO_SLOT_REQUEST_ID - Static variable in class org.apache.flink.runtime.instance.Slot
 
NO_SLOT_SHARING_GROUP_ID - Static variable in class org.apache.flink.runtime.instance.Slot
 
NO_STRINGS - Static variable in class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
 
NO_VALUES - Static variable in class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
 
nodeChanged() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
nodeChanged() - Method in class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
 
noLocality(ResourceProfile) - Static method in class org.apache.flink.runtime.clusterframework.types.SlotProfile
Returns a slot profile for the given resource profile, without any locality requirements.
noMoreBlocks - Variable in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
nonBlockingShutDown(long, TimeUnit, ActorRef...) - Static method in class org.apache.flink.runtime.akka.ActorUtils
Shuts the given Actor down in a non blocking fashion.
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(CheckpointStreamFactory.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
 
NonClosingOutpusStreamDecorator - Class in org.apache.flink.runtime.util
Decorator for input streams that ignores calls to OutputStream.close().
NonClosingOutpusStreamDecorator(OutputStream) - Constructor for class org.apache.flink.runtime.util.NonClosingOutpusStreamDecorator
 
none() - Static method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
 
NonOffloaded() - Constructor for class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.NonOffloaded
 
NonOffloaded(SerializedValue<T>) - Constructor for class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.NonOffloaded
 
NonPersistentMetadataCheckpointStorageLocation - Class in org.apache.flink.runtime.state.memory
A checkpoint storage location for the MemoryStateBackend in case no durable persistence for metadata has been configured.
NonPersistentMetadataCheckpointStorageLocation(int) - Constructor for class org.apache.flink.runtime.state.memory.NonPersistentMetadataCheckpointStorageLocation
 
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 JoinTaskIterator that 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 JoinTaskIterator that 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 DeserializationDelegate that 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 MutableObjectIterator into a regular Iterator.
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
 
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
 
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
 
NoOpMetricRegistry - Class in org.apache.flink.runtime.metrics
Metric registry which does nothing.
NoOpTaskLocalStateStoreImpl - Class in org.apache.flink.runtime.state
This class implements a TaskLocalStateStore with no functionality and is used when local recovery is disabled.
noRequirements() - Static method in class org.apache.flink.runtime.clusterframework.types.SlotProfile
Returns a slot profile that has no requirements.
NoResourceAvailableException - Exception in org.apache.flink.runtime.jobmanager.scheduler
 
NoResourceAvailableException() - Constructor for exception org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
 
NoResourceAvailableException(ScheduledUnit) - Constructor for exception org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
 
NoResourceAvailableException(int, int, int) - 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
 
NoRestartStrategy - Class in org.apache.flink.runtime.executiongraph.restart
Restart strategy which does not restart an ExecutionGraph.
NoRestartStrategy() - Constructor for class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
 
NoRestartStrategy.NoRestartStrategyFactory - Class in org.apache.flink.runtime.executiongraph.restart
 
NoRestartStrategyFactory() - Constructor for class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy.NoRestartStrategyFactory
 
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
 
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 404 return code.
NotFoundException(String) - Constructor for exception org.apache.flink.runtime.rest.NotFoundException
 
NotFoundException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rest.NotFoundException
 
NotificationListener - Interface in org.apache.flink.runtime.util.event
 
notifyAllocationFailure(AllocationID, Exception) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
notifyAllocationFailure(AllocationID, Exception) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Notifies that the allocation has failed.
notifyAllocationFailure(JobID, AllocationID, Exception) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ResourceActions
Notifies that an allocation failure has occurred.
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.RemoteInputChannel
The Buffer pool notifies this channel 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.RemoteInputChannel
 
notifyChannelNonEmpty() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
Notifies the owning SingleInputGate that this channel became non-empty.
notifyCheckpointComplete(long, long) - Method in class org.apache.flink.runtime.executiongraph.Execution
Notify the task of this execution about a completed checkpoint.
notifyCheckpointComplete(long) - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Invoked when a checkpoint has been completed, i.e., when the checkpoint coordinator has received the notification from all participating tasks.
notifyCheckpointComplete(ExecutionAttemptID, JobID, long, long) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
notifyCheckpointComplete(ExecutionAttemptID, JobID, long, long) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Notify the given task about a completed checkpoint.
notifyCheckpointComplete(ExecutionAttemptID, JobID, long, long) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
NotifyCheckpointComplete - Class in org.apache.flink.runtime.messages.checkpoint
This message is sent from the JobManager to the TaskManager to tell a task that the checkpoint has been confirmed and that the task can commit the checkpoint to the outside world.
NotifyCheckpointComplete(JobID, ExecutionAttemptID, long, long) - Constructor for class org.apache.flink.runtime.messages.checkpoint.NotifyCheckpointComplete
 
notifyCheckpointComplete(long) - Method in interface org.apache.flink.runtime.state.CheckpointListener
This method is called as a notification once a distributed checkpoint has been completed.
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 disposed.
notifyCheckpointComplete(long) - Method in class org.apache.flink.runtime.taskmanager.Task
 
notifyCreditAvailable(RemoteInputChannel) - Method in class org.apache.flink.runtime.io.network.netty.PartitionRequestClient
 
notifyCreditAvailable(RemoteInputChannel) - Method in interface org.apache.flink.runtime.io.network.NetworkClientHandler
The credit begins to announce after receiving the sender's backlog from buffer response.
notifyDataAvailable() - Method in interface org.apache.flink.runtime.io.network.partition.BufferAvailabilityListener
Called whenever there might be new data available.
notifyDataAvailable() - Method in class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
 
notifyDataAvailable() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
 
notifyFatalError(String, Throwable) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayTaskManagerActions
 
notifyFatalError(String, Throwable) - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerActions
Notifies the task manager about a fatal error occurred in the task.
notifyFinalState(ExecutionAttemptID) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayTaskManagerActions
 
notifyFinalState(ExecutionAttemptID) - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerActions
Notifies the task manager that the given task is in a final state.
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.
notifyInfoMessage(InfoMessage) - Method in interface org.apache.flink.runtime.resourcemanager.InfoMessageListenerRpcGateway
Notifies when resource manager need to notify listener about InfoMessage
notifyInputGateNonEmpty(InputGate) - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGateListener
Notification callback if the input gate moves from zero to non-zero available input channels with data.
notifyInputGateNonEmpty(InputGate) - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
notifyJobTimeout(JobID, UUID) - Method in interface org.apache.flink.runtime.resourcemanager.JobLeaderIdActions
Notify a job timeout.
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(JobVertexID, KeyGroupRange, String, KvStateID, InetSocketAddress) - Method in class org.apache.flink.runtime.query.KvStateLocationRegistry
Notifies the registry about a registered KvState instance.
NotifyKvStateRegistered(JobID, JobVertexID, KeyGroupRange, String, KvStateID, InetSocketAddress) - Constructor for class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
Notifies the JobManager about a registered InternalKvState instance.
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) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayKvStateRegistryListener
 
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(JobVertexID, KeyGroupRange, String) - Method in class org.apache.flink.runtime.query.KvStateLocationRegistry
Notifies the registry about an unregistered KvState instance.
NotifyKvStateUnregistered(JobID, JobVertexID, KeyGroupRange, String) - Constructor for class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
Notifies the JobManager about an unregistered InternalKvState instance.
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.taskexecutor.rpc.RpcKvStateRegistryListener
 
notifyKvStateUnregistered(JobID, JobVertexID, KeyGroupRange, String) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayKvStateRegistryListener
 
notifyLeaderAddress(String, UUID) - Method in class org.apache.flink.runtime.client.JobClientActor
 
notifyLeaderAddress(String, UUID) - Method in interface org.apache.flink.runtime.leaderretrieval.LeaderRetrievalListener
This method is called by the LeaderRetrievalService when a new leader is elected.
notifyLeaderAddress(String, UUID) - Method in class org.apache.flink.runtime.minicluster.OneTimeLeaderListenerFuture
 
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.LeaderConnectionInfoListener
 
notifyLeaderAddress(String, UUID) - Method in class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderGatewayListener
 
notifyLeaderAddress(String, UUID) - Method in class org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
 
notifyListener(String, UUID) - Method in class org.apache.flink.runtime.leaderretrieval.SettableLeaderRetrievalService
 
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
 
notifyNewVertices(List<ExecutionJobVertex>) - Method in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategy
Called whenever new vertices are added to the ExecutionGraph.
notifyNewVertices(List<ExecutionJobVertex>) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy
 
notifyNewVertices(List<ExecutionJobVertex>) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
 
notifyNewVertices(List<ExecutionJobVertex>) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
 
notifyOfAddedMetric(ActorRef, Metric, String, AbstractMetricGroup) - Static method in class org.apache.flink.runtime.metrics.dump.MetricQueryService
Utility method to notify a MetricQueryService of an added metric.
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).
notifyOfRemovedMetric(ActorRef, Metric) - Static method in class org.apache.flink.runtime.metrics.dump.MetricQueryService
Utility method to notify a MetricQueryService of a removed metric.
notifyOfRemovedView(View) - Method in class org.apache.flink.runtime.metrics.ViewUpdater
Notifies this ViewUpdater of a metric that should no longer be regularly updated.
notifyPartitionConsumable(JobID, ResultPartitionID, TaskActions) - Method in interface org.apache.flink.runtime.io.network.partition.ResultPartitionConsumableNotifier
 
notifyPartitionConsumable(JobID, ResultPartitionID, TaskActions) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcResultPartitionConsumableNotifier
 
notifyPartitionConsumable(JobID, ResultPartitionID, TaskActions) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayResultPartitionConsumableNotifier
 
NotifyResourceStarted - Class in org.apache.flink.runtime.clusterframework.messages
Notifies the ResourceManager that a TaskManager has been started in a container with the given resource id.
NotifyResourceStarted(ResourceID) - Constructor for class org.apache.flink.runtime.clusterframework.messages.NotifyResourceStarted
 
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.
notifySolutionSetUpdate() - Method in class org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrier
Releases the waiting thread.
notifySubpartitionConsumed() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
 
notifySubpartitionConsumed() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
 
notifyTaskExecutionStateChanged(TaskExecutionState) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayTaskExecutionStateListener
 
notifyTaskExecutionStateChanged(TaskExecutionState) - Method in interface org.apache.flink.runtime.taskmanager.TaskExecutionStateListener
Called whenever the task's execution state changes
notifyTimeout(AllocationID, UUID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
 
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.
notifyWorkerFailed(ResourceID, String) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
This method should be called by the framework once it detects that a currently registered worker has failed.
notLeader() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
NUM_ARENAS - Static variable in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
NUM_THREADS_CLIENT - Static variable in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
NUM_THREADS_SERVER - Static variable in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
NumberOfFullRestartsGauge - Class in org.apache.flink.runtime.executiongraph.metrics
Gauge which returns the number of full restarts.
NumberOfFullRestartsGauge(ExecutionGraph) - Constructor for class org.apache.flink.runtime.executiongraph.metrics.NumberOfFullRestartsGauge
 
numberOfKeyGroups - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
The number of key-groups aka max parallelism
numberOfWorkers() - Method in class org.apache.flink.runtime.clusterframework.messages.SetWorkerPoolSize
 
numBuckets - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The number of buckets in the current table.
numBytesIn - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
 
numBytesInLocal - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
 
numBytesInLocalPerSecond - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
 
numBytesInRemote - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
 
numBytesInRemotePerSecond - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
 
numBytesOut - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
 
numBytesOutPerSecond - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
 
numCounters - Variable in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
 
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
 
numMeters - Variable in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
 
numOverflowSegments - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
 
numOverflowSegments - Variable in class org.apache.flink.runtime.operators.hash.InMemoryPartition
 
numProxyQueryThreads() - Method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
Returns the number of threads for the thread pool that performs the actual state lookup.
numProxyServerThreads() - Method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
Returns the number of threads for the query server NIO event loop.
numRecordsIn - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
 
numRecordsIn - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
numRecordsInPerSecond - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
 
numRecordsOut - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
 
numRecordsOut - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
numRecordsOutPerSecond - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
 
numRegisteredJobMetricGroups() - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
numRegisteredJobMetricGroups() - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
numRegisteredTaskManagers() - Method in class org.apache.flink.runtime.clusterframework.messages.GetClusterStatusResponse
 
numRequestsRemaining - Variable in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
 
numSlots() - Method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
 
numStateEntries() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
Returns the total number of state entries across all keys/namespaces.
numStateEntries() - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
Returns the total number of state entries across all keys/namespaces.
numStateEntries(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.
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.
numTargetKeyGroups - Variable in class org.apache.flink.runtime.io.network.partition.ResultPartition
 
numWriteBuffersToCluster - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 

O

objectReuseEnabled - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
objectReuseEnabled - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Whether to reuse objects during deserialization.
occupySlot() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
of(int, OperatorID) - Static method in class org.apache.flink.runtime.jobgraph.OperatorInstanceID
 
of(TriggerId, JobID) - Static method in class org.apache.flink.runtime.rest.handler.job.AsynchronousJobOperationKey
 
of(OperatorBackPressureStats) - Static method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStatsResponse
 
of(T) - Static method in class org.apache.flink.runtime.state.DoneFuture
 
of(int, int) - Static method in class org.apache.flink.runtime.state.KeyGroupRange
Factory method that also handles creation of empty key-groups.
of(T) - Static method in class org.apache.flink.runtime.state.SnapshotResult
 
offer(E) - Method in class org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
 
offer(E) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
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()).
offerSlot(TaskManagerLocation, TaskManagerGateway, SlotOffer) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
Slot offering by TaskExecutor with AllocationID.
offerSlot(TaskManagerLocation, TaskManagerGateway, SlotOffer) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolGateway
Offers a slot to the SlotPool.
offerSlots(ResourceID, Collection<SlotOffer>, Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
offerSlots(ResourceID, Collection<SlotOffer>, Time) - 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.SlotPool
 
offerSlots(TaskManagerLocation, TaskManagerGateway, Collection<SlotOffer>) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolGateway
Offers multiple slots to the SlotPool.
Offloaded() - Constructor for class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.Offloaded
 
Offloaded(PermanentBlobKey) - Constructor for class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.Offloaded
 
onAddedJobGraph(JobID) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
onAddedJobGraph(JobID) - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore.SubmittedJobGraphListener
Callback for SubmittedJobGraph instances added by a different SubmittedJobGraphStore instance.
onBuffer(Buffer, int, int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
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.
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
 
OneTimeLeaderListenerFuture - Class in org.apache.flink.runtime.minicluster
A leader listener that exposes a future for the first leader notification.
OneTimeLeaderListenerFuture() - Constructor for class org.apache.flink.runtime.minicluster.OneTimeLeaderListenerFuture
 
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
 
onExecutionFail(Execution, Throwable) - Method in class org.apache.flink.runtime.executiongraph.failover.FailoverRegion
 
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 class org.apache.flink.runtime.resourcemanager.ResourceManager
Notifies the ResourceManager that a fatal error has occurred and it cannot proceed.
onFatalError(Throwable) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRunner
 
onFatalError(Throwable) - Method in interface org.apache.flink.runtime.rpc.FatalErrorHandler
Being called when a fatal error occurs.
onFatalError(Throwable) - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
onNotification() - Method in interface org.apache.flink.runtime.util.event.NotificationListener
 
onReceive(Object) - Method in class org.apache.flink.runtime.akka.FlinkUntypedActor
This method is called by Akka if a new message has arrived for the actor.
onReceive(Object) - Method in class org.apache.flink.runtime.akka.QuarantineMonitor
 
onReceive(Object) - Method in class org.apache.flink.runtime.metrics.dump.MetricQueryService
 
onReceive(Object) - Method in class org.apache.flink.runtime.process.ProcessReaper
 
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 RegisteredRpcConnection when the registration fails.
onRegistrationFailure(Throwable) - 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 RegisteredRpcConnection when the registration is success.
onRegistrationSuccess(TaskExecutorRegistrationSuccess) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorToResourceManagerConnection
 
onRemovedJobGraph(JobID) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
onRemovedJobGraph(JobID) - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore.SubmittedJobGraphListener
Callback for SubmittedJobGraph instances removed by a different SubmittedJobGraphStore instance.
onTaskFailure(Execution, Throwable) - Method in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategy
Called by the execution graph when a task failure occurs.
onTaskFailure(Execution, Throwable) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy
 
onTaskFailure(Execution, Throwable) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
 
onTaskFailure(Execution, Throwable) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
 
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(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() - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
 
open() - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
 
open(MutableObjectIterator<BT>, MutableObjectIterator<PT>, boolean) - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
 
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.
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.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 interface org.apache.flink.runtime.state.StreamStateHandle
Returns an FSDataInputStream that 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.ChainedTerminationCriterionDriver
 
openTask() - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
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(Configuration) method.
OperationKey - Class in org.apache.flink.runtime.rest.handler.async
Any operation key for the AbstractAsynchronousOperationHandlers must extend this class.
OperationKey(TriggerId) - Constructor for class org.apache.flink.runtime.rest.handler.async.OperationKey
 
operationResultResponse(R) - Method in class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.StatusHandler
Create the operation result from the given value.
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(String) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointStatusHandler
 
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<RegisteredOperatorBackendStateMetaInfo.Snapshot<?>>, List<RegisteredBroadcastBackendStateMetaInfo.Snapshot<?, ?>>) - Constructor for class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
 
OperatorBackendStateMetaInfoReaderV1(ClassLoader) - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoReaderV1
 
OperatorBackendStateMetaInfoReaderV2(ClassLoader) - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoReaderV2
 
OperatorBackendStateMetaInfoSnapshotReaderWriters - Class in org.apache.flink.runtime.state
Readers and writers for different versions of the RegisteredOperatorBackendStateMetaInfo.Snapshot.
OperatorBackendStateMetaInfoSnapshotReaderWriters() - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters
 
OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractBroadcastStateMetaInfoReader<K,V> - Class in org.apache.flink.runtime.state
 
OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractBroadcastStateMetaInfoWriter<K,V> - Class in org.apache.flink.runtime.state
 
OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractOperatorBackendStateMetaInfoReader<S> - Class in org.apache.flink.runtime.state
 
OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractOperatorBackendStateMetaInfoWriter<S> - Class in org.apache.flink.runtime.state
 
OperatorBackendStateMetaInfoSnapshotReaderWriters.BroadcastStateMetaInfoReader<K,V> - Interface in org.apache.flink.runtime.state
 
OperatorBackendStateMetaInfoSnapshotReaderWriters.BroadcastStateMetaInfoReaderV3<K,V> - Class in org.apache.flink.runtime.state
 
OperatorBackendStateMetaInfoSnapshotReaderWriters.BroadcastStateMetaInfoWriter - Interface in org.apache.flink.runtime.state
 
OperatorBackendStateMetaInfoSnapshotReaderWriters.BroadcastStateMetaInfoWriterV3<K,V> - Class in org.apache.flink.runtime.state
 
OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoReader<S> - Interface in org.apache.flink.runtime.state
 
OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoReaderV1<S> - Class in org.apache.flink.runtime.state
 
OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoReaderV2<S> - Class in org.apache.flink.runtime.state
 
OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoWriter - Interface in org.apache.flink.runtime.state
 
OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoWriterV1<S> - Class in org.apache.flink.runtime.state
 
OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoWriterV2<S> - Class in org.apache.flink.runtime.state
 
OperatorBackendStateMetaInfoWriterV1(RegisteredOperatorBackendStateMetaInfo.Snapshot<S>) - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoWriterV1
 
OperatorBackendStateMetaInfoWriterV2(RegisteredOperatorBackendStateMetaInfo.Snapshot<S>) - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoWriterV2
 
OperatorBackPressureStats - Class in org.apache.flink.runtime.rest.handler.legacy.backpressure
Back pressure statistics of multiple tasks.
OperatorBackPressureStats(int, long, double[]) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
 
OperatorBackPressureStatsResponse - Class in org.apache.flink.runtime.rest.handler.legacy.backpressure
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
 
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
 
OperatorIOMetricGroup - Class in org.apache.flink.runtime.metrics.groups
Metric group that contains shareable pre-defined IO-related metrics.
OperatorIOMetricGroup(OperatorMetricGroup) - Constructor for class org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
 
OperatorMetricGroup - Class in org.apache.flink.runtime.metrics.groups
Special MetricGroup representing an Operator.
OperatorMetricGroup(MetricRegistry, TaskMetricGroup, OperatorID, String) - Constructor for class org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
 
operatorName - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
 
OperatorQueryScopeInfo(String, String, int, String) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
 
OperatorQueryScopeInfo(String, String, 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 OperatorMetricGroup.
OperatorScopeFormat(String, TaskScopeFormat) - Constructor for class org.apache.flink.runtime.metrics.scope.OperatorScopeFormat
 
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 sub tasks of an operator and therefore represents the complete state of a logical operator.
OperatorState(OperatorID, int, int) - Constructor for class org.apache.flink.runtime.checkpoint.OperatorState
 
OperatorStateBackend - Interface in org.apache.flink.runtime.state
Interface that combines both, the user facing OperatorStateStore interface and the system interface Snapshotable
OperatorStateCheckpointOutputStream - Class in org.apache.flink.runtime.state
Checkpoint output stream that allows to write raw operator state in a partitioned way.
OperatorStateCheckpointOutputStream(CheckpointStreamFactory.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 OperatorStreamStateHandle is assigned to tasks during restore.
OperatorStateHandle.StateMetaInfo - Class in org.apache.flink.runtime.state
Meta information about the operator state handle.
OperatorStateRepartitioner - Interface in org.apache.flink.runtime.checkpoint
Interface that allows to implement different strategies for repartitioning of operator state as parallelism changes.
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() - Constructor for class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
Empty state.
OperatorSubtaskState(StateObjectCollection<OperatorStateHandle>, StateObjectCollection<OperatorStateHandle>, StateObjectCollection<KeyedStateHandle>, StateObjectCollection<KeyedStateHandle>) - Constructor for class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
 
OperatorSubtaskState(OperatorStateHandle, OperatorStateHandle, KeyedStateHandle, KeyedStateHandle) - Constructor for class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
For convenience because the size of the collections is typically 0 or 1.
operatorSubtaskStateFrom(OperatorInstanceID, Map<OperatorInstanceID, List<OperatorStateHandle>>, Map<OperatorInstanceID, List<OperatorStateHandle>>, Map<OperatorInstanceID, List<KeyedStateHandle>>, Map<OperatorInstanceID, List<KeyedStateHandle>>) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
 
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.
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.akka - package org.apache.flink.runtime.akka
 
org.apache.flink.runtime.blob - package org.apache.flink.runtime.blob
 
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.decline - package org.apache.flink.runtime.checkpoint.decline
 
org.apache.flink.runtime.checkpoint.hooks - package org.apache.flink.runtime.checkpoint.hooks
 
org.apache.flink.runtime.checkpoint.savepoint - package org.apache.flink.runtime.checkpoint.savepoint
 
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.messages - package org.apache.flink.runtime.clusterframework.messages
This package contains the actor messages that are sent between the cluster resource framework and the JobManager, as well as the generic messages sent between the cluster resource framework and the client.
org.apache.flink.runtime.clusterframework.overlays - package org.apache.flink.runtime.clusterframework.overlays
 
org.apache.flink.runtime.clusterframework.standalone - package org.apache.flink.runtime.clusterframework.standalone
 
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.concurrent.akka - package org.apache.flink.runtime.concurrent.akka
 
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.entrypoint - package org.apache.flink.runtime.entrypoint
 
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.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.executiongraph.restart - package org.apache.flink.runtime.executiongraph.restart
 
org.apache.flink.runtime.filecache - package org.apache.flink.runtime.filecache
 
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.leaderelection - package org.apache.flink.runtime.highavailability.nonha.leaderelection
 
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.async - package org.apache.flink.runtime.io.async
 
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.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.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.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.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.exceptions - package org.apache.flink.runtime.jobmaster.exceptions
 
org.apache.flink.runtime.jobmaster.factories - package org.apache.flink.runtime.jobmaster.factories
 
org.apache.flink.runtime.jobmaster.message - package org.apache.flink.runtime.jobmaster.message
 
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 actors, like the JobManager and TaskManager 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 JobManager and TaskManager to 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.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.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.plugable - package org.apache.flink.runtime.plugable
 
org.apache.flink.runtime.process - package org.apache.flink.runtime.process
 
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.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.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.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.backpressure - package org.apache.flink.runtime.rest.handler.legacy.backpressure
 
org.apache.flink.runtime.rest.handler.legacy.checkpoints - package org.apache.flink.runtime.rest.handler.legacy.checkpoints
 
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.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.job - package org.apache.flink.runtime.rest.messages.job
 
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.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.rpc - package org.apache.flink.runtime.rpc
 
org.apache.flink.runtime.rpc.akka - package org.apache.flink.runtime.rpc.akka
 
org.apache.flink.runtime.rpc.akka.exceptions - package org.apache.flink.runtime.rpc.akka.exceptions
 
org.apache.flink.runtime.rpc.akka.messages - package org.apache.flink.runtime.rpc.akka.messages
 
org.apache.flink.runtime.rpc.exceptions - package org.apache.flink.runtime.rpc.exceptions
 
org.apache.flink.runtime.rpc.messages - package org.apache.flink.runtime.rpc.messages
 
org.apache.flink.runtime.security - package org.apache.flink.runtime.security
 
org.apache.flink.runtime.security.modules - package org.apache.flink.runtime.security.modules
 
org.apache.flink.runtime.state - package org.apache.flink.runtime.state
 
org.apache.flink.runtime.state.filesystem - package org.apache.flink.runtime.state.filesystem
 
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.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.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.util - package org.apache.flink.runtime.util
 
org.apache.flink.runtime.util.clock - package org.apache.flink.runtime.util.clock
 
org.apache.flink.runtime.util.event - package org.apache.flink.runtime.util.event
 
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.zookeeper - package org.apache.flink.runtime.zookeeper
 
org.apache.flink.runtime.zookeeper.filesystem - package org.apache.flink.runtime.zookeeper.filesystem
 
orTimeout(CompletableFuture<T>, long, TimeUnit) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
Times the given future out after the timeout.
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.
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, ...) and uses the supplied task index perform a round robin distribution.
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, ...) and uses the supplied comparator to hash / compare records for partitioning them deterministically.
OutputEmitter(ShipStrategyType, int, TypeComparator<T>, Partitioner<?>, DataDistribution) - Constructor for class org.apache.flink.runtime.operators.shipping.OutputEmitter
 
OutputFormatVertex - Class in org.apache.flink.runtime.jobgraph
A task vertex that run an initialization on the master, trying to deserialize an output format and initializing it on master, if necessary.
OutputFormatVertex(String) - Constructor for class org.apache.flink.runtime.jobgraph.OutputFormatVertex
Creates a new task vertex with the specified name.
overflowSegments - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
 
overflowSegments - Variable in class org.apache.flink.runtime.operators.hash.InMemoryPartition
 
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.

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
 
pairComparator - Variable in class org.apache.flink.runtime.operators.hash.AbstractHashTableProber
 
pairComparator - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
PARALLELISM_AUTO_MAX_ERROR_MESSAGE - Static variable in class org.apache.flink.runtime.executiongraph.ExecutionGraphBuilder
 
PARAMETER_JOB_ID - Static variable in class org.apache.flink.runtime.rest.handler.legacy.metrics.JobMetricsHandler
 
PARAMETER_METRICS - Static variable in class org.apache.flink.runtime.rest.handler.legacy.metrics.AbstractMetricsHandler
 
PARAMETER_SUBTASK_INDEX - Static variable in class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptDetailsHandler
 
PARAMETER_VERTEX_ID - Static variable in class org.apache.flink.runtime.rest.handler.legacy.metrics.JobVertexMetricsHandler
Deprecated.
 
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.OperatorMetricGroup
 
parent() - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
 
parent() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
parentFirst(URL[], ClassLoader) - Static method in class org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders
 
parentMetricGroup - Variable in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
parseArguments(String[]) - Static method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
parseDynamicProperties(CommandLine) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
Parse the dynamic properties (passed on the command line).
parseJobVertexId(Map<String, String>) - Static method in class org.apache.flink.runtime.rest.handler.legacy.AbstractJobVertexRequestHandler
Returns the job vertex ID parsed from the provided parameters.
PartialInputChannelDeploymentDescriptor - Class in org.apache.flink.runtime.deployment
Partial deployment descriptor for a single input channel instance.
PartialInputChannelDeploymentDescriptor(IntermediateDataSetID, ResultPartitionID, TaskManagerLocation, int) - Constructor for class org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor
 
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
 
partitionBuffers - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
 
PartitionException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
Exception indicating a problem with the result partitions on the TaskExecutor side.
PartitionException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.PartitionException
 
PartitionException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.PartitionException
 
PartitionException(Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.PartitionException
 
partitionId - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
 
PartitionInfo - Class in org.apache.flink.runtime.executiongraph
Contains information where to find a partition.
PartitionInfo(IntermediateDataSetID, InputChannelDeploymentDescriptor) - Constructor for class org.apache.flink.runtime.executiongraph.PartitionInfo
 
PartitionNotFoundException - Exception in org.apache.flink.runtime.io.network.partition
 
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 JobManagerMessages.RequestPartitionProducerState 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.io.network.netty
Intermediate partition state checker to query the JobManager about the state of the producer of a result partition.
PartitionRequestClient - Class in org.apache.flink.runtime.io.network.netty
Partition request client for remote partition requests.
partitionRequestInitialBackoff() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
partitionRequestMaxBackoff() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
partitionsBeingBuilt - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The partitions that are built by processing the current partition.
path() - Method in interface org.apache.flink.runtime.instance.ActorGateway
Returns the path of the remote instance.
path() - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
Returns the ActorPath of the remote instance.
pathToCheckpointId(String) - Static method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
Converts a path to the checkpoint id.
peek() - Method in class org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
 
peek() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
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.
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, Map<ExecutionAttemptID, ExecutionVertex>, CheckpointProperties, CheckpointStorageLocation, Executor) - Constructor for class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
PendingCheckpoint.TaskAcknowledgeResult - Enum in org.apache.flink.runtime.checkpoint
PendingCheckpointStatistics(long, CheckpointStatsStatus, boolean, long, long, long, long, long, int, int, 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.
PendingSlotRequest - Class in org.apache.flink.runtime.resourcemanager.slotmanager
 
PendingSlotRequest(SlotRequest) - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
PendingSubtaskCheckpointStatistics(int) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.PendingSubtaskCheckpointStatistics
 
performOperation() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
Implements the actual operation.
performSnapshot(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 CheckpointStreamFactory and returns a @RunnableFuture that gives a state handle to the snapshot.
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() after SnapshotDirectory.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, 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.
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).
PersistentMetadataCheckpointStorageLocation - Class in org.apache.flink.runtime.state.memory
A checkpoint storage location for the MemoryStateBackend when 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.
PIPELINED_REGION_RESTART_STRATEGY_NAME - Static variable in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategyLoader
Config name for the RestartPipelinedRegionStrategy
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
 
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() - Constructor for class org.apache.flink.runtime.state.PlaceholderStreamStateHandle
 
poll() - Method in class org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
 
poll() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
poll() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
Removes and returns the least element of the PriorityQueue in log(size) time.
pollNextBufferOrEvent() - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGate
Poll the BufferOrEvent.
pollNextBufferOrEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
pollNextBufferOrEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
postStop() - Method in class org.apache.flink.runtime.client.JobClientActor
 
postStop() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
 
postStop() - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
postStop() - Method in class org.apache.flink.runtime.jobmaster.JobMaster
Suspend the job and shutdown all other services including rpc.
postStop() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
 
postStop() - Method in class org.apache.flink.runtime.metrics.dump.MetricQueryService
 
postStop() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
postStop() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
User overridable callback.
postStop() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
Called to shut down the TaskManager.
preferredLocality(ResourceProfile, Collection<TaskManagerLocation>) - Static method in class org.apache.flink.runtime.clusterframework.types.SlotProfile
Returns a slot profile for the given resource profile and the preferred locations.
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
 
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
 
preStart() - Method in class org.apache.flink.runtime.akka.QuarantineMonitor
 
preStart() - Method in class org.apache.flink.runtime.client.JobClientActor
 
preStart() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
 
PreviousAllocationSchedulingStrategy - Class in org.apache.flink.runtime.jobmaster.slotpool
SchedulingStrategy which tries to match a slot with its previous AllocationID.
PrimaryAndSecondaryStream(CheckpointStreamFactory.CheckpointStateOutputStream, CheckpointStreamFactory.CheckpointStateOutputStream) - Constructor for class org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryAndSecondaryStream
 
PrimaryStreamOnly(CheckpointStreamFactory.CheckpointStateOutputStream) - Constructor for class org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryStreamOnly
 
priorAllocation(ResourceProfile, Collection<AllocationID>) - Static method in class org.apache.flink.runtime.clusterframework.types.SlotProfile
Returns a slot profile for the given resource profile and the prior allocations.
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 OperatorSubtaskState that 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
 
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(K, S) - Method in class org.apache.flink.runtime.state.KeyedStateFunction
The actual method to be applied on each of the states.
processExitCode() - Method in enum org.apache.flink.runtime.clusterframework.ApplicationStatus
Gets the process exit code associated with this status
Processing - Enum in org.apache.flink.runtime.rpc.akka.messages
Controls the processing behaviour of the AkkaRpcActor
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
 
processProbeIter() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
ProcessReaper - Class in org.apache.flink.runtime.process
Utility actors that monitors other actors and kills the JVM upon actor termination.
ProcessReaper(ActorRef, Logger, int) - Constructor for class org.apache.flink.runtime.process.ProcessReaper
 
ProcessShutDownThread - Class in org.apache.flink.runtime.util
JVM shut down thread awaiting actor system shut down for a certain amount of time before exiting the JVM.
ProcessShutDownThread(Logger, ActorSystem, Duration) - Constructor for class org.apache.flink.runtime.util.ProcessShutDownThread
Creates a shut down thread.
processUnmatchedBuildIter() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
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.
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
 
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 EventListener instances.
pushDownPages() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
 
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(ArchivedExecutionGraph) - Method in interface org.apache.flink.runtime.dispatcher.ArchivedExecutionGraphStore
Store the given ArchivedExecutionGraph in the store.
put(ArchivedExecutionGraph) - Method in class org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
 
put(ArchivedExecutionGraph) - Method in class org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
 
put(A, B, V) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
put(T) - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
Adds a buffer to a PriorityQueue in log(size) time.
put(K, int, N, S) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
put(N, S) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
put(UK, UV) - Method in class org.apache.flink.runtime.state.heap.HeapMapState
 
put(N, S) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
put(K, int, N, S) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
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(K, int, N, S) - Method in class org.apache.flink.runtime.state.heap.StateTable
 
put(K, V) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
 
put(JobID, JobManagerConnection) - Method in class org.apache.flink.runtime.taskexecutor.JobManagerTable
 
putAll(Map<UK, UV>) - Method in class org.apache.flink.runtime.state.heap.HeapMapState
 
putAll(Map<K, V>) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
 
putAndGetOld(N, S) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
putAndGetOld(N, S) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
putAndGetOld(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.
putJobGraph(SubmittedJobGraph) - Method in class org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
 
putJobGraph(SubmittedJobGraph) - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
 
putJobGraph(SubmittedJobGraph) - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
Adds the SubmittedJobGraph instance.
putJobGraph(SubmittedJobGraph) - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
 
putPermanent(JobID, byte[]) - Method in class org.apache.flink.runtime.blob.BlobServer
 
putPermanent(JobID, InputStream) - 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, 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, byte[]) - Method in class org.apache.flink.runtime.blob.VoidBlobWriter
 
putPermanent(JobID, InputStream) - Method in class org.apache.flink.runtime.blob.VoidBlobWriter
 
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(JobID, byte[]) - Method in class org.apache.flink.runtime.blob.BlobServer
 
putTransient(InputStream) - Method in class org.apache.flink.runtime.blob.BlobServer
 
putTransient(JobID, InputStream) - Method in class org.apache.flink.runtime.blob.BlobServer
 
putTransient(byte[]) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
 
putTransient(JobID, byte[]) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
 
putTransient(InputStream) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
 
putTransient(JobID, InputStream) - 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(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(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, 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 AbstractMetricGroup and 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.JobManagerMetricGroup
 
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.OperatorMetricGroup
 
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

QuarantineHandler - Interface in org.apache.flink.runtime.akka
Callback interface for the QuarantineMonitor which is called in case the actor system has been quarantined or quarantined another system.
QuarantineMonitor - Class in org.apache.flink.runtime.akka
The quarantine monitor subscribes to the event bus of the actor system in which it was started.
QuarantineMonitor(QuarantineHandler, Logger) - Constructor for class org.apache.flink.runtime.akka.QuarantineMonitor
 
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
 
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
 
queryMetrics(Time) - Method in class org.apache.flink.runtime.webmonitor.retriever.impl.AkkaQueryServiceGateway
 
queryMetrics(Time) - Method in interface org.apache.flink.runtime.webmonitor.retriever.MetricQueryServiceGateway
 
QueryScopeInfo - Class in org.apache.flink.runtime.metrics.dump
Container for scope related information as required by the MetricQueryService.
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.
queues - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
The queue of empty buffer that can be used for reading;
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 RequestDoneCallback that 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
 

R

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 channel.
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
 
rate - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.MeterDump
 
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
 
reacceptRegisteredWorkers(Collection<ResourceID>) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
This method is called when the resource manager starts after a failure and reconnects to the leader JobManager, who still has some workers registered.
reacceptRegisteredWorkers(Collection<ResourceID>) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
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(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.EndOfPartitionEvent
 
read(DataInputView) - Method in class org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
 
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(byte[]) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
read(byte[], int, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
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() - Method in class org.apache.flink.runtime.state.BoundedInputStream
 
read(byte[]) - Method in class org.apache.flink.runtime.state.BoundedInputStream
 
read(byte[], int, int) - Method in class org.apache.flink.runtime.state.BoundedInputStream
 
read(DataInputView) - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
read(DataInputView) - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
 
read() - Method in class org.apache.flink.runtime.util.ForwardingInputStream
 
read(byte[]) - Method in class org.apache.flink.runtime.util.ForwardingInputStream
 
read(byte[], int, int) - Method in class org.apache.flink.runtime.util.ForwardingInputStream
 
readableBytes() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
Returns the number of readable bytes (same as Buffer.getSize() - Buffer.getReaderIndex()).
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
 
readBroadcastStateMetaInfo(DataInputView) - Method in interface org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.BroadcastStateMetaInfoReader
 
readBroadcastStateMetaInfo(DataInputView) - Method in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.BroadcastStateMetaInfoReaderV3
 
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.
readByte() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
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
 
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.
ReaderIterator<T> - Class in org.apache.flink.runtime.operators.util
A MutableObjectIterator that 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.
readFloat() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
readFully(byte[]) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
readFully(byte[], int, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
ReadingThread(ExceptionHandler<IOException>, MutableObjectIterator<E>, UnilateralSortMerger.CircularQueues<E>, LargeRecordHandler<E>, E, AbstractInvokable, long) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ReadingThread
Creates a new reading thread.
readInt() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
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
 
readLine() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
readLong() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
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.
readOnlySlice(int, int) - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
Returns a read-only slice of this buffer.
readOnlySlice() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
readOnlySlice(int, int) - 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 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 Buffer implementation wrapping a NetworkBuffer's sub-region based on io.netty.buffer.SlicedByteBuf and io.netty.buffer.ReadOnlyByteBuf.
readOperatorStateMetaInfo(DataInputView) - Method in interface org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoReader
 
readOperatorStateMetaInfo(DataInputView) - Method in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoReaderV1
 
readOperatorStateMetaInfo(DataInputView) - Method in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoReaderV2
 
readPhase - Variable in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
readRecordAt(long, T) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
 
readRecordAt(long) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
 
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
 
readStateMetaInfo(DataInputView) - Method in interface org.apache.flink.runtime.state.KeyedBackendStateMetaInfoSnapshotReaderWriters.KeyedBackendStateMetaInfoReader
 
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
 
readWriteLock - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
Lock guarding concurrent file accesses.
receiveAcknowledgeMessage(AcknowledgeCheckpoint) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Receives an AcknowledgeCheckpoint message and returns whether the message was associated with a pending checkpoint.
receiveDeclineMessage(DeclineCheckpoint) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Receives a DeclineCheckpoint message for a pending checkpoint.
receiveHeartbeat(ResourceID, I) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
 
receiveHeartbeat(ResourceID, I) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatTarget
Sends a heartbeat response to the target.
reconnect(JobID) - Method in class org.apache.flink.runtime.taskexecutor.JobLeaderService
Triggers reconnection to the last known leader of the given job.
ReconnectResourceManager - Class in org.apache.flink.runtime.clusterframework.messages
This message signals that the ResourceManager should reconnect to the JobManager.
ReconnectResourceManager(ActorRef, long) - Constructor for class org.apache.flink.runtime.clusterframework.messages.ReconnectResourceManager
 
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.
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.
RecordSerializer<T extends org.apache.flink.core.io.IOReadableWritable> - Interface in org.apache.flink.runtime.io.network.api.serialization
Interface for turning records into sequences of memory segments.
RecordSerializer.SerializationResult - Enum in org.apache.flink.runtime.io.network.api.serialization
Status of the serialization result.
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
 
RecordWriter<T extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.writer
A record-oriented runtime result writer.
RecordWriter(ResultPartitionWriter) - Constructor for class org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
RecordWriter(ResultPartitionWriter, ChannelSelector<T>) - Constructor for class org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
RecordWriter(ResultPartitionWriter, ChannelSelector<T>, boolean) - Constructor for class org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
recover() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
Recover available CompletedCheckpoint instances.
recover() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
recover() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
Gets the latest checkpoint from ZooKeeper and removes all others.
recoverJobGraph(JobID) - Method in class org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
 
recoverJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
 
recoverJobGraph(JobID) - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
Returns the SubmittedJobGraph with the given JobID or null if no job was registered.
recoverJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
 
recursionLevel - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
 
recycle(MemorySegment) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferRecycler
Recycles the MemorySegment to its original BufferPool instance.
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.NetworkBufferPool
 
recycle(MemorySegment) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
Exclusive buffer is recycled to this input channel directly and it may trigger return extra floating buffer and notify increased credit to the producer.
recycleBuffer() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
Releases this buffer once, i.e.
recycleBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
recycleBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
recycleMemorySegments(List<MemorySegment>) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
RedirectHandler<T extends RestfulGateway> - Class in org.apache.flink.runtime.rest.handler
SimpleChannelInboundHandler which encapsulates the redirection logic for the REST endpoints.
RedirectHandler(CompletableFuture<String>, GatewayRetriever<? extends T>, Time, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.RedirectHandler
 
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
 
refresh() - Method in class org.apache.flink.runtime.security.DynamicConfiguration
 
register(Metric, String, AbstractMetricGroup) - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
Registers a new Metric with 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(Logger) - Static method in class org.apache.flink.runtime.util.SignalHandler
Register some signal handlers.
registerAll(Iterable<? extends CompositeStateHandle>) - Method in class org.apache.flink.runtime.state.SharedStateRegistry
Register given shared states in the registry.
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.
registerBufferPool(BufferPool) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
Registers a buffer pool with this result partition.
registerChannelToBeRemovedAtShudown(FileIOChannel.ID) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Adds a channel to the list of channels that are to be removed at shutdown.
registerConsumer() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
 
RegisteredBroadcastBackendStateMetaInfo<K,V> - Class in org.apache.flink.runtime.state
 
RegisteredBroadcastBackendStateMetaInfo(String, OperatorStateHandle.Mode, TypeSerializer<K>, TypeSerializer<V>) - Constructor for class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo
 
RegisteredBroadcastBackendStateMetaInfo(RegisteredBroadcastBackendStateMetaInfo<K, V>) - Constructor for class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo
 
RegisteredBroadcastBackendStateMetaInfo.Snapshot<K,V> - Class in org.apache.flink.runtime.state
A consistent snapshot of a RegisteredOperatorBackendStateMetaInfo.
RegisteredKeyedBackendStateMetaInfo<N,S> - Class in org.apache.flink.runtime.state
Compound meta information for a registered state in a keyed state backend.
RegisteredKeyedBackendStateMetaInfo(StateDescriptor.Type, String, TypeSerializer<N>, TypeSerializer<S>) - Constructor for class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
 
RegisteredKeyedBackendStateMetaInfo.Snapshot<N,S> - Class in org.apache.flink.runtime.state
A consistent snapshot of a RegisteredKeyedBackendStateMetaInfo.
RegisteredOperatorBackendStateMetaInfo<S> - Class in org.apache.flink.runtime.state
Compound meta information for a registered state in an operator state backend.
RegisteredOperatorBackendStateMetaInfo(String, TypeSerializer<S>, OperatorStateHandle.Mode) - Constructor for class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo
 
RegisteredOperatorBackendStateMetaInfo.Snapshot<S> - Class in org.apache.flink.runtime.state
A consistent snapshot of a RegisteredOperatorBackendStateMetaInfo.
registeredPartitions - Variable in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
RegisteredRpcConnection<F extends Serializable,G extends RpcGateway,S extends RegistrationResponse.Success> - 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
 
registerExecutionListener(ExecutionStatusListener) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
registerExecutionListener(TaskExecutionStateListener) - Method in class org.apache.flink.runtime.taskmanager.Task
 
RegisterInfoMessageListener - Class in org.apache.flink.runtime.clusterframework.messages
This message signals to the resource master to register the sender as an info message listener.
registerInfoMessageListener(String) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
Registers an info message listener.
registerInfoMessageListener(String) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Registers an infoMessage listener
RegisterInfoMessageListenerSuccessful - Class in org.apache.flink.runtime.clusterframework.messages
This message signals to the application client that the registration was successful.
registerJob(JobID) - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
Registers use of job-related BLOBs.
registerJob(JobID, Collection<PermanentBlobKey>, Collection<URL>) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
registerJob(JobID, Collection<PermanentBlobKey>, Collection<URL>) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
Registers a job with its required jar files and classpaths.
registerJobManager(JobMasterId, ResourceID, String, JobID, Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
registerJobManager(JobMasterId, ResourceID, String, JobID, Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Register a JobMaster at the resource manager.
registerJobStatusListener(JobStatusListener) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
registerKvState(KeyGroupRange, KvStateID, InetSocketAddress) - Method in class org.apache.flink.runtime.query.KvStateLocation
Registers a KvState instance for the given key group index.
registerKvState(JobID, JobVertexID, KeyGroupRange, String, InternalKvState<?, ?, ?>) - Method in class org.apache.flink.runtime.query.KvStateRegistry
Registers the KvState instance and returns the assigned ID.
registerKvState(KeyGroupRange, String, InternalKvState<?, ?, ?>) - Method in class org.apache.flink.runtime.query.TaskKvStateRegistry
Registers the KvState instance at the KvStateRegistry.
registerListener(InputGateListener) - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGate
 
registerListener(InputGateListener) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
registerListener(InputGateListener) - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
registerListener(JobID, KvStateRegistryListener) - Method in class org.apache.flink.runtime.query.KvStateRegistry
Registers a listener with the registry.
registerMetrics(MetricGroup) - Method in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategy
Tells the FailoverStrategy to register its metrics.
registerMetrics(MetricGroup) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
 
registerOngoingOperation(K, CompletableFuture<R>) - Method in class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.CompletedOperationCache
Registers an ongoing operation with the cache.
registerOpenChannelToBeRemovedAtShudown(FileIOChannel) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Adds a channel reader/writer to the list of channels that are to be removed at shutdown.
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).
registerQueueLengthMetrics(MetricGroup, SingleInputGate) - Static method in class org.apache.flink.runtime.io.network.partition.consumer.InputGateMetrics
 
registerQueueLengthMetrics(MetricGroup, ResultPartition) - Static method in class org.apache.flink.runtime.io.network.partition.ResultPartitionMetrics
 
registerReference(SharedStateRegistryKey, StreamStateHandle) - Method in class org.apache.flink.runtime.state.SharedStateRegistry
Register a reference to the given shared state in the registry.
RegisterResourceManager - Class in org.apache.flink.runtime.clusterframework.messages
This message signals that the resource manager wants to register at the JobManager leader.
RegisterResourceManager(ActorRef) - Constructor for class org.apache.flink.runtime.clusterframework.messages.RegisterResourceManager
 
RegisterResourceManagerSuccessful - Class in org.apache.flink.runtime.clusterframework.messages
Message that informs the resource manager that the JobManager accepted its registration.
RegisterResourceManagerSuccessful(ActorRef, Collection<ResourceID>) - Constructor for class org.apache.flink.runtime.clusterframework.messages.RegisterResourceManagerSuccessful
Creates a new message with a list of existing known TaskManagers.
registerResultPartition(ResultPartition) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.checkpoint.OperatorState
 
registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
 
registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
 
registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.checkpoint.TaskState
Deprecated.
 
registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
 
registerSharedStates(SharedStateRegistry) - Method in interface org.apache.flink.runtime.state.CompositeStateHandle
Register both newly created and already referenced shared states in the given SharedStateRegistry.
registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.state.DirectoryKeyedStateHandle
 
registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
 
registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
 
registerSharedStatesAfterRestored(SharedStateRegistry) - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
Register all shared states in the given registry.
registerShutdownActions(CompletableFuture<ApplicationStatus>) - Method in class org.apache.flink.runtime.entrypoint.JobClusterEntrypoint
 
registerSlotRequest(SlotRequest) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Requests a slot with the respective resource profile.
registerTask(JobID, ExecutionAttemptID, Collection<PermanentBlobKey>, Collection<URL>) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
registerTask(JobID, ExecutionAttemptID, Collection<PermanentBlobKey>, Collection<URL>) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
Registers a job task execution with its required jar files and classpaths.
registerTask(Task) - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
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(String, ResourceID, int, HardwareDescription, Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
registerTaskExecutor(String, ResourceID, int, HardwareDescription, Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Register a TaskExecutor at the resource manager.
registerTaskManager(TaskManagerGateway, TaskManagerLocation, HardwareDescription, int) - Method in class org.apache.flink.runtime.instance.InstanceManager
Registers a task manager.
registerTaskManager(String, TaskManagerLocation, Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
registerTaskManager(String, TaskManagerLocation, Time) - 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.SlotPool
Register TaskManager to this pool, only those slots come from registered TaskManager will be considered valid.
registerTaskManager(ResourceID) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolGateway
Registers a TaskExecutor with the given ResourceID at SlotPool.
registerTaskManager(TaskExecutorConnection, SlotReport) - Method in class 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.TimerService
Register a timeout for the given key which shall occur in the given delay.
RegistrationConnectionListener<T extends RegisteredRpcConnection<?,?,S>,S extends RegistrationResponse.Success> - Interface in org.apache.flink.runtime.registration
Classes which want to be notified about the registration result by the RegisteredRpcConnection have 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.Decline - 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 TaskExecutor could 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.
RegularToMutableObjectIterator<T> - Class in org.apache.flink.runtime.util
 
RegularToMutableObjectIterator(Iterator<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.util.RegularToMutableObjectIterator
 
relativeTimeMillis() - Method in class org.apache.flink.runtime.util.clock.Clock
 
relativeTimeMillis() - Method in class org.apache.flink.runtime.util.clock.SystemClock
 
relativeTimeNanos() - Method in class org.apache.flink.runtime.util.clock.Clock
 
relativeTimeNanos() - Method in class org.apache.flink.runtime.util.clock.SystemClock
 
release() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
 
release(Throwable) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
Releases the result partition.
release() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
release(Throwable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
A release of the payload by the AllocatedSlot triggers a release of the payload of the logical slot.
release(Throwable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.MultiTaskSlot
 
release(Throwable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.SingleTaskSlot
 
release(Throwable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.TaskSlot
Release the task slot.
release(MemorySegment) - Method in class org.apache.flink.runtime.memory.MemoryManager
Tries to release the memory for the specified segment.
release(Collection<MemorySegment>) - Method in class org.apache.flink.runtime.memory.MemoryManager
Tries to release many memory segments together.
release() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTableSnapshot
 
release(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Releases the lock from the node under the given ZooKeeper path.
releaseAll(Object) - Method in class org.apache.flink.runtime.memory.MemoryManager
Releases all memory segments for the given owner.
releaseAll() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Releases all lock nodes of this ZooKeeperStateHandleStore.
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.consumer.SingleInputGate
 
releaseAllResources() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
 
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.
releaseAndTryRemove(String, ZooKeeperStateHandleStore.RemoveCallback<T>) - 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.
releaseAndTryRemoveAll() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Releases all lock nodes of this ZooKeeperStateHandleStores and tries to remove all state nodes which are not locked anymore.
releaseBroadcastVariables(String, int, DistributedRuntimeUDFContext) - Method in class org.apache.flink.runtime.operators.BatchTask
 
releaseJob(JobID) - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
Unregisters use of job-related BLOBs and allow them to be released.
releaseLocalStateForAllocationId(AllocationID) - Method in class org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager
 
releaseMemory(int) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPoolOwner
 
releaseMemory(int) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
Releases buffers held by this result partition.
releasePartitionsProducedBy(ExecutionAttemptID) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
releasePartitionsProducedBy(ExecutionAttemptID, Throwable) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
releasePendingWorker(ResourceID) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Trigger a release of a pending worker.
releasePendingWorker(ResourceID) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
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(InstanceID, Exception) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
releaseResource(InstanceID, Exception) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ResourceActions
Releases the resource with the given instance id.
releaseResources() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
Releases resources acquired by this object.
releaseSlot(Throwable) - Method in class org.apache.flink.runtime.instance.SharedSlot
 
releaseSlot(Throwable) - Method in class org.apache.flink.runtime.instance.SimpleSlot
 
releaseSlot(Throwable) - Method in class org.apache.flink.runtime.instance.Slot
This method cancels and releases the slot and all its sub-slots.
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(SlotRequestId, SlotSharingGroupId, Throwable) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotActions
Releases the slot with the given SlotRequestId.
releaseSlot(Throwable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
 
releaseSlot(SlotRequestId, SlotSharingGroupId, Throwable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
 
releaseStartedWorker(WorkerType) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Trigger a release of a started worker.
releaseStartedWorker(ResourceID) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
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.SlotPool
Unregister TaskManager from this pool, all the related slots will be released and tasks be canceled.
releaseTaskManager(ResourceID, Exception) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolGateway
Releases a TaskExecutor with the given ResourceID from the SlotPool.
remainingCapacity() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
Returns the remaining capacity of the backing array.
RemoteFencedMessage<F extends Serializable,P extends Serializable> - Class in org.apache.flink.runtime.rpc.messages
Remote FencedMessage implementation.
RemoteFencedMessage(F, P) - Constructor for class org.apache.flink.runtime.rpc.messages.RemoteFencedMessage
 
RemoteHandshakeMessage - Class in org.apache.flink.runtime.rpc.messages
Handshake message between rpc endpoints.
RemoteHandshakeMessage(Class<?>, int) - Constructor for class org.apache.flink.runtime.rpc.messages.RemoteHandshakeMessage
 
RemoteInputChannel - Class in org.apache.flink.runtime.io.network.partition.consumer
An input channel, which requests a remote partition queue.
RemoteInputChannel(SingleInputGate, int, ResultPartitionID, ConnectionID, ConnectionManager, TaskIOMetricGroup) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
RemoteInputChannel(SingleInputGate, int, ResultPartitionID, ConnectionID, ConnectionManager, int, int, TaskIOMetricGroup) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
RemoteRpcInvocation - Class in org.apache.flink.runtime.rpc.messages
Remote rpc invocation message which is used when the actor communication is remote and, thus, the message has to be serialized.
RemoteRpcInvocation(String, Class<?>[], Object[]) - Constructor for class org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation
 
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(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(Object) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
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(N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
remove(UK) - Method in class org.apache.flink.runtime.state.heap.HeapMapState
 
remove(N) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
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(K) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
 
remove(JobID) - Method in class org.apache.flink.runtime.taskexecutor.JobManagerTable
 
remove(ExecutionAttemptID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Remove the task identified by the given execution attempt id.
remove() - Method in class org.apache.flink.runtime.util.EmptyIterator
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
 
removeAll(Collection<?>) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
 
removeAll(Collection<?>) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
removeAndGetOld(N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
removeAndGetOld(N) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
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.
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
 
removeInstanceListener(InstanceListener) - Method in class org.apache.flink.runtime.instance.InstanceManager
 
removeJob(JobID) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
removeJob(JobID) - Method in class 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.resourcemanager.ResourceManager
 
removeJob(JobID) - Method in class org.apache.flink.runtime.taskexecutor.JobLeaderService
Remove the given job from being monitored by the job leader service.
removeJobGraph(JobID) - Method in class org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
 
removeJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
 
removeJobGraph(JobID) - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
Removes the SubmittedJobGraph with the given JobID if it exists.
removeJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
 
removeJobMetricsGroup(JobID, TaskManagerJobMetricGroup) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
removeKeyA(A) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
removeKeyB(B) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
removeLast() - Method in class org.apache.flink.runtime.util.IntArrayList
 
removeLong(int) - Method in class org.apache.flink.runtime.util.LongArrayList
 
RemoveRangeIndex<T> - Class in org.apache.flink.runtime.operators.udf
 
RemoveRangeIndex() - Constructor for class org.apache.flink.runtime.operators.udf.RemoveRangeIndex
 
RemoveResource - Class in org.apache.flink.runtime.clusterframework.messages
Message sent to the ResourceManager by the JobManager to instruct to remove a resource.
RemoveResource(ResourceID) - Constructor for class org.apache.flink.runtime.clusterframework.messages.RemoveResource
Constructor for a shutdown of a registered resource.
removeSlotListener() - Method in class org.apache.flink.runtime.instance.Instance
Removes the listener that receives notifications for slot availability.
removeTask(ExecutionAttemptID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Remove the task with the given execution attempt id from its task slot.
removeTaskMetricGroup(AbstractID) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
 
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<V2>) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstReOpenableHashJoinIterator
Set new input for probe side
reopenProbe(MutableObjectIterator<V1>) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondReOpenableHashJoinIterator
Set new input for probe side
reopenProbe(MutableObjectIterator<PT>) - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
 
reopenProbe(MutableObjectIterator<V2>) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstReOpenableHashJoinIterator
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
repartitionState(List<OperatorStateHandle>, int) - Method in interface org.apache.flink.runtime.checkpoint.OperatorStateRepartitioner
 
repartitionState(List<OperatorStateHandle>, int) - Method in class org.apache.flink.runtime.checkpoint.RoundRobinOperatorStateRepartitioner
 
replace(String, int, T) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Replaces a state handle in ZooKeeper and discards the old state handle.
reporterIndex - Variable in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
 
reportHeartBeat() - Method in class org.apache.flink.runtime.instance.Instance
Updates the time of last received heart beat to the current system time.
reportHeartBeat(InstanceID) - Method in class org.apache.flink.runtime.instance.InstanceManager
 
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.
reportSlotStatus(InstanceID, SlotReport) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Reports the current slot allocations for a task manager identified by the given instance id.
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
 
requestBlobServerPort(Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
 
requestBlobServerPort(Time) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerGateway
Requests the BlobServer port.
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 Buffer instance from the buffer provider, if one is available.
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 interface org.apache.flink.runtime.io.network.buffer.BufferProvider
Returns a Buffer instance from the buffer provider.
requestBufferBuilderBlocking() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
Returns a BufferBuilder instance from the buffer provider.
requestClassloadingProps(JobID, Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
 
requestClassloadingProps(JobID, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerGateway
Requests the class loading properties for the given JobID.
requestClassloadingProps() - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
requestClassloadingProps() - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Request the classloading props of this job.
requestClusterOverview(Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
 
requestClusterOverview(Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
requestClusterOverview(Time) - 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.
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, ResourceID) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.AbstractTaskManagerFileHandler
 
requestFileUpload(ResourceManagerGateway, ResourceID) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerLogFileHandler
 
requestFileUpload(ResourceManagerGateway, ResourceID) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerStdoutFileHandler
 
requestFileUpload(FileType, Time) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
requestFileUpload(FileType, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Requests the file upload of the specified type to the cluster's BlobServer.
RequestHandler - Interface in org.apache.flink.runtime.rest.handler.legacy
Base interface for all request handlers.
RequestHandlerException - Exception in org.apache.flink.runtime.rest.handler.legacy
Base class for request handler exceptions.
RequestHandlerException(String) - Constructor for exception org.apache.flink.runtime.rest.handler.legacy.RequestHandlerException
 
requestHeartbeat(ResourceID, I) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
 
requestHeartbeat(ResourceID, I) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatTarget
Requests a heartbeat from the target.
requestJob(JobID, Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
 
requestJob(JobID, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
requestJob(JobID, Time) - Method in interface org.apache.flink.runtime.dispatcher.DispatcherGateway
Requests the ArchivedExecutionGraph for the given jobId.
requestJob(Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
requestJob(Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Requests the ArchivedExecutionGraph of the executed job.
requestJob(JobID, Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
Requests the AccessExecutionGraph for the given jobId.
requestJobDetails(Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
requestJobDetails(Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Request the details of the executed job.
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
 
requestJobResult(JobID, Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
 
requestJobResult(JobID, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
requestJobResult(JobID, Time) - Method in class org.apache.flink.runtime.dispatcher.MiniDispatcher
 
requestJobResult(JobID) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
 
requestJobResult(JobID, Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
Requests the JobResult of a job specified by the given jobId.
requestJobsOverview(Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
 
requestJobsOverview(Time) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerGateway
Requests the job overview from the JobManager.
RequestJobsOverview - Class in org.apache.flink.runtime.messages.webmonitor
This message requests an overview of how many jobs are in which status.
requestJobStatus(JobID, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
requestJobStatus(Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
requestJobStatus(Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Requests the current job status.
requestJobStatus(JobID, Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
Request the JobStatus of 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 KvStateLocation for the specified InternalKvState registration name.
requestKvStateLocation(JobID, String) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayKvStateLocationOracle
 
requestMemorySegment() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
requestMemorySegments(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
requestMetricQueryServicePaths(Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
 
requestMetricQueryServicePaths(Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
requestMetricQueryServicePaths(Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
Requests the paths for the MetricQueryService to query.
requestMultipleJobDetails(Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
 
requestMultipleJobDetails(Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
requestMultipleJobDetails(Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
Requests job details currently being executed on the Flink cluster.
requestNewWorkers(int) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Requests to allocate a certain number of new workers.
requestNewWorkers(int) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
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.
requestOperatorBackPressureStats(JobID, JobVertexID) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
requestOperatorBackPressureStats(JobVertexID) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
requestOperatorBackPressureStats(JobVertexID) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Requests the statistics on operator back pressure.
requestOperatorBackPressureStats(JobID, JobVertexID) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
Requests the statistics on operator back pressure.
requestPartitionProducerState(JobID, IntermediateDataSetID, ResultPartitionID) - Method in interface org.apache.flink.runtime.io.network.netty.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(JobID, IntermediateDataSetID, ResultPartitionID) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayPartitionProducerStateChecker
 
requestPartitions() - Method in interface 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
 
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.
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 LinkedBlockingQueue that is extended with closing methods.
RequestQueue() - Constructor for class org.apache.flink.runtime.io.disk.iomanager.RequestQueue
 
requestResourceOverview(Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
requestResourceOverview(Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Requests the resource overview.
requestRestAddress(Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
 
requestRestAddress(Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
requestRestAddress(Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
Requests the REST address of this RpcEndpoint.
requestSlot(JobMasterId, SlotRequest, Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
requestSlot(JobMasterId, SlotRequest, Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Requests a slot from the resource manager.
requestSlot(SlotID, JobID, AllocationID, String, ResourceManagerId, Time) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
requestSlot(SlotID, JobID, AllocationID, String, ResourceManagerId, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Requests a slot from the TaskManager.
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.
requestStackTrace(Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
requestStackTrace(Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Request the stack trace from the task manager.
requestStackTrace(Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
requestStackTraceSample(int, int, Time, int, Time) - Method in class org.apache.flink.runtime.executiongraph.Execution
Request a stack trace sample from the task of this execution.
requestStackTraceSample(ExecutionAttemptID, int, int, Time, int, Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
requestStackTraceSample(ExecutionAttemptID, int, int, Time, int, Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Request a stack trace sample from the given task.
requestStackTraceSample(ExecutionAttemptID, int, int, Time, int, Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
requestStackTraceSample(ExecutionAttemptID, int, int, Time, int, Time) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
requestStackTraceSample(ExecutionAttemptID, int, int, Time, int, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
 
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, int, RemoteInputChannel, int) - Method in class org.apache.flink.runtime.io.network.netty.PartitionRequestClient
Requests a remote intermediate result partition queue.
requestSubpartition(int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
Requests a remote subpartition.
requestSubpartitionView(ResultPartitionProvider, ResultPartitionID, int) - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
 
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
 
requestTaskManagerFileUpload(ResourceID, FileType, Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
requestTaskManagerFileUpload(ResourceID, FileType, Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Request the file upload from the given TaskExecutor to the cluster's BlobServer.
requestTaskManagerInfo(Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
requestTaskManagerInfo(ResourceID, Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
requestTaskManagerInfo(Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Requests information about the registered TaskExecutor.
requestTaskManagerInfo(ResourceID, Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Requests information about the given TaskExecutor.
requestTaskManagerInstance(ResourceID, Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
 
requestTaskManagerInstance(ResourceID, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerGateway
Requests the TaskManager instance registered under the given instanceId from the JobManager.
requestTaskManagerInstances(Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
 
requestTaskManagerInstances(Time) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerGateway
Requests all currently registered TaskManager instances from the JobManager.
requestTaskManagerLog(Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
requestTaskManagerLog(Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Request the task manager log from the task manager.
requestTaskManagerLog(Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
requestTaskManagerMetricQueryServicePaths(Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
 
requestTaskManagerMetricQueryServicePaths(Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
requestTaskManagerMetricQueryServicePaths(Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
requestTaskManagerMetricQueryServicePaths(Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Requests the paths for the TaskManager's MetricQueryService to query.
requestTaskManagerMetricQueryServicePaths(Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
Requests the paths for the TaskManager's MetricQueryService to query.
requestTaskManagerStdout(Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
requestTaskManagerStdout(Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Request the task manager stdout from the task manager.
requestTaskManagerStdout(Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
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
 
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 class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
requiresExternalizedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
 
RequiresLeaderSessionID - Interface in org.apache.flink.runtime.messages
Marks messages to be sent wrapped in a JobManagerMessages.LeaderSessionMessage
rescaleJob(JobID, int, RescalingBehaviour, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
rescaleJob(int, RescalingBehaviour, Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
rescaleJob(int, RescalingBehaviour, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Triggers rescaling of the executed job.
rescaleJob(JobID, int, RescalingBehaviour, Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
Trigger rescaling of the given job.
rescaleOperators(Collection<JobVertexID>, int, RescalingBehaviour, Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
rescaleOperators(Collection<JobVertexID>, int, RescalingBehaviour, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Triggers rescaling of the given set of operators.
RescalingBehaviour - Enum in org.apache.flink.runtime.jobmaster
Definition of the rescaling behaviour.
RescalingHandlers - Class in org.apache.flink.runtime.rest.handler.job.rescaling
Rest handler to trigger and poll the rescaling of a running job.
RescalingHandlers() - 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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, 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
MessageParameters for polling the status of a rescaling operation.
RescalingStatusMessageParameters() - Constructor for class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusMessageParameters
 
RescalingTriggerHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, 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
MessageParameters for triggering the rescaling of a job.
RescalingTriggerMessageParameters() - Constructor for class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerMessageParameters
 
reset(Collection<MasterTriggerRestoreHook<?>>, Logger) - Static method in class org.apache.flink.runtime.checkpoint.hooks.MasterHooks
Resets the master hooks.
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.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.
resetAllInputs() - Method in class org.apache.flink.runtime.operators.BatchTask
 
resetConstraints() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
Resets this co-location group, meaning that future calls to CoLocationGroup.getLocationConstraint(int) will give out new CoLocationConstraints.
resetEndOfSuperstep() - Method in class org.apache.flink.runtime.iterative.task.SyncEventHandler
 
resetForNewExecution(long, long) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
resetForNewExecution(long, long) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
Archives the current Execution and creates a new Execution for this vertex.
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
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
ResettableDriver<S extends org.apache.flink.api.common.functions.Function,OT> - Interface in org.apache.flink.runtime.operators
This interface marks a Driver as 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.
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 class org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
 
resolveCheckpoint(String) - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
 
resolveCheckpoint(String) - Method in interface org.apache.flink.runtime.state.StateBackend
Resolves the given pointer to a checkpoint/savepoint into a checkpoint location.
resolveCheckpointPointer(String) - Static method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
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.CheckpointStorage
Resolves a storage location reference into a CheckpointStreamFactory.
resolveCheckpointStorageLocation(long, CheckpointStorageLocationReference) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
 
resolveCheckpointStorageLocation(long, CheckpointStorageLocationReference) - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
 
resolveFromString(String) - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
Resolves this parameter for the given string value representation.
resolveKvStateCompatibility(RegisteredKeyedBackendStateMetaInfo.Snapshot<N, S>, TypeSerializer<N>, StateDescriptor<?, S>) - Static method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
Checks compatibility of a restored k/v state, with the new StateDescriptor provided to it.
resolvePrioritizedAlternatives(StateObjectCollection<T>, List<StateObjectCollection<T>>, BiFunction<T, T, Boolean>) - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState.Builder
This helper method resolves the dependencies between the ground truth of the operator state obtained from the job manager and potential alternatives for recovery, e.g.
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, null otherwise.
RESOURCE_MANAGER_NAME - Static variable in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
The default name of the resource manager actor
RESOURCE_MANAGER_NAME - Static variable in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
ResourceActions - Interface in org.apache.flink.runtime.resourcemanager.slotmanager
Resource related actions which the SlotManager can perform.
resourceId() - Method in class org.apache.flink.runtime.clusterframework.messages.RemoveResource
Gets the ID under which the resource is registered (for example container ID).
resourceId() - Method in class org.apache.flink.runtime.clusterframework.messages.ResourceRemoved
Gets the ID under which the resource is registered (for example container ID).
ResourceID - Class in org.apache.flink.runtime.clusterframework.types
Class for Resource Ids assigned at the FlinkResourceManager.
ResourceID(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() - Method in class org.apache.flink.runtime.clusterframework.messages.ReconnectResourceManager
 
resourceManager() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterResourceManager
 
ResourceManager<WorkerType extends ResourceIDRetrievable> - Class in org.apache.flink.runtime.resourcemanager
ResourceManager implementation.
ResourceManager(RpcService, String, ResourceID, ResourceManagerConfiguration, HighAvailabilityServices, HeartbeatServices, SlotManager, MetricRegistry, JobLeaderIdService, ClusterInformation, FatalErrorHandler) - 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
 
ResourceManagerConfiguration - Class in org.apache.flink.runtime.resourcemanager
Resource manager configuration
ResourceManagerConfiguration(Time, Time) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceManagerConfiguration
 
ResourceManagerException - Exception in org.apache.flink.runtime.resourcemanager.exceptions
Base class for ResourceManager exceptions.
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
 
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.
ResourceManagerRunner - Class in org.apache.flink.runtime.resourcemanager
ResourceManagerRunner(ResourceID, String, Configuration, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, ClusterInformation) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceManagerRunner
 
ResourceManagerRuntimeServices - Class in org.apache.flink.runtime.resourcemanager
Container class for the ResourceManager services.
ResourceManagerRuntimeServices(SlotManager, JobLeaderIdService) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
 
ResourceManagerRuntimeServicesConfiguration - Class in org.apache.flink.runtime.resourcemanager
Configuration class for the ResourceManagerRuntimeServices class.
ResourceManagerRuntimeServicesConfiguration(Time, SlotManagerConfiguration) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
 
ResourceManagerServices - Interface in org.apache.flink.runtime.resourcemanager
Interface which provides access to services of the ResourceManager.
ResourceOverview - Class in org.apache.flink.runtime.resourcemanager
Class containing information about the available cluster resources.
ResourceOverview(int, int, int) - 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(double, int, int, int, int, Map<String, Resource>) - Constructor for class org.apache.flink.runtime.clusterframework.types.ResourceProfile
Creates a new ResourceProfile.
ResourceProfile(double, int) - Constructor for class org.apache.flink.runtime.clusterframework.types.ResourceProfile
Creates a new simple ResourceProfile used for testing.
ResourceProfile(ResourceProfile) - Constructor for class org.apache.flink.runtime.clusterframework.types.ResourceProfile
Creates a copy of the given ResourceProfile.
ResourceRemoved - Class in org.apache.flink.runtime.clusterframework.messages
Message sent to the JobManager by the Resource Manager to inform about the removal of a resource.
ResourceRemoved(ResourceID, String) - Constructor for class org.apache.flink.runtime.clusterframework.messages.ResourceRemoved
Constructor for a shutdown of a registered resource.
respondAsLeader(ChannelHandlerContext, Routed, T) - Method in class org.apache.flink.runtime.rest.AbstractHandler
 
respondAsLeader(ChannelHandlerContext, Routed, T) - Method in class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
 
respondAsLeader(ChannelHandlerContext, Routed, JobManagerGateway) - Method in class org.apache.flink.runtime.rest.handler.legacy.TaskManagerLogHandler
Response when running with leading JobManager.
respondAsLeader(ChannelHandlerContext, Routed, T) - Method in class org.apache.flink.runtime.rest.handler.RedirectHandler
 
respondNotFound(ChannelHandlerContext, HttpRequest) - Method in class org.apache.flink.runtime.rest.handler.RouterHandler
 
respondToRequest(ChannelHandlerContext, HttpRequest, HandlerRequest<R, M>, T) - Method in class org.apache.flink.runtime.rest.AbstractHandler
Respond to the given HandlerRequest.
respondToRequest(ChannelHandlerContext, HttpRequest, HandlerRequest<R, M>, T) - Method in class org.apache.flink.runtime.rest.handler.AbstractRestHandler
 
respondToRequest(ChannelHandlerContext, HttpRequest, HandlerRequest<EmptyRequestBody, M>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.AbstractTaskManagerFileHandler
 
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.RedirectHandler
 
responseHeaders - Variable in class org.apache.flink.runtime.rest.RestServerEndpoint
 
REST_CONTENT_TYPE - Static variable in enum org.apache.flink.runtime.rest.util.RestConstants
 
restAddress - Variable in class org.apache.flink.runtime.dispatcher.Dispatcher
 
restart(long) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
restart(RestartCallback, ScheduledExecutor) - Method in class org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy
 
restart(RestartCallback, ScheduledExecutor) - Method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
 
restart(RestartCallback, ScheduledExecutor) - Method in class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
 
restart(RestartCallback, ScheduledExecutor) - Method in interface org.apache.flink.runtime.executiongraph.restart.RestartStrategy
Called by the ExecutionGraph to eventually trigger a full recovery.
RestartAllStrategy - Class in org.apache.flink.runtime.executiongraph.failover
Simple failover strategy that triggers a restart of all tasks in the execution graph, via ExecutionGraph.failGlobal(Throwable).
RestartAllStrategy(ExecutionGraph) - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy
Creates a new failover strategy that recovers from failures by restarting all tasks of the execution graph.
RestartAllStrategy.Factory - Class in org.apache.flink.runtime.executiongraph.failover
Factory that instantiates the RestartAllStrategy.
RestartCallback - Interface in org.apache.flink.runtime.executiongraph.restart
A callback to trigger restarts, passed to the RestartStrategy to trigger recovery on the ExecutionGraph.
RestartIndividualStrategy - Class in org.apache.flink.runtime.executiongraph.failover
Simple failover strategy that restarts each task individually.
RestartIndividualStrategy(ExecutionGraph) - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
Creates a new failover strategy that recovers from failures by restarting only the failed task of the execution graph.
RestartIndividualStrategy(ExecutionGraph, Executor) - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
Creates a new failover strategy that recovers from failures by restarting only the failed task of the execution graph.
RestartIndividualStrategy.Factory - Class in org.apache.flink.runtime.executiongraph.failover
Factory that instantiates the RestartAllStrategy.
RestartPipelinedRegionStrategy - Class in org.apache.flink.runtime.executiongraph.failover
A failover strategy that restarts regions of the ExecutionGraph.
RestartPipelinedRegionStrategy(ExecutionGraph) - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
Creates a new failover strategy to restart pipelined regions that works on the given execution graph and uses the execution graph's future executor to call restart actions.
RestartPipelinedRegionStrategy(ExecutionGraph, Executor) - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
Creates a new failover strategy to restart pipelined regions that works on the given execution graph and uses the given executor to call restart actions.
RestartPipelinedRegionStrategy.Factory - Class in org.apache.flink.runtime.executiongraph.failover
Factory that instantiates the RestartPipelinedRegionStrategy.
RestartStrategy - Interface in org.apache.flink.runtime.executiongraph.restart
Strategy for ExecutionGraph restarts.
RestartStrategyFactory - Class in org.apache.flink.runtime.executiongraph.restart
 
RestartStrategyFactory() - Constructor for class org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
 
RestartTimeGauge - Class in org.apache.flink.runtime.executiongraph.metrics
Gauge which returns the last restarting time.
RestartTimeGauge(ExecutionGraph) - Constructor for class org.apache.flink.runtime.executiongraph.metrics.RestartTimeGauge
 
RestClient - Class in org.apache.flink.runtime.rest
This client is the counter-part to the RestServerEndpoint.
RestClient(RestClientConfiguration, Executor) - 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, HttpResponseStatus) - Constructor for exception org.apache.flink.runtime.rest.util.RestClientException
 
RestClientException(String, Throwable, 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.
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, Time, File) - 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
 
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(Collection<OperatorStateHandle>) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
restore(Collection<KeyedStateHandle>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
restore(R) - Method in interface org.apache.flink.runtime.state.Snapshotable
Restores state that was previously snapshotted from the provided parameters.
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.
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.
restoreLatestCheckpointedState(Map<JobVertexID, ExecutionJobVertex>, boolean, boolean) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Restores the latest checkpointed state.
restoreLatestCheckpointedState(boolean, boolean) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Restores the latest checkpointed state.
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.
restoreSavepoint(String, boolean, Map<JobVertexID, ExecutionJobVertex>, ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Restore the state with given savepoint.
restoreSavepoint() - Method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
Returns whether to restore from savepoint.
RestServerEndpoint - Class in org.apache.flink.runtime.rest
An abstract class for netty-based REST server endpoints.
RestServerEndpoint(RestServerEndpointConfiguration) - 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.
Result(StreamStateHandle, int) - Constructor for class org.apache.flink.runtime.state.SharedStateRegistry.Result
 
resultHandler - Variable in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
Handler for completed requests
ResultPartition - Class in org.apache.flink.runtime.io.network.partition
A result partition for data produced by a single task.
ResultPartition(String, TaskActions, JobID, ResultPartitionID, ResultPartitionType, int, int, ResultPartitionManager, ResultPartitionConsumableNotifier, IOManager, boolean) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultPartition
 
ResultPartitionConsumableNotifier - Interface in org.apache.flink.runtime.io.network.partition
 
ResultPartitionDeploymentDescriptor - Class in org.apache.flink.runtime.deployment
Deployment descriptor for a result partition.
ResultPartitionDeploymentDescriptor(IntermediateDataSetID, IntermediateResultPartitionID, ResultPartitionType, int, int, boolean) - Constructor for class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
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(IntermediateResultPartitionID, ExecutionAttemptID) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultPartitionID
 
ResultPartitionLocation - Class in org.apache.flink.runtime.deployment
Location of a result partition from the perspective of the consuming task.
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
 
ResultPartitionMetrics - Class in org.apache.flink.runtime.io.network.partition
Collects metrics of a result partition.
ResultPartitionProvider - Interface in org.apache.flink.runtime.io.network.partition
 
ResultPartitionType - Enum in org.apache.flink.runtime.io.network.partition
 
ResultPartitionWriter - Interface in org.apache.flink.runtime.io.network.api.writer
A buffer-oriented runtime result writer API for producing results.
ResultSubpartition - Class in org.apache.flink.runtime.io.network.partition
A single subpartition of a ResultPartition instance.
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 Buffer and the backlog length indicating how many non-event buffers are available in the subpartition.
ResultSubpartitionView - Interface in org.apache.flink.runtime.io.network.partition
A view to consume a ResultSubpartition instance.
retainAll(Collection<?>) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
 
retainAll(Collection<?>) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
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.NetworkBuffer
 
retainBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
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.zookeeper
State storage helper which is used by ZooKeeperStateHandleStore to persist state before the state handle is written to ZooKeeper.
RetrievableStreamStateHandle<T extends Serializable> - Class in org.apache.flink.runtime.state
Wrapper around a StreamStateHandle to make the referenced state object retrievable trough a simple get call.
RetrievableStreamStateHandle(StreamStateHandle) - Constructor for class org.apache.flink.runtime.state.RetrievableStreamStateHandle
 
RetrievableStreamStateHandle(Path, long) - Constructor for class org.apache.flink.runtime.state.RetrievableStreamStateHandle
 
retrieveBlobServerAddress(JobManagerGateway, Time) - Static method in class org.apache.flink.runtime.client.JobClient
Utility method to retrieve the BlobServer address from the given JobManager gateway.
retrieveClassLoader(JobID, JobManagerGateway, Configuration, HighAvailabilityServices, Time) - Static method in class org.apache.flink.runtime.client.JobClient
Reconstructs the class loader by first requesting information about it at the JobManager and then downloading missing jar files.
retrieveJobGraph(Configuration) - Method in class org.apache.flink.runtime.entrypoint.JobClusterEntrypoint
 
retrieveLeaderConnectionInfo(LeaderRetrievalService, FiniteDuration) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
Retrieves the leader akka url and the current leader session ID.
retrieveLeaderGateway(LeaderRetrievalService, ActorSystem, FiniteDuration) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
Retrieves the current leader gateway using the given LeaderRetrievalService.
retrieveLeaderSessionId(LeaderRetrievalService, FiniteDuration) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
Retrieves the current leader session id of the component identified by the given leader retrieval service.
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.AkkaQueryServiceRetriever
 
retrieveService(String) - Method in interface org.apache.flink.runtime.webmonitor.retriever.MetricQueryServiceRetriever
Retrieves for the given query service path 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) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
Retriggers a partition request.
retry(Supplier<CompletableFuture<T>>, int, Executor) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
Retry the given operation the given number of times in case of a failure.
retry(Object, int, FiniteDuration, ExecutionContext) - Method in interface org.apache.flink.runtime.instance.ActorGateway
Retries to send asynchronously a message up to numberRetries times.
retry(Object, int, FiniteDuration, ExecutionContext) - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
Retries to send asynchronously a message up to numberRetries times.
RetryException(String) - Constructor for exception org.apache.flink.runtime.concurrent.FutureUtils.RetryException
 
RetryException(String, Throwable) - Constructor for exception org.apache.flink.runtime.concurrent.FutureUtils.RetryException
 
RetryException(Throwable) - Constructor for exception org.apache.flink.runtime.concurrent.FutureUtils.RetryException
 
RetryingRegistration<F extends Serializable,G extends RpcGateway,S extends RegistrationResponse.Success> - 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) - Constructor for class org.apache.flink.runtime.registration.RetryingRegistration
 
RetryingRegistration(Logger, RpcService, String, Class<G>, String, F, long, long, long, long) - Constructor for class org.apache.flink.runtime.registration.RetryingRegistration
 
retrySuccesfulWithDelay(Supplier<CompletableFuture<T>>, Time, Deadline, Predicate<T>, ScheduledExecutor) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
Retry the given operation with the given delay in between successful completions where the result does not match a given predicate.
retryWithDelay(Supplier<CompletableFuture<T>>, int, Time, Predicate<Throwable>, ScheduledExecutor) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
Retry the given operation with the given delay in between failures.
retryWithDelay(Supplier<CompletableFuture<T>>, int, Time, ScheduledExecutor) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
Retry the given operation with the given delay in between failures.
returnAllocatedSlot(LogicalSlot) - Method in class org.apache.flink.runtime.instance.Instance
Returns a slot that has been allocated from this instance.
returnAllocatedSlot(LogicalSlot) - Method in interface org.apache.flink.runtime.jobmaster.SlotOwner
Return the given slot to the slot owner.
returnExclusiveSegments(List<MemorySegment>) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
The exclusive segments are recycled to network buffer pool directly when input channel is released.
reuseInputMetricsForTask() - Method in class org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
Causes the containing task to use this operators input record counter.
reuseOutputMetricsForTask() - Method in class org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
Causes the containing task to use this operators output record counter.
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 JoinTaskIterator that 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 JoinTaskIterator that 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 DeserializationDelegate that 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 MutableObjectIterator into a regular Iterator.
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
 
RevisionInformation(String, String) - Constructor for class org.apache.flink.runtime.util.EnvironmentInformation.RevisionInformation
 
revokeLeadership() - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
Callback method when current resourceManager loses leadership.
revokeLeadership() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
 
revokeLeadership() - Method in interface org.apache.flink.runtime.leaderelection.LeaderContender
Callback method which is called by the LeaderElectionService upon revoking the leadership of a former leader.
revokeLeadership() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
Callback method when current resourceManager loses leadership.
revokeLeadership() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
 
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
 
ROCKSDB_STATE_BACKEND_NAME - Static variable in class org.apache.flink.runtime.state.StateBackendLoader
The shortcut configuration name for the RocksDB State Backend
roundDownToPageSizeMultiple(long) - Method in class org.apache.flink.runtime.memory.MemoryManager
Rounds the given value down to a multiple of the memory manager's page size.
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 ChannelSelector interface.
RoundRobinChannelSelector() - Constructor for class org.apache.flink.runtime.io.network.api.writer.RoundRobinChannelSelector
Constructs a new default channel selector.
RoundRobinOperatorStateRepartitioner - Class in org.apache.flink.runtime.checkpoint
Current default implementation of OperatorStateRepartitioner that redistributes state in round robin fashion.
RoundRobinOperatorStateRepartitioner() - Constructor for class org.apache.flink.runtime.checkpoint.RoundRobinOperatorStateRepartitioner
 
RouterHandler - Class in org.apache.flink.runtime.rest.handler
This class is an extension of Handler that replaces the standard error response to be identical with those sent by the AbstractRestHandler.
RouterHandler(Router, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.RouterHandler
 
RpcCheckpointResponder - Class in org.apache.flink.runtime.taskexecutor.rpc
 
RpcCheckpointResponder(CheckpointCoordinatorGateway) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcCheckpointResponder
 
RpcConnectionException - Exception in org.apache.flink.runtime.rpc.exceptions
Exception class which is thrown if a rpc connection failed.
RpcConnectionException(String) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcConnectionException
 
RpcConnectionException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcConnectionException
 
RpcConnectionException(Throwable) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcConnectionException
 
RpcEndpoint - Class in org.apache.flink.runtime.rpc
Base class for RPC endpoints.
RpcEndpoint(RpcService, String) - Constructor for class org.apache.flink.runtime.rpc.RpcEndpoint
Initializes the RPC endpoint.
RpcEndpoint(RpcService) - Constructor for class org.apache.flink.runtime.rpc.RpcEndpoint
Initializes the RPC endpoint with a random endpoint id.
RpcEndpoint.MainThreadExecutor - Class in org.apache.flink.runtime.rpc
Executor which executes runnables in the main thread context.
RpcException - Exception in org.apache.flink.runtime.rpc.exceptions
Base class for RPC related exceptions.
RpcException(String) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcException
 
RpcException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcException
 
RpcException(Throwable) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcException
 
RpcGateway - Interface in org.apache.flink.runtime.rpc
Rpc gateway interface which has to be implemented by Rpc gateways.
RpcGatewayRetriever<F extends Serializable,T extends FencedRpcGateway<F>> - Class in org.apache.flink.runtime.webmonitor.retriever.impl
LeaderGatewayRetriever implementation using the RpcService.
RpcGatewayRetriever(RpcService, Class<T>, Function<UUID, F>, int, Time) - Constructor for class org.apache.flink.runtime.webmonitor.retriever.impl.RpcGatewayRetriever
 
RpcInputSplitProvider - Class in org.apache.flink.runtime.taskexecutor.rpc
 
RpcInputSplitProvider(JobMasterGateway, JobVertexID, ExecutionAttemptID, Time) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcInputSplitProvider
 
RpcInvocation - Interface in org.apache.flink.runtime.rpc.messages
Interface for rpc invocation messages.
RpcKvStateRegistryListener - Class in org.apache.flink.runtime.taskexecutor.rpc
KvStateRegistryListener implementation for the new RPC service.
RpcKvStateRegistryListener(KvStateRegistryGateway, InetSocketAddress) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcKvStateRegistryListener
 
RpcPartitionStateChecker - Class in org.apache.flink.runtime.taskexecutor.rpc
 
RpcPartitionStateChecker(JobMasterGateway) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcPartitionStateChecker
 
RpcResultPartitionConsumableNotifier - Class in org.apache.flink.runtime.taskexecutor.rpc
 
RpcResultPartitionConsumableNotifier(JobMasterGateway, Executor, Time) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcResultPartitionConsumableNotifier
 
rpcServer - Variable in class org.apache.flink.runtime.rpc.RpcEndpoint
Interface to access the underlying rpc server.
RpcServer - Interface in org.apache.flink.runtime.rpc
Interface for self gateways.
RpcService - Interface in org.apache.flink.runtime.rpc
Interface for rpc services.
RpcTaskManagerGateway - Class in org.apache.flink.runtime.jobmaster
Implementation of the TaskManagerGateway for Flink's RPC system.
RpcTaskManagerGateway(TaskExecutorGateway, JobMasterId) - Constructor for class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
RpcTimeout - Annotation Type in org.apache.flink.runtime.rpc
Annotation for RpcGateway methods to specify an additional timeout parameter for the returned future to be completed.
RpcUtils - Class in org.apache.flink.runtime.rpc
Utility functions for Flink's RPC implementation.
run() - Method in class org.apache.flink.runtime.blob.BlobServer
 
run() - Method in class org.apache.flink.runtime.heartbeat.HeartbeatManagerSenderImpl
 
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.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.sort.UnilateralSortMerger.ThreadBase
Implements exception handling and delegates to go().
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.runtime.util.ProcessShutDownThread
 
runAfterwards(CompletableFuture<?>, RunnableWithException) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
Run the given action after the completion of the given future.
runAfterwardsAsync(CompletableFuture<?>, RunnableWithException) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
Run the given action after the completion of the given future.
runAfterwardsAsync(CompletableFuture<?>, RunnableWithException, Executor) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
Run the given action after the completion of the given future.
runAsync(Runnable) - Method in interface org.apache.flink.runtime.rpc.MainThreadExecutable
Execute the runnable in the main thread of the underlying RPC endpoint.
RunAsync - Class in org.apache.flink.runtime.rpc.messages
Message for asynchronous runnable invocations
RunAsync(Runnable, long) - Constructor for class org.apache.flink.runtime.rpc.messages.RunAsync
Creates a new RunAsync message.
runAsync(Runnable) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Execute the runnable in the main thread of the underlying RPC endpoint.
runAsyncWithoutFencing(Runnable) - Method in class org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
 
runAsyncWithoutFencing(Runnable) - Method in interface org.apache.flink.runtime.rpc.FencedMainThreadExecutable
Run the given runnable in the main thread without attaching a fencing token.
runAsyncWithoutFencing(Runnable) - Method in class org.apache.flink.runtime.rpc.FencedRpcEndpoint
Run the given runnable in the main thread of the RpcEndpoint without checking the fencing token.
runCluster(Configuration) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
runDetached(JobGraph) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
This method executes a job in detached mode.
runFlinkZkQuorumPeer(String, int) - Static method in class org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
Runs a ZooKeeper QuorumPeer if further peers are configured or a single ZooKeeperServer if no further peers are configured.
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
 
RunningJobsRegistry - Interface in org.apache.flink.runtime.highavailability
A simple registry that tracks if a certain job is pending execution, running, or completed.
RunningJobsRegistry.JobSchedulingStatus - Enum in org.apache.flink.runtime.highavailability
The scheduling status of a job, as maintained by the RunningJobsRegistry.
runSecured(Callable<T>) - Method in interface org.apache.flink.runtime.security.SecurityContext
 
runTaskManager(Configuration, ResourceID) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
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, JobVertexID, ExecutionAttemptID, ExecutionConfig, TaskInfo, Configuration, Configuration, ClassLoader, MemoryManager, IOManager, BroadcastVariableManager, TaskStateManager, AccumulatorRegistry, TaskKvStateRegistry, InputSplitProvider, Map<String, Future<Path>>, ResultPartitionWriter[], InputGate[], TaskEventDispatcher, CheckpointResponder, TaskManagerRuntimeInfo, TaskMetricGroup, Task) - 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
 
runtimeUdfContext - Variable in class org.apache.flink.runtime.operators.BatchTask
The udf's runtime context.

S

Savepoint - Interface in org.apache.flink.runtime.checkpoint.savepoint
Savepoints are manually-triggered snapshots from which a program can be resumed on submission.
SavepointDisposalHandlers - Class in org.apache.flink.runtime.rest.handler.job.savepoints
Handlers to trigger the disposal of a savepoint.
SavepointDisposalHandlers() - Constructor for class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers
 
SavepointDisposalHandlers.SavepointDisposalStatusHandler - Class in org.apache.flink.runtime.rest.handler.job.savepoints
StatusHandler implementation for the savepoint disposal operation.
SavepointDisposalHandlers.SavepointDisposalTriggerHandler - Class in org.apache.flink.runtime.rest.handler.job.savepoints
TriggerHandler implementation 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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, 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
AsynchronousOperationTriggerMessageHeaders implementation for the SavepointDisposalHandlers.SavepointDisposalStatusHandler.
SavepointDisposalStatusMessageParameters - Class in org.apache.flink.runtime.rest.messages.job.savepoints
MessageParameters for the SavepointDisposalHandlers.SavepointDisposalStatusHandler.
SavepointDisposalStatusMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusMessageParameters
 
SavepointDisposalTriggerHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, 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
AsynchronousOperationTriggerMessageHeaders for the SavepointDisposalHandlers.SavepointDisposalTriggerHandler.
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.
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
 
SavepointRestoreSettings - Class in org.apache.flink.runtime.jobgraph
Savepoint restore settings.
SavepointSerializer<T extends Savepoint> - Interface in org.apache.flink.runtime.checkpoint.savepoint
Serializer for Savepoint instances.
SavepointSerializers - Class in org.apache.flink.runtime.checkpoint.savepoint
Helper to access SavepointSerializer for a specific savepoint version.
SavepointStatusHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, 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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, 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
RequestBody to trigger savepoints.
SavepointTriggerRequestBody(String, boolean) - Constructor for class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerRequestBody
 
SavepointV1 - Class in org.apache.flink.runtime.checkpoint.savepoint
Savepoint version 0.
SavepointV1(long, Collection<TaskState>) - Constructor for class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
 
SavepointV1Serializer - Class in org.apache.flink.runtime.checkpoint.savepoint
Deserializer for checkpoints written in format 1 (Flink 1.2.x format)
SavepointV2 - Class in org.apache.flink.runtime.checkpoint.savepoint
The persistent checkpoint metadata, format version 2.
SavepointV2(long, Collection<TaskState>) - Constructor for class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
Deprecated.
Only kept for backwards-compatibility with versions < 1.3. Will be removed in the future.
SavepointV2(long, Collection<OperatorState>, Collection<MasterState>) - Constructor for class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
ScalaUtils - Class in org.apache.flink.runtime.util
Utilities to convert Scala types into Java types.
schedule(Runnable, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.akka.ActorSystemScheduledExecutorAdapter
 
schedule(Callable<V>, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.akka.ActorSystemScheduledExecutorAdapter
 
schedule(Runnable, long, TimeUnit) - Method in interface org.apache.flink.runtime.concurrent.ScheduledExecutor
Executes the given command after the given delay.
schedule(Callable<V>, long, TimeUnit) - Method in interface org.apache.flink.runtime.concurrent.ScheduledExecutor
Executes the given callable after the given delay.
schedule(Runnable, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
 
schedule(Callable<V>, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
 
scheduleAll(SlotProvider, boolean, LocationPreferenceConstraint) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
Schedules all execution vertices of this ExecutionJobVertex.
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.akka.ActorSystemScheduledExecutorAdapter
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface org.apache.flink.runtime.concurrent.ScheduledExecutor
Executes the given command periodically.
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
 
ScheduledExecutor - Interface in org.apache.flink.runtime.concurrent
Extension for the Executor interface which is enriched by method for scheduling tasks in the future.
ScheduledExecutorServiceAdapter - Class in org.apache.flink.runtime.concurrent
Adapter class for a ScheduledExecutorService which shall be used as a ScheduledExecutor.
ScheduledExecutorServiceAdapter(ScheduledExecutorService) - Constructor for class org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
 
ScheduledUnit - Class in org.apache.flink.runtime.jobmanager.scheduler
ScheduledUnit contains the information necessary to allocate a slot for the given JobVertexID.
ScheduledUnit(Execution) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
ScheduledUnit(Execution, SlotSharingGroupId) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
ScheduledUnit(Execution, SlotSharingGroupId, CoLocationConstraint) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
ScheduledUnit(JobVertexID, SlotSharingGroupId, CoLocationConstraint) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
ScheduledUnit(Execution, JobVertexID, SlotSharingGroupId, CoLocationConstraint) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
scheduleForExecution() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
scheduleForExecution(SlotProvider, boolean, LocationPreferenceConstraint) - Method in class org.apache.flink.runtime.executiongraph.Execution
NOTE: This method only throws exceptions if it is in an illegal state to be scheduled, or if the tasks needs to be scheduled immediately and no resource is available.
scheduleForExecution() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
scheduleForExecution(SlotProvider, boolean, LocationPreferenceConstraint) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
Schedules the current execution of this ExecutionVertex.
ScheduleMode - Enum in org.apache.flink.runtime.jobgraph
The ScheduleMode decides how tasks of an execution graph are started.
scheduleOrUpdateConsumers(ResultPartitionID) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Schedule or updates consumers of the given result partition.
scheduleOrUpdateConsumers(ResultPartitionID, Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
scheduleOrUpdateConsumers(ResultPartitionID, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Notifies the JobManager about available data for a produced partition.
Scheduler - Class in org.apache.flink.runtime.jobmanager.scheduler
The scheduler is responsible for distributing the ready-to-run tasks among instances and slots.
Scheduler(Executor) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
Creates a new scheduler.
scheduleRunAsync(Runnable, long) - Method in interface org.apache.flink.runtime.rpc.MainThreadExecutable
Execute the runnable in the main thread of the underlying RPC endpoint, with a delay of the given number of milliseconds.
scheduleRunAsync(Runnable, Time) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Execute the runnable in the main thread of the underlying RPC endpoint, with a delay of the given number of milliseconds.
scheduleRunAsync(Runnable, long, TimeUnit) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Execute the runnable in the main thread of the underlying RPC endpoint, with a delay of the given number of milliseconds.
scheduleRunnable(Runnable, long, TimeUnit) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
scheduleRunnable(Runnable, long, TimeUnit) - Method in interface org.apache.flink.runtime.rpc.RpcService
Execute the runnable in the execution context of this RPC Service, as returned by RpcService.getExecutor(), after a scheduled delay.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.akka.ActorSystemScheduledExecutorAdapter
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface org.apache.flink.runtime.concurrent.ScheduledExecutor
Executed the given command repeatedly with the given delay between the end of an execution and the start of the next execution.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
 
SchedulingStrategy - Interface in org.apache.flink.runtime.jobmaster.slotpool
Classes that implement this interface provide a method to match objects to somehow represent slot candidates against the SlotProfile that produced the matcher object.
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.
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<SecurityModuleFactory>) - 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
A security context with may be required to run a Callable.
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
Utils for configuring security.
seek(long) - Method in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
 
SeekableFileChannelInputView - Class in org.apache.flink.runtime.io.disk
A DataInputView that is backed by a BlockChannelReader, 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
 
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(ExecutionMode, ShipStrategyType, boolean) - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
Computes the mode of data exchange to be used for a given execution mode and ship strategy.
selectAllocationBaseDirectory(int) - Method in interface org.apache.flink.runtime.state.LocalRecoveryDirectoryProvider
Returns a specific allocation base directory.
selectAllocationBaseDirectory(int) - Method in class org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
 
selectChannels(T, int) - Method in interface org.apache.flink.runtime.io.network.api.writer.ChannelSelector
Returns the logical channel indexes, to which the given record should be written.
selectChannels(T, int) - Method in class org.apache.flink.runtime.io.network.api.writer.RoundRobinChannelSelector
 
selectChannels(SerializationDelegate<T>, int) - Method in class org.apache.flink.runtime.operators.shipping.OutputEmitter
 
selectSubtaskBaseDirectory(int) - Method in interface org.apache.flink.runtime.state.LocalRecoveryDirectoryProvider
Returns a specific subtask base directory.
selectSubtaskBaseDirectory(int) - Method in class org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
 
SEND_RECEIVE_BUFFER_SIZE - Static variable in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
sendError(ChannelHandlerContext, HttpResponseStatus) - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
Writes a simple error response message.
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.
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.
sendInfoMessage(String) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
 
sendInfoMessage(String) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
sendNotModified(ChannelHandlerContext) - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
Send the "304 Not Modified" response.
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, 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
 
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.
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, 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.
sendScheduleOrUpdateConsumersMessage() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
sendSlotReport(ResourceID, InstanceID, SlotReport, Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
sendSlotReport(ResourceID, InstanceID, SlotReport, Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Sends the given SlotReport to 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(ResultPartitionID, TaskEvent, RemoteInputChannel) - Method in class org.apache.flink.runtime.io.network.netty.PartitionRequestClient
Sends a task event backwards to an intermediate result partition producer.
sendTaskEvent(TaskEvent) - Method in interface 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
 
SerializationDelegate<T> - Class in org.apache.flink.runtime.plugable
The serialization delegate exposes an arbitrary element as a IOReadableWritable for serialization, with the help of a type serializer.
SerializationDelegate(TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.plugable.SerializationDelegate
 
serialize(T, DataOutputStream) - Method in interface org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializer
Serializes a savepoint to an output stream.
serialize(SavepointV2, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
serialize(JobDetails, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails.JobDetailsSerializer
 
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(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, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.JobPlanInfo.Serializer
 
serialize(JobID, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.JobIDSerializer
 
serialize(JobResult, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.JobResultSerializer
 
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(ResourceID, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.ResourceIDSerializer
 
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(TriggerId, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.TriggerId.TriggerIdSerializer
 
serialize(ArrayList<T>, DataOutputView) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
serialize(VoidNamespace, DataOutputView) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
 
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.
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 JobExecutionResult that 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.
serializedMetrics - 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
AbstractPagedOutputView used by the BlockingBackChannel for 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
 
serializeKeyedStateHandle(KeyedStateHandle, DataOutputStream) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
serializeOld(SavepointV1, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
serializeOperatorStateHandle(OperatorStateHandle, DataOutputStream) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
serializer - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
serializer - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
serializer - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
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.Serializer
 
serializer1 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
serializer2 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
serializeStreamStateHandle(StreamStateHandle, DataOutputStream) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
serverAddress - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
 
ServicesThreadFactory - Class in org.apache.flink.runtime.highavailability
 
ServicesThreadFactory() - Constructor for class org.apache.flink.runtime.highavailability.ServicesThreadFactory
 
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
 
set(int) - Method in class org.apache.flink.runtime.operators.util.BitSet
Sets the bit at specified index.
set(int) - Method in class org.apache.flink.runtime.operators.util.BloomFilter.BitSet
Sets the bit at specified index.
set(int, T) - Method in class org.apache.flink.runtime.util.EvictingBoundedList
 
set(E) - Method in class org.apache.flink.runtime.util.SingleElementIterator
Resets the element.
setAccumulators(Map<String, Accumulator<?, ?>>) - Method in class org.apache.flink.runtime.executiongraph.Execution
Update accumulators (discarded when the Execution has already been terminated).
setAlignmentDurationNanos(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
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.NetworkBuffer
 
setAllocator(ByteBufAllocator) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
setAllowQueuedScheduling(boolean) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
 
setAsyncDurationMillis(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
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.
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
 
setBufferPoolOwner(BufferPoolOwner) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
The owner of this buffer pool to be called when memory needs to be released to avoid back pressure.
setBytes(int, ByteBuf, int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
setBytes(int, byte[], int, 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, InputStream, 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
 
setBytesBufferedInAlignment(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
setCachable(boolean) - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
setCancellerHandle(ScheduledFuture<?>) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
Sets the handle for the canceller to this pending checkpoint.
setChannelIndex(int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
setCheckpointStatsTracker(CheckpointStatsTracker) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Sets the checkpoint stats tracker.
setClasspaths(List<URL>) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Sets the classpaths required to run the job on a task manager.
setCommonBindAddress(String) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
 
setConfigDir(String) - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
setConfigDir(String) - Method in class org.apache.flink.runtime.taskmanager.TaskManagerCliOptions
 
setConfiguration(Configuration) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
 
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
 
setCount(long) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
Sets the current checkpoint ID.
setCount(long) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
 
setCount(long) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
 
setCurrentKey(K) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
setCurrentKey(K) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
Sets the current key that is used for partitioned state.
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.
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.
setDest(Path) - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
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
 
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.
setExecutable(boolean) - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
setExecutionConfig(ExecutionConfig) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Sets the execution config.
setExtract(boolean) - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
setFailWhenLegacyStateDetected(boolean) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializers
This is only visible as a temporary solution to keep the stateful job migration it cases working from binary savepoints that still contain legacy state (<= Flink 1.1).
setFencingToken(F) - Method in class org.apache.flink.runtime.rpc.FencedRpcEndpoint
 
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
 
setFormatDescription(String) - Method in class org.apache.flink.runtime.jobgraph.InputFormatVertex
 
setFormatDescription(String) - Method in class org.apache.flink.runtime.jobgraph.OutputFormatVertex
 
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
 
setHost(String) - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
setImplicitConvergenceCriterion(String, ConvergenceCriterion<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
Sets the default convergence criterion of a DeltaIteration
setInitialState(JobManagerTaskRestore) - Method in class org.apache.flink.runtime.executiongraph.Execution
Sets the initial state for the execution.
setInputAsynchronouslyMaterialized(int, boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setInputCached(int, boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setInputChannel(IntermediateResultPartitionID, InputChannel) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
setInputComparator(TypeComparatorFactory<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setInputLocalStrategy(int, LocalStrategy) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setInputSerializer(TypeSerializerFactory<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setInputSplitSource(InputSplitSource<?>) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
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
 
setInvokableClass(Class<? extends AbstractInvokable>) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
setIsCompacted(boolean) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
sets compaction status (should only be set true directly after compaction and false when garbage was created)
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
 
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
 
setJobFinished(JobID) - Method in class org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
 
setJobFinished(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
 
setJobFinished(JobID) - Method in interface org.apache.flink.runtime.highavailability.RunningJobsRegistry
Marks a job as completed.
setJobFinished(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperRunningJobsRegistry
 
setJobManagerMode(String) - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
setJobRunning(JobID) - Method in class org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
 
setJobRunning(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
 
setJobRunning(JobID) - Method in interface org.apache.flink.runtime.highavailability.RunningJobsRegistry
Marks a job as running.
setJobRunning(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperRunningJobsRegistry
 
setJsonPlan(String) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
setKeyGroupOffset(int, long) - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
Sets the offset for the given key-group.
setLastOutputCollector(Collector<OT>) - Method in class org.apache.flink.runtime.operators.BatchTask
Sets the last output Collector of the collector chain of this BatchTask.
setLocality(Locality) - Method in class org.apache.flink.runtime.instance.SimpleSlot
Attached locality information to this slot.
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.
setMemorySegment(MemorySegment, int) - Method in class org.apache.flink.runtime.operators.util.BitSet
 
setMemorySegment(MemorySegment, int) - Method in class org.apache.flink.runtime.operators.util.BloomFilter.BitSet
 
setMetaInfo(RegisteredKeyedBackendStateMetaInfo<N, S>) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
setMetaInfo(RegisteredKeyedBackendStateMetaInfo<N, S>) - Method in class org.apache.flink.runtime.state.heap.StateTable
 
setMetricGroup(TaskIOMetricGroup) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
Sets the metric group for this RecordWriter.
setMoreAvailable(boolean) - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
setMutableObjectMode(boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setName(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Sets the name of the vertex
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
 
setNumBuffers(int) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
Sets the current size of this buffer pool.
setNumSlotsPerTaskManager(int) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
 
setNumTaskManagers(int) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
 
setOperatorDescription(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
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.jobgraph.JobVertex
 
setOperatorPrettyName(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
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
 
setOutputPartitioner(Partitioner<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setOutputSerializer(TypeSerializerFactory<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setParallelism(int) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Sets the parallelism for the task.
setPartition(int, IntermediateResultPartition) - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
 
setPartitionNumber(int) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
overwrites partition number and should only be used on compaction partition
setPreProcessingOperationName(String) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
Sets the name of the pre-processing operation for this input.
SetQueue<E> - Class in org.apache.flink.runtime.jobmanager.scheduler
A queue that maintains set characteristics, i.e., elements that are already in the queue may not be added another time.
SetQueue() - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
setQueuedSchedulingAllowed(boolean) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
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.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
 
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
 
setRequestFuture(CompletableFuture<Acknowledge>) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
setResources(ResourceSpec, ResourceSpec) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Sets the minimum and preferred resources for the task.
setResultIterator(MutableObjectIterator<E>) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Sets the result iterator.
setResultIteratorException(IOException) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Reports an exception to all threads that are waiting for the result iterator.
setResultOptimizerProperties(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
setRpcServiceSharing(MiniClusterConfiguration.RpcServiceSharing) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
 
setSavepointRestoreSettings(SavepointRestoreSettings) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Sets the savepoint restore settings.
setScheduleMode(ScheduleMode) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
setScheduleMode(ScheduleMode) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
 
setSessionTimeout(long) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Sets the timeout of the session in seconds.
setSharedSlot(SharedSlot) - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Assigns a new shared slot to this co-location constraint.
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.
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
 
setSlotAvailabilityListener(SlotAvailabilityListener) - Method in class org.apache.flink.runtime.instance.Instance
Sets the listener that receives notifications for slot availability.
setSlotRequestId(SlotRequestId) - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Sets the slot request id of the currently assigned slot to the co-location constraint.
setSlotSharingGroup(SlotSharingGroup) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Associates this vertex with a slot sharing group for scheduling.
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
 
setSource(Path) - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
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
 
setSSLVerAndCipherSuites(SSLEngine) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
setSSLVerAndCipherSuites(ServerSocket, Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
Sets SSl version and cipher suites for SSLServerSocket.
setSSLVerAndCipherSuites(SSLEngine, Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
setSSLVerifyHostname(SSLParameters) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
setSSLVerifyHostname(Configuration, SSLParameters) - Static method in class org.apache.flink.runtime.net.SSLUtils
Sets SSL options to verify peer's hostname in the certificate.
setStateMetaInfo(RegisteredBroadcastBackendStateMetaInfo<K, V>) - Method in interface org.apache.flink.runtime.state.BackendWritableBroadcastState
 
setStateMetaInfo(RegisteredBroadcastBackendStateMetaInfo<K, V>) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
 
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
 
setSyncDurationMillis(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
SettableLeaderRetrievalService - Class in org.apache.flink.runtime.leaderretrieval
LeaderRetrievalService implementation which directly forwards calls of notifyListener to the listener.
SettableLeaderRetrievalService() - Constructor for class org.apache.flink.runtime.leaderretrieval.SettableLeaderRetrievalService
 
SettableLeaderRetrievalService(String, UUID) - Constructor for class org.apache.flink.runtime.leaderretrieval.SettableLeaderRetrievalService
 
setTaskName(String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setUdfConfiguration(Configuration) - Method in class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger
 
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(TaskContext<FlatJoinFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
setup(TaskContext<GroupCombineFunction<IN, OUT>, OUT>) - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
 
setup(TaskContext<GroupReduceFunction<IT, OT>, OT>) - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
 
setup(TaskContext<ReduceFunction<T>, T>) - Method in class org.apache.flink.runtime.operators.AllReduceDriver
 
setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
 
setup(TaskConfig, String, Collector<OT>, AbstractInvokable, ClassLoader, ExecutionConfig, Map<String, Accumulator<?, ?>>) - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
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.ChainedTerminationCriterionDriver
 
setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
 
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<S, OT>) - Method in interface org.apache.flink.runtime.operators.Driver
 
setup(TaskContext<FlatMapFunction<IT, OT>, OT>) - Method in class org.apache.flink.runtime.operators.FlatMapDriver
 
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.GroupReduceDriver
 
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<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(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<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<Function, T>) - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
 
setupInputGate(SingleInputGate) - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
setupPartition(ResultPartition) - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
setUseLargeRecordHandler(boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setValue(byte[]) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
 
setWaitForSolutionSetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setWebUIPort(int) - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
SetWorkerPoolSize - Class in org.apache.flink.runtime.clusterframework.messages
Message sent to the resource master actor to adjust the designated number of workers it maintains.
SetWorkerPoolSize(int) - Constructor for class org.apache.flink.runtime.clusterframework.messages.SetWorkerPoolSize
 
setWritePosition(long) - Method in class org.apache.flink.runtime.io.disk.RandomAccessOutputView
 
SharedSlot - Class in org.apache.flink.runtime.instance
This class represents a shared slot.
SharedSlot(SlotOwner, TaskManagerLocation, int, TaskManagerGateway, SlotSharingGroupAssignment) - Constructor for class org.apache.flink.runtime.instance.SharedSlot
Creates a new shared slot that has no parent (is a root slot) and does not belong to any task group.
SharedSlot(SlotOwner, TaskManagerLocation, int, TaskManagerGateway, SlotSharingGroupAssignment, SharedSlot, AbstractID) - Constructor for class org.apache.flink.runtime.instance.SharedSlot
Creates a new shared slot that has is a sub-slot of the given parent shared slot, and that belongs to the given task group.
SharedSlot(SlotContext, SlotOwner, SlotSharingGroupAssignment) - Constructor for class org.apache.flink.runtime.instance.SharedSlot
Creates a new shared slot that has no parent (is a root slot) and does not belong to any task group.
SharedStateRegistry - Class 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.
SharedStateRegistry() - Constructor for class org.apache.flink.runtime.state.SharedStateRegistry
Default uses direct executor to delete unreferenced state
SharedStateRegistry(Executor) - Constructor for class org.apache.flink.runtime.state.SharedStateRegistry
 
SharedStateRegistry.Result - Class in org.apache.flink.runtime.state
The result of an attempt to (un)/reference state
SharedStateRegistryFactory - Interface in org.apache.flink.runtime.state
Simple factory to produce SharedStateRegistry objects.
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, StateHandleID) - Constructor for class org.apache.flink.runtime.state.SharedStateRegistryKey
 
SharedStateRegistryKey(String) - Constructor for class org.apache.flink.runtime.state.SharedStateRegistryKey
 
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.
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.
shouldIncludeFinished() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
 
shouldIncludeRunning() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
 
shutdown(JobStatus) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Shuts down the checkpoint coordinator.
shutdown(JobStatus) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
Shuts the CheckpointIDCounter service.
shutdown(JobStatus) - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
Shuts down the store.
shutdown(JobStatus) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
 
shutdown(JobStatus) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
shutdown(JobStatus) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
 
shutdown(JobStatus) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
 
shutdown() - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
shutdown() - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
Shutdown method which may release created class loaders.
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 class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
 
shutdown() - Method in class org.apache.flink.runtime.instance.InstanceManager
 
shutdown() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
Close method, marks the I/O manager as closed and removed all temporary files.
shutdown() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
Close method.
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.NetworkEnvironment
Tries to shut down all network I/O components.
shutdown() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
shutdown() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
Shuts the scheduler down.
shutdown() - Method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
Shutdown the JobMaster services.
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.MetricRegistryImpl
Shuts down this registry and the associated MetricReporter.
shutdown() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
Forces an immediate shutdown of the thread.
shutdown() - Method in interface org.apache.flink.runtime.query.KvStateServer
Shuts down the server and all related thread pools.
shutDown() - Method in interface org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTracker
Shuts the BackPressureStatsTracker down.
shutDown() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTrackerImpl
Shuts down the stats tracker.
shutDown() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator
Shuts down the coordinator.
shutdown(Time) - Method in class org.apache.flink.runtime.rest.RestClient
 
shutDown() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Triggers the shut down of the rpc endpoint.
shutdown() - Method in class org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager
 
shutDown() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
Shuts the TaskExecutor services down.
shutdown() - Method in class org.apache.flink.runtime.taskmanager.MemoryLogger
 
shutDownAndTerminate(int, ApplicationStatus, String, boolean) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
shutdownApplication(ApplicationStatus, String) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
The framework specific code for shutting down the application.
shutdownApplication(ApplicationStatus, String) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
shutDownCluster() - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
shutDownCluster() - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
 
ShutdownClusterAfterJob - Class in org.apache.flink.runtime.clusterframework.messages
Message sent to the cluster framework master to signal it that the cluster should be shut down upon completion of a certain job identified by a job id.
ShutdownClusterAfterJob(JobID) - Constructor for class org.apache.flink.runtime.clusterframework.messages.ShutdownClusterAfterJob
 
ShutdownHandler - Class in org.apache.flink.runtime.rest.handler.cluster
REST handler which allows to shut down the cluster.
ShutdownHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, 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
 
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
 
signalTermination() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
 
SignatureVisitorImpl(int) - Constructor for class org.apache.flink.runtime.util.DependencyVisitor.SignatureVisitorImpl
 
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
 
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
 
SimpleSlot - Class in org.apache.flink.runtime.instance
A SimpleSlot represents a single slot on a TaskManager instance, or a slot within a shared slot.
SimpleSlot(SlotOwner, TaskManagerLocation, int, TaskManagerGateway) - Constructor for class org.apache.flink.runtime.instance.SimpleSlot
Creates a new simple slot that stands alone and does not belong to shared slot.
SimpleSlot(SlotOwner, TaskManagerLocation, int, TaskManagerGateway, SharedSlot, AbstractID) - Constructor for class org.apache.flink.runtime.instance.SimpleSlot
Creates a new simple slot that belongs to the given shared slot and is identified by the given ID.
SimpleSlot(SlotContext, SlotOwner, int) - Constructor for class org.apache.flink.runtime.instance.SimpleSlot
Creates a new simple slot that stands alone and does not belong to shared slot.
SimpleSlot(SharedSlot, SlotOwner, int, AbstractID) - Constructor for class org.apache.flink.runtime.instance.SimpleSlot
Creates a new simple slot that belongs to the given shared slot and is identified by the given ID..
SimpleSlotContext - Class in org.apache.flink.runtime.instance
Simple implementation of the SlotContext interface for the legacy code.
SimpleSlotContext(AllocationID, TaskManagerLocation, int, TaskManagerGateway) - Constructor for class org.apache.flink.runtime.instance.SimpleSlotContext
 
SingleElementIterator<E> - Class in org.apache.flink.runtime.util
An Iterator that 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, JobID, IntermediateDataSetID, ResultPartitionType, int, int, TaskActions, TaskIOMetricGroup, boolean) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
SingleJobSubmittedJobGraphStore - Class in org.apache.flink.runtime.dispatcher
SubmittedJobGraphStore implementation for a single job.
SingleJobSubmittedJobGraphStore(JobGraph) - Constructor for class org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
 
SingleLeaderElectionService - Class in org.apache.flink.runtime.highavailability.nonha.leaderelection
An implementation of the LeaderElectionService interface that handles a single leader contender.
SingleLeaderElectionService(Executor, UUID) - Constructor for class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
Creates a new leader election service.
SingleLogicalSlot - Class in org.apache.flink.runtime.jobmaster.slotpool
Implementation of the LogicalSlot which is used by the SlotPool.
SingleLogicalSlot(SlotRequestId, SlotContext, SlotSharingGroupId, Locality, SlotOwner) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
 
singleton(T) - Static method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
 
SIZE - Static variable in class org.apache.flink.runtime.blob.BlobKey
Size of the internal BLOB key in bytes.
size() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
 
size() - Method in interface org.apache.flink.runtime.dispatcher.ArchivedExecutionGraphStore
Returns the current number of stored ArchivedExecutionGraph.
size() - Method in class org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
 
size() - Method in class org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
 
size() - Method in class org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
 
size() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
size() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
size() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool.AvailableSlots
 
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.ExecutionGraphCache
Gets the number of cache entries.
size() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
Returns the total number of entries in this CopyOnWriteStateTable.
size() - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
size() - Method in class org.apache.flink.runtime.state.heap.StateTable
Returns the total number of entries in this NestedMapsStateTable.
size() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
 
size() - Method in class org.apache.flink.runtime.util.IntArrayList
 
size() - Method in class org.apache.flink.runtime.util.LongArrayList
 
sizeOfNamespace(Object) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
sizeOfNamespace(Object) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
sizeOfNamespace(Object) - Method in class org.apache.flink.runtime.state.heap.StateTable
 
skip(long) - Method in class org.apache.flink.runtime.state.BoundedInputStream
 
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
 
Slot - Class in org.apache.flink.runtime.instance
Base class for slots that the Scheduler / ExecutionGraph take from the SlotPool and use to place tasks to execute into.
Slot(SlotOwner, TaskManagerLocation, int, TaskManagerGateway, SharedSlot, AbstractID) - Constructor for class org.apache.flink.runtime.instance.Slot
Base constructor for slots.
Slot(SlotContext, SlotOwner, int, SharedSlot, AbstractID) - Constructor for class org.apache.flink.runtime.instance.Slot
Base constructor for slots.
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
 
SlotAndLocality - Class in org.apache.flink.runtime.jobmaster.slotpool
A combination of a AllocatedSlot and a Locality.
SlotAndLocality(AllocatedSlot, Locality) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.SlotAndLocality
 
SlotAvailabilityListener - Interface in org.apache.flink.runtime.jobmanager.scheduler
A SlotAvailabilityListener can be notified when new Slots become available on an Instance.
SlotContext - Interface in org.apache.flink.runtime.jobmaster
Interface for the context of a LogicalSlot.
SlotException - Exception in org.apache.flink.runtime.jobmanager.slots
Base class for slot related exceptions.
SlotException(String) - Constructor for exception org.apache.flink.runtime.jobmanager.slots.SlotException
 
SlotException(Throwable) - Constructor for exception org.apache.flink.runtime.jobmanager.slots.SlotException
 
SlotException(String, Throwable) - Constructor for exception org.apache.flink.runtime.jobmanager.slots.SlotException
 
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
 
SlotManager - Class 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(ScheduledExecutor, Time, Time, Time) - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
 
SlotManagerConfiguration - Class in org.apache.flink.runtime.resourcemanager.slotmanager
Configuration for the SlotManager.
SlotManagerConfiguration(Time, Time, Time) - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
 
SlotManagerException - Exception in org.apache.flink.runtime.resourcemanager.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
 
SlotNotActiveException - Exception in org.apache.flink.runtime.taskexecutor.slot
Exception indicating that the given TaskSlot was 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 TaskSlot could not be found.
SlotNotFoundException(AllocationID) - Constructor for exception org.apache.flink.runtime.taskexecutor.slot.SlotNotFoundException
 
SlotNotFoundException(String) - 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 - Class in org.apache.flink.runtime.jobmaster.slotpool
The slot pool serves slot request issued by ExecutionGraph.
SlotPool(RpcService, JobID, SchedulingStrategy) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
 
SlotPool(RpcService, JobID, SchedulingStrategy, Clock, Time, Time) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
 
SlotPool.AvailableSlots - Class in org.apache.flink.runtime.jobmaster.slotpool
Organize all available slots from different points of view.
SlotPoolFactory - Interface in org.apache.flink.runtime.jobmaster.slotpool
Factory interface for SlotPool.
SlotPoolGateway - Interface in org.apache.flink.runtime.jobmaster.slotpool
The gateway for calls on the SlotPool.
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.
SlotProfile(ResourceProfile, Collection<TaskManagerLocation>, Collection<AllocationID>) - Constructor for class org.apache.flink.runtime.clusterframework.types.SlotProfile
 
SlotProvider - Interface in org.apache.flink.runtime.jobmaster.slotpool
The slot provider is responsible for preparing slots for ready-to-run tasks.
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(SlotStatus) - Constructor for class org.apache.flink.runtime.taskexecutor.SlotReport
 
SlotReport(Collection<SlotStatus>) - Constructor for class org.apache.flink.runtime.taskexecutor.SlotReport
 
SlotRequest - Class in org.apache.flink.runtime.resourcemanager
This describes the requirement of the slot, mainly used by JobManager requesting slot from ResourceManager.
SlotRequest(JobID, AllocationID, ResourceProfile, String) - Constructor for class org.apache.flink.runtime.resourcemanager.SlotRequest
 
SlotRequestId - Class in org.apache.flink.runtime.jobmaster
This ID identifies the request for a logical slot from the Execution to the SlotPool oe SlotProvider.
SlotRequestId(long, long) - Constructor for class org.apache.flink.runtime.jobmaster.SlotRequestId
 
SlotRequestId() - Constructor for class org.apache.flink.runtime.jobmaster.SlotRequestId
 
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
 
SlotSharingGroup(JobVertexID...) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
SlotSharingGroupAssignment - Class in org.apache.flink.runtime.instance
The SlotSharingGroupAssignment manages a set of shared slots, which are shared between tasks of a SlotSharingGroup.
SlotSharingGroupAssignment() - Constructor for class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
 
SlotSharingGroupId - Class in org.apache.flink.runtime.instance
 
SlotSharingGroupId(long, long) - Constructor for class org.apache.flink.runtime.instance.SlotSharingGroupId
 
SlotSharingGroupId() - Constructor for class org.apache.flink.runtime.instance.SlotSharingGroupId
 
SlotSharingManager - Class in org.apache.flink.runtime.jobmaster.slotpool
Manager which is responsible for slot sharing.
SlotSharingManager.MultiTaskSlot - Class in org.apache.flink.runtime.jobmaster.slotpool
SlotSharingManager.TaskSlot implementation which can have multiple other task slots assigned as children.
SlotSharingManager.SingleTaskSlot - Class in org.apache.flink.runtime.jobmaster.slotpool
SlotSharingManager.TaskSlot implementation which harbours a LogicalSlot.
SlotSharingManager.TaskSlot - Class in org.apache.flink.runtime.jobmaster.slotpool
Base class for all task slots.
slotSharingManagers - Variable in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
Managers for the different slot sharing groups.
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
 
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(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() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo
 
snapshot() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
 
snapshot() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo
 
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 CheckpointStreamFactory and returns a @RunnableFuture that gives a state handle to the snapshot.
Snapshotable<S extends StateObject,R> - Interface in org.apache.flink.runtime.state
Interface for operators that can perform snapshots of their state.
snapshotConfiguration() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
SnapshotDirectory - Class in org.apache.flink.runtime.state
This class represents a directory that is the target for a state 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. A state object that represents the state for the TaskLocalStateStoreImpl. Both state objects are optional and can be null, e.g.
SnapshotStrategy<S extends StateObject> - Interface in org.apache.flink.runtime.state
Interface for different snapshot approaches in state backends.
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 Collector to 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 Collector to 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 IterationHeadTask and the IterationTailTask in 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 Collector to 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, int, int) - Method in class org.apache.flink.runtime.operators.sort.HeapSort
 
sort(IndexedSortable) - 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) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSorter
 
sort(IndexedSortable, int, int) - Method in class org.apache.flink.runtime.operators.sort.QuickSort
Sort the given range of items using quick sort.
sort(IndexedSortable) - Method in class org.apache.flink.runtime.operators.sort.QuickSort
 
Sorter<E> - Interface in org.apache.flink.runtime.operators.sort
The SortMerger interface representing the public interface to all specific Sort-Merge implementations.
SortingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SortingThread
Creates a new sorting thread.
sortReadMemory - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The memory segments used first for sorting and later for reading/pre-fetching during the external merge.
source - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
source - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
SpanningRecordSerializer<T extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.serialization
Record serializer which serializes the complete record to an intermediate data serialization buffer and copies this buffer to target buffers one-by-one using SpanningRecordSerializer.continueWritingWithNextBufferBuilder(BufferBuilder).
SpanningRecordSerializer() - Constructor for class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
 
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
 
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
 
spillingMarker() - Static method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Gets the element that is passed as marker for signal beginning of spilling.
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
 
SpillingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable, MemoryManager, IOManager, TypeSerializer<E>, TypeComparator<E>, List<MemorySegment>, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Creates the spilling thread.
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.
spillPartition() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
Selects a partition and spills it.
SSLEngineFactory - Class in org.apache.flink.runtime.net
Creates and configures SSLEngine instances.
SSLEngineFactory(SSLContext, String[], String[], boolean) - Constructor for class org.apache.flink.runtime.net.SSLEngineFactory
 
SSLStoreOverlay - Class in org.apache.flink.runtime.clusterframework.overlays
Overlays an SSL keystore/truststore into a container.
SSLStoreOverlay(File, File) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay
 
SSLStoreOverlay.Builder - Class in org.apache.flink.runtime.clusterframework.overlays
A builder for the Krb5ConfOverlay.
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
 
StackTrace - Class in org.apache.flink.runtime.messages
 
StackTrace(InstanceID, String) - Constructor for class org.apache.flink.runtime.messages.StackTrace
 
StackTraceSample - Class in org.apache.flink.runtime.rest.handler.legacy.backpressure
A sample of stack traces for one or more tasks.
StackTraceSample(int, long, long, Map<ExecutionAttemptID, List<StackTraceElement[]>>) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSample
Creates a stack trace sample.
StackTraceSampleCoordinator - Class in org.apache.flink.runtime.rest.handler.legacy.backpressure
A coordinator for triggering and collecting stack traces of running tasks.
StackTraceSampleCoordinator(Executor, long) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator
Creates a new coordinator for the job.
StackTraceSampleResponse - Class in org.apache.flink.runtime.messages
Response to the TriggerStackTraceSample message.
StackTraceSampleResponse(int, ExecutionAttemptID, List<StackTraceElement[]>) - Constructor for class org.apache.flink.runtime.messages.StackTraceSampleResponse
 
StandaloneCheckpointIDCounter - Class in org.apache.flink.runtime.checkpoint
CheckpointIDCounter instances for JobManagers running in HighAvailabilityMode.NONE.
StandaloneCheckpointIDCounter() - Constructor for class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
 
StandaloneCheckpointRecoveryFactory - Class in org.apache.flink.runtime.checkpoint
StandaloneCheckpointRecoveryFactory() - Constructor for class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
 
StandaloneCompletedCheckpointStore - Class in org.apache.flink.runtime.checkpoint
StandaloneCompletedCheckpointStore(int) - Constructor for class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
StandaloneDispatcher - Class in org.apache.flink.runtime.dispatcher
Dispatcher implementation which spawns a JobMaster for each submitted JobGraph within in the same process.
StandaloneDispatcher(RpcService, String, Configuration, HighAvailabilityServices, ResourceManagerGateway, BlobServer, HeartbeatServices, JobManagerMetricGroup, String, ArchivedExecutionGraphStore, Dispatcher.JobManagerRunnerFactory, FatalErrorHandler, String, HistoryServerArchivist) - Constructor for class org.apache.flink.runtime.dispatcher.StandaloneDispatcher
 
StandaloneHaServices - Class in org.apache.flink.runtime.highavailability.nonha.standalone
An implementation of the HighAvailabilityServices for the non-high-availability case.
StandaloneHaServices(String, 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.
StandaloneLeaderElectionService - Class in org.apache.flink.runtime.leaderelection
Standalone implementation of the LeaderElectionService interface.
StandaloneLeaderElectionService() - Constructor for class org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
 
StandaloneLeaderRetrievalService - Class in org.apache.flink.runtime.leaderretrieval
Standalone implementation of the LeaderRetrievalService.
StandaloneLeaderRetrievalService(String) - Constructor for class org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
StandaloneLeaderRetrievalService(String, UUID) - Constructor for class org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
Creates a StandaloneLeaderRetrievalService with the given leader address.
StandaloneMiniCluster - Class in org.apache.flink.runtime.minicluster
Mini cluster to run the old JobManager code without embedded high availability services.
StandaloneMiniCluster(Configuration) - Constructor for class org.apache.flink.runtime.minicluster.StandaloneMiniCluster
 
StandaloneResourceManager - Class in org.apache.flink.runtime.clusterframework.standalone
A standalone implementation of the resource manager.
StandaloneResourceManager(Configuration, LeaderRetrievalService) - Constructor for class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
StandaloneResourceManager - Class in org.apache.flink.runtime.resourcemanager
A standalone implementation of the resource manager.
StandaloneResourceManager(RpcService, String, ResourceID, ResourceManagerConfiguration, HighAvailabilityServices, HeartbeatServices, SlotManager, MetricRegistry, JobLeaderIdService, ClusterInformation, FatalErrorHandler) - Constructor for class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
 
StandaloneRunningJobsRegistry - Class in org.apache.flink.runtime.highavailability.nonha.standalone
A registry for running jobs, not-highly available.
StandaloneRunningJobsRegistry() - Constructor for class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
 
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
 
StandaloneSubmittedJobGraphStore - Class in org.apache.flink.runtime.jobmanager
SubmittedJobGraph instances for JobManagers running in HighAvailabilityMode.NONE.
StandaloneSubmittedJobGraphStore() - Constructor for class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
 
StandaloneUtils - Class in org.apache.flink.runtime.util
Utility class to work with Flink standalone mode.
start() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
Starts the CheckpointIDCounter service down.
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.Dispatcher
 
start(SubmittedJobGraphStore.SubmittedJobGraphListener) - Method in class org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
 
start(LeaderContender) - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
 
start(ResultPartitionProvider, TaskEventDispatcher) - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
 
start(ResultPartitionProvider, TaskEventDispatcher) - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
 
start(ResultPartitionProvider, TaskEventDispatcher) - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
 
start() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
start(SubmittedJobGraphStore.SubmittedJobGraphListener) - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
 
start(SubmittedJobGraphStore.SubmittedJobGraphListener) - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
Starts the SubmittedJobGraphStore service.
start(SubmittedJobGraphStore.SubmittedJobGraphListener) - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
 
start() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
 
start() - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
start(JobMasterId, Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
Start the rpc service and begin to run the job.
start() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
 
start(JobMasterId, String) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
Start the slot pool to accept RPC calls.
start(LeaderContender) - Method in interface org.apache.flink.runtime.leaderelection.LeaderElectionService
Starts the leader election service.
start(LeaderContender) - Method in class org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
 
start(LeaderContender) - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
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.SettableLeaderRetrievalService
 
start(LeaderRetrievalListener) - Method in class org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
 
start(LeaderRetrievalListener) - Method in class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
 
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.query.KvStateServer
Starts the server.
start() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
 
start(JobLeaderIdActions) - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
Start the service with the given job leader actions.
start() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
start() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRunner
 
start(ResourceManagerId, Executor, ResourceActions) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Starts the slot manager with the given leader id and resource manager actions.
start() - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
Starts this REST server endpoint.
start() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Starts the rpc endpoint.
start() - Method in interface org.apache.flink.runtime.rpc.StartStoppable
Starts the processing of remote procedure calls.
start(String, RpcService, HighAvailabilityServices, JobLeaderListener) - Method in class org.apache.flink.runtime.taskexecutor.JobLeaderService
Start the job leader service with the given services.
start(SlotActions) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Start the task slot table with the given slot actions and slot timeout value.
start(TimeoutListener<K>) - Method in class org.apache.flink.runtime.taskexecutor.slot.TimerService
 
start() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
start() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
start() - Method in interface org.apache.flink.runtime.webmonitor.WebMonitor
Starts the web monitor.
start() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
 
start() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
 
startActorSystem(Configuration, String, String, Logger) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
Starts an ActorSystem with the given configuration listening at the address/ports.
startActorSystem(Configuration, String, int, Logger) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
Starts an Actor System at a specific port.
startCheckpointScheduler() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
startCluster() - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
startClusterComponents(Configuration, RpcService, HighAvailabilityServices, BlobServer, HeartbeatServices, MetricRegistry) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
startCuratorFramework(Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
Starts a CuratorFramework instance and connects it to the given ZooKeeper quorum.
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
 
startJobClientActorSystem(Configuration, String) - Static method in class org.apache.flink.runtime.client.JobClient
 
startMetricQueryService(ActorSystem, ResourceID) - Static method in class org.apache.flink.runtime.metrics.dump.MetricQueryService
Starts the MetricQueryService actor in the given actor system.
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.
startNewWorker(ResourceProfile) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
Allocates a resource using the resource profile.
startNewWorker(ResourceProfile) - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
 
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
 
startQueryService(ActorSystem, ResourceID) - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
Initializes the MetricQueryService.
startReading() - Method in class org.apache.flink.runtime.operators.TempBarrier
 
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.
startResourceManager(Configuration, HighAvailabilityServices, HeartbeatServices, MetricRegistry, RpcService, ClusterInformation) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
 
startResourceManagerActors(Configuration, ActorSystem, LeaderRetrievalService, Class<? extends FlinkResourceManager<?>>) - Static method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Starts the resource manager actors.
startResourceManagerActors(Configuration, ActorSystem, LeaderRetrievalService, Class<? extends FlinkResourceManager<?>>, String) - Static method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Starts the resource manager actors.
startServer(C) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
startServer(C) - Method in interface org.apache.flink.runtime.rpc.RpcService
Start a rpc server which forwards the remote procedure calls to the provided rpc endpoint.
StartStoppable - Interface in org.apache.flink.runtime.rpc
Interface to start and stop the processing of rpc calls in the rpc server.
startTaskManager(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, BlobCacheService, boolean, FatalErrorHandler) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
startTaskManagers(Configuration, HighAvailabilityServices, HeartbeatServices, MetricRegistry, BlobCacheService, int, RpcService[]) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
 
startTaskThread() - Method in class org.apache.flink.runtime.taskmanager.Task
Starts the task's thread.
startThreads() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Starts all the threads that are used by this sort-merger.
STARTUP_FAILURE_RETURN_CODE - Static variable in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
startWebMonitorIfConfigured(Configuration, HighAvailabilityServices, LeaderGatewayRetriever<JobManagerGateway>, MetricQueryServiceRetriever, Time, ScheduledExecutor, Logger) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
Starts the web frontend.
startWebRuntimeMonitor(Configuration, HighAvailabilityServices, LeaderGatewayRetriever<JobManagerGateway>, MetricQueryServiceRetriever, Time, ScheduledExecutor) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
Starts the web runtime monitor.
state - Variable in class org.apache.flink.runtime.state.SnapshotDirectory
This reference tracks the lifecycle state of the snapshot directory.
StateAssignmentOperation - Class in org.apache.flink.runtime.checkpoint
This class encapsulates the operation of assigning restored state when restoring from a checkpoint.
StateAssignmentOperation(long, Map<JobVertexID, ExecutionJobVertex>, Map<OperatorID, OperatorState>, boolean) - Constructor for class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
 
StateBackend - Interface in org.apache.flink.runtime.state
A State Backend defines how the state of a streaming application is stored and checkpointed.
StateBackendFactory<T extends StateBackend> - Interface in org.apache.flink.runtime.state
A factory to create a specific state backend.
StateBackendLoader - Class in org.apache.flink.runtime.state
This class contains utility methods to load state backends from configurations.
StateEntry<K,N,S> - Interface in org.apache.flink.runtime.state.heap
Interface of entries in a state table.
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
 
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.
StateInitializationContextImpl - Class in org.apache.flink.runtime.state
Default implementation of StateInitializationContext.
StateInitializationContextImpl(boolean, OperatorStateStore, KeyedStateStore, Iterable<KeyGroupStatePartitionStreamProvider>, Iterable<StatePartitionStreamProvider>) - Constructor for class org.apache.flink.runtime.state.StateInitializationContextImpl
 
stateLock - Variable in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
The lock to synchronize state changes (open / close) on
stateMetaInfo - Variable in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractOperatorBackendStateMetaInfoWriter
 
StateMetaInfo(long[], OperatorStateHandle.Mode) - Constructor for class org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
 
StateObject - Interface in org.apache.flink.runtime.state
Base of all handles that represent checkpointed state in some form.
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(IOException) - Constructor for class org.apache.flink.runtime.state.StatePartitionStreamProvider
 
StatePartitionStreamProvider(InputStream) - Constructor for class org.apache.flink.runtime.state.StatePartitionStreamProvider
 
StateSnapshotContext - Interface in org.apache.flink.runtime.state
This interface provides a context in which operators that use managed (i.e.
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
 
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>, RegisteredKeyedBackendStateMetaInfo<N, S>) - Constructor for class org.apache.flink.runtime.state.heap.StateTable
 
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.
StateUtil - Class in org.apache.flink.runtime.state
Helpers for StateObject related code.
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>, CompletableFuture<String>, Time, File) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
 
StatusHandler(CompletableFuture<String>, GatewayRetriever<? extends T>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, AsynchronousOperationResult<V>, M>) - Constructor for class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.StatusHandler
 
StatusListenerMessenger - Class in org.apache.flink.runtime.executiongraph
A JobStatusListener and ExecutionStatusListener that sends an actor message for each status change.
StatusListenerMessenger(ActorRef, UUID) - Constructor for class org.apache.flink.runtime.executiongraph.StatusListenerMessenger
 
stddev - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
stdOutFile - Variable in class org.apache.flink.runtime.webmonitor.WebMonitorUtils.LogFileLocation
 
StdoutFileHandlerSpecification - Class in org.apache.flink.runtime.rest.handler.legacy.files
Rest handler specification for the stdout file of the main cluster component.
stop() - Method in class org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
 
stop() - Method in class org.apache.flink.runtime.executiongraph.Execution
Sends stop RPC call.
stop() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
stop() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
stop() - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatManager
Stops the heartbeat manager.
stop() - Method in class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
 
stop() - Method in class org.apache.flink.runtime.heartbeat.HeartbeatManagerSenderImpl
 
stop() - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
 
stop() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
Stops the I/O operation by closing the I/O handle.
stop() - Method in interface org.apache.flink.runtime.io.async.AsyncStoppable
Stop the operation
stop() - Method in interface org.apache.flink.runtime.jobgraph.tasks.StoppableTask
Called on STOP signal.
stop() - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
 
stop() - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
Stops the SubmittedJobGraphStore service.
stop() - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
 
stop(Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
stop(Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Cancel the currently executed job.
stop() - Method in interface org.apache.flink.runtime.leaderelection.LeaderElectionService
Stops the leader election service.
stop() - Method in class org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
 
stop() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
stop() - Method in interface org.apache.flink.runtime.leaderretrieval.LeaderRetrievalService
Stops the leader retrieval service.
stop() - Method in class org.apache.flink.runtime.leaderretrieval.SettableLeaderRetrievalService
 
stop() - Method in class org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
 
stop() - Method in class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
 
stop() - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
Stop the service.
stop() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Stops the rpc endpoint.
stop() - Method in interface org.apache.flink.runtime.rpc.StartStoppable
Stops the processing of remote procedure calls.
stop() - Method in class org.apache.flink.runtime.taskexecutor.JobLeaderService
Stop the job leader services.
stop() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Stop the task slot table.
stop() - Method in class org.apache.flink.runtime.taskexecutor.slot.TimerService
 
stop() - Method in interface org.apache.flink.runtime.webmonitor.WebMonitor
Stops the web server.
stopCheckpointScheduler() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
StopCluster - Class in org.apache.flink.runtime.clusterframework.messages
Generic message to signal the cluster framework to shut the cluster down.
StopCluster(ApplicationStatus, String) - Constructor for class org.apache.flink.runtime.clusterframework.messages.StopCluster
 
stopCluster(ApplicationStatus, String) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
stopCluster(ApplicationStatus, String) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Stop the cluster.
stopCluster(ApplicationStatus, String) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
stopClusterComponents() - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
stopClusterServices(boolean) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
StopClusterSuccessful - Class in org.apache.flink.runtime.clusterframework.messages
Generic message to signal the cluster listener that the cluster has been shut down.
stopExecution() - Method in class org.apache.flink.runtime.taskmanager.Task
Stops the executing task by calling StoppableTask.stop().
stopJob(JobID, Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
 
stopJob(JobID, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
stopJob(JobID, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerGateway
Stops the given job.
stopJob(JobID) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
 
stopJob(JobID, Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
Stop the given job.
stopOperation() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncCallableWithResources
This method implements how the operation is stopped.
stoppableCallbackCallable - Variable in class org.apache.flink.runtime.io.async.AsyncStoppableTaskWithCallback
 
StoppableCallbackCallable<V> - Interface in org.apache.flink.runtime.io.async
A Callable that can be stopped and offers a callback on termination.
StoppableTask - Interface in org.apache.flink.runtime.jobgraph.tasks
Implemented by tasks that can receive STOP signal.
stopped - Variable in class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
Running state of the heartbeat manager.
StoppingException - Exception in org.apache.flink.runtime
Indicates that a job is not stoppable.
StoppingException(String) - Constructor for exception org.apache.flink.runtime.StoppingException
 
StoppingException(String, Throwable) - Constructor for exception org.apache.flink.runtime.StoppingException
 
StoppingSupervisorWithoutLoggingActorKilledExceptionStrategy - Class in org.apache.flink.runtime.akka
Stopping supervisor strategy which logs ActorKilledException only on debug log level.
StoppingSupervisorWithoutLoggingActorKilledExceptionStrategy() - Constructor for class org.apache.flink.runtime.akka.StoppingSupervisorWithoutLoggingActorKilledExceptionStrategy
 
stopServer(RpcServer) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
stopServer(RpcServer) - Method in interface org.apache.flink.runtime.rpc.RpcService
Stop the underlying rpc server of the provided self gateway.
stopService() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
stopService() - Method in interface org.apache.flink.runtime.rpc.RpcService
Trigger the asynchronous stopping of the RpcService.
stopTask(ExecutionAttemptID, Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
stopTask(ExecutionAttemptID, Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Stop the given task.
stopTask(ExecutionAttemptID, Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
stopTask(ExecutionAttemptID, Time) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
stopTask(ExecutionAttemptID, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Stop the given task.
stopWorker(WorkerType) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
Stops the given worker.
stopWorker(ResourceID) - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
 
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.zookeeper.filesystem.FileSystemStateStorageHelper
 
store(T) - Method in interface org.apache.flink.runtime.zookeeper.RetrievableStateStorageHelper
Stores the given state and returns a state handle to it.
storeCheckpointMetadata(T, OutputStream) - Static method in class org.apache.flink.runtime.checkpoint.Checkpoints
 
storeCheckpointMetadata(T, DataOutputStream) - Static method in class org.apache.flink.runtime.checkpoint.Checkpoints
 
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
 
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
 
StreamStateHandle - Interface in org.apache.flink.runtime.state
A StateObject that represents state that was written to a stream.
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.
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.JobManagerJobMetricGroup
 
subComponents() - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
subComponents() - Method in class org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
 
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
 
submitJob(JobGraph, ListeningBehaviour, Time) - Method in class org.apache.flink.runtime.akka.AkkaJobManagerGateway
 
submitJob(ActorSystem, Configuration, HighAvailabilityServices, JobGraph, FiniteDuration, boolean, ClassLoader) - Static method in class org.apache.flink.runtime.client.JobClient
Submits a job to a Flink cluster (non-blocking) and returns a JobListeningContext which can be passed to awaitJobResult to get the result of the submission.
submitJob(JobGraph, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
submitJob(JobGraph, Time) - Method in interface org.apache.flink.runtime.dispatcher.DispatcherGateway
Submit a job to the dispatcher.
submitJob(JobGraph, Time) - Method in class org.apache.flink.runtime.dispatcher.MiniDispatcher
 
submitJob(JobGraph, ListeningBehaviour, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobManagerGateway
Submits a job to the JobManager.
submitJob(JobGraph) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
 
submitJobAndWait(ActorSystem, Configuration, HighAvailabilityServices, JobGraph, FiniteDuration, boolean, ClassLoader) - Static method in class org.apache.flink.runtime.client.JobClient
Sends a [[JobGraph]] to the JobClient actor specified by jobClient which submits it then to the JobManager.
submitJobDetached(JobManagerGateway, Configuration, JobGraph, Time, ClassLoader) - Static method in class org.apache.flink.runtime.client.JobClient
Submits a job in detached mode.
submitTask(TaskDeploymentDescriptor, Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
submitTask(TaskDeploymentDescriptor, Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Submit a task to the task manager.
submitTask(TaskDeploymentDescriptor, Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
submitTask(TaskDeploymentDescriptor, JobMasterId, Time) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
submitTask(TaskDeploymentDescriptor, JobMasterId, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Submit a Task to the TaskExecutor.
SubmittedJobGraph - Class in org.apache.flink.runtime.jobmanager
A recoverable JobGraph and JobInfo.
SubmittedJobGraph(JobGraph, JobInfo) - Constructor for class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
SubmittedJobGraphStore - Interface in org.apache.flink.runtime.jobmanager
SubmittedJobGraph instances for recovery.
SubmittedJobGraphStore.SubmittedJobGraphListener - Interface in org.apache.flink.runtime.jobmanager
A listener for SubmittedJobGraph instances.
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.
SUBTASK_CURRENT_ATTEMPT_DETAILS_REST_PATH - Static variable in class org.apache.flink.runtime.rest.handler.legacy.SubtaskCurrentAttemptDetailsHandler
 
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
 
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, JobVertexBackPressureInfo.VertexBackPressureLevel, double) - Constructor for class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
 
subtaskBaseDirectory(long) - Method in interface org.apache.flink.runtime.state.LocalRecoveryDirectoryProvider
Returns the local state directory for the owning subtask the given checkpoint id w.r.t.
subtaskBaseDirectory(long) - Method in class org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
 
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.
SubtaskCurrentAttemptDetailsHandler - Class in org.apache.flink.runtime.rest.handler.job
Request handler providing details about a single task execution attempt.
SubtaskCurrentAttemptDetailsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, SubtaskExecutionAttemptDetailsInfo, SubtaskMessageParameters>, ExecutionGraphCache, Executor, MetricFetcher<?>) - Constructor for class org.apache.flink.runtime.rest.handler.job.SubtaskCurrentAttemptDetailsHandler
 
SubtaskCurrentAttemptDetailsHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Request handler providing details about a single task execution attempt.
SubtaskCurrentAttemptDetailsHandler(ExecutionGraphCache, Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, 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.
SubtaskExecutionAttemptAccumulatorsHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Base class for request handlers whose response depends on a specific job vertex (defined via the "vertexid" parameter) in a specific job, defined via (defined voa the "jobid" parameter).
SubtaskExecutionAttemptAccumulatorsHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptAccumulatorsHandler
 
SubtaskExecutionAttemptAccumulatorsHandler.SubtaskExecutionAttemptAccumulatorsJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy
Archivist for the SubtaskExecutionAttemptAccumulatorsHandler.
SubtaskExecutionAttemptAccumulatorsHeaders - Class in org.apache.flink.runtime.rest.messages.job
SubtaskExecutionAttemptAccumulatorsHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
 
SubtaskExecutionAttemptAccumulatorsInfo - Class in org.apache.flink.runtime.rest.messages.job
SubtaskExecutionAttemptAccumulatorsInfo(int, int, String, Collection<UserAccumulator>) - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsInfo
 
SubtaskExecutionAttemptAccumulatorsJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptAccumulatorsHandler.SubtaskExecutionAttemptAccumulatorsJsonArchivist
 
SubtaskExecutionAttemptDetailsHandler - Class in org.apache.flink.runtime.rest.handler.job
Handler of specific sub task execution attempt.
SubtaskExecutionAttemptDetailsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, 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.
SubtaskExecutionAttemptDetailsHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Request handler providing details about a single task execution attempt.
SubtaskExecutionAttemptDetailsHandler(ExecutionGraphCache, Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptDetailsHandler
 
SubtaskExecutionAttemptDetailsHandler.SubtaskExecutionAttemptDetailsJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy
Archivist for the SubtaskExecutionAttemptDetailsHandler.
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) - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
 
SubtaskExecutionAttemptDetailsJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.SubtaskExecutionAttemptDetailsHandler.SubtaskExecutionAttemptDetailsJsonArchivist
 
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() - 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
 
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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.SubtaskMetricsHandler
 
SubtaskMetricsHandler - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
Request handler that returns, aggregated across all subtasks of a single tasks, a list of all available metrics or the values for a set of metrics.
SubtaskMetricsHandler(Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.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
 
SubtasksAllAccumulatorsHandler - Class in org.apache.flink.runtime.rest.handler.job
Request handler for the subtasks all accumulators.
SubtasksAllAccumulatorsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, SubtasksAllAccumulatorsInfo, JobVertexMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.SubtasksAllAccumulatorsHandler
 
SubtasksAllAccumulatorsHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Request handler that returns the accumulators for all subtasks of job vertex.
SubtasksAllAccumulatorsHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.SubtasksAllAccumulatorsHandler
 
SubtasksAllAccumulatorsHandler.SubtasksAllAccumulatorsJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy
Archivist for the 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.
SubtasksAllAccumulatorsJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.SubtasksAllAccumulatorsHandler.SubtasksAllAccumulatorsJsonArchivist
 
SubtasksFilterQueryParameter - Class in org.apache.flink.runtime.rest.messages.job.metrics
MessageQueryParameter for selecting subtasks when aggregating metrics.
subtaskSpecificCheckpointDirectory(long) - Method in interface org.apache.flink.runtime.state.LocalRecoveryDirectoryProvider
Returns the local state directory for the specific operator subtask and the given checkpoint id w.r.t.
subtaskSpecificCheckpointDirectory(long) - Method in class org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
 
SubtaskState - Class in org.apache.flink.runtime.checkpoint
Container for the chained state of one parallel subtask of an operator/task.
SubtaskState(ChainedStateHandle<OperatorStateHandle>, ChainedStateHandle<OperatorStateHandle>, KeyedStateHandle, KeyedStateHandle) - Constructor for class org.apache.flink.runtime.checkpoint.SubtaskState
 
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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, SubtasksTimesInfo, JobVertexMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.SubtasksTimesHandler
 
SubtasksTimesHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Request handler that returns the state transition timestamps for all subtasks, plus their location and duration.
SubtasksTimesHandler(ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.SubtasksTimesHandler
 
SubtasksTimesHandler.SubtasksTimesJsonArchivist - Class in org.apache.flink.runtime.rest.handler.legacy
Archivist for the 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.
SubtasksTimesJsonArchivist() - Constructor for class org.apache.flink.runtime.rest.handler.legacy.SubtasksTimesHandler.SubtasksTimesJsonArchivist
 
SubtaskTimeInfo(int, String, long, Map<ExecutionState, Long>) - Constructor for class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
 
Success() - Constructor for class org.apache.flink.runtime.registration.RegistrationResponse.Success
 
SUCCESS_RETURN_CODE - Static variable in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
 
Summary(MinMaxAvgStatistics, MinMaxAvgStatistics, MinMaxAvgStatistics) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
 
Summary(MinMaxAvgStatistics, MinMaxAvgStatistics, TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration, TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment) - 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
supplyAsync(SupplierWithException<T, ?>, Executor) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
Returns a future which is completed with the result of the SupplierWithException.
supportsAsynchronousSnapshots() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
supportsAsynchronousSnapshots() - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
supportsHighlyAvailableStorage() - Method in interface org.apache.flink.runtime.state.CheckpointStorage
Checks whether this backend supports highly available storage of data.
supportsHighlyAvailableStorage() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
 
supportsHighlyAvailableStorage() - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
 
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(Throwable) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Suspends the current ExecutionGraph.
suspend(Exception, Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
Suspending job, all the running tasks will be cancelled, and communication with other components will be disposed.
suspend() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
Suspends this pool, meaning it has lost its authority to accept and distribute slots.
suspend() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolGateway
 
suspend() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Suspends the component.
swap(int, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
swap(int, int, 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, int, int) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
Swap records 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.NormalizedKeySorter
 
switchBuffers() - Method in class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
 
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.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
 
SyncEventHandler - Class in org.apache.flink.runtime.iterative.task
Listener for WorkerDoneEvent which 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
 
SynchronousBufferFileReader - Class in org.apache.flink.runtime.io.disk.iomanager
A synchronous BufferFileReader implementation.
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
 
SystemClock - Class in org.apache.flink.runtime.util.clock
A clock that returns the time of the system / process.

T

tagAsEvent() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
Tags this buffer to represent an event.
tagAsEvent() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
tagAsEvent() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
takeNext(BlockingQueue<UnilateralSortMerger.CircularElement<E>>, Queue<UnilateralSortMerger.CircularElement<E>>) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
targetPartition - Variable in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
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, int, int, Collection<ResultPartitionDeploymentDescriptor>, Collection<InputGateDeploymentDescriptor>, int, MemoryManager, IOManager, NetworkEnvironment, BroadcastVariableManager, TaskStateManager, TaskManagerActions, InputSplitProvider, CheckpointResponder, BlobCacheService, LibraryCacheManager, FileCache, TaskManagerRuntimeInfo, TaskMetricGroup, ResultPartitionConsumableNotifier, PartitionProducerStateChecker, Executor) - 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_MANAGER_ID_KEY - Static variable in class org.apache.flink.runtime.rest.handler.legacy.TaskManagersHandler
 
TASK_MANAGER_NAME - Static variable in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
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_HOST - 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
 
TaskActions - Interface in org.apache.flink.runtime.taskmanager
Actions which can be performed on a Task.
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(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, TaskCheckpointStatisticsWithSubtaskDetails, TaskCheckpointMessageParameters>, ExecutionGraphCache, Executor, 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, int, int) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
 
TaskCheckpointStatisticsHeaders - Class in org.apache.flink.runtime.rest.messages.checkpoints
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, 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, or JoinDriver) 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, int, int, int, JobManagerTaskRestore, Collection<ResultPartitionDeploymentDescriptor>, Collection<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 BlobServer or 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.
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 EventListener instances and allows to to publish events to them.
TaskEventHandler() - Constructor for class org.apache.flink.runtime.io.network.api.TaskEventHandler
 
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(JobID, 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(JobID, 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(JobID, 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.
TaskExecutionStateListener - Interface in org.apache.flink.runtime.taskmanager
 
TaskExecutor - Class in org.apache.flink.runtime.taskexecutor
TaskExecutor implementation.
TaskExecutor(RpcService, TaskManagerConfiguration, HighAvailabilityServices, TaskManagerServices, HeartbeatServices, TaskManagerMetricGroup, BlobCacheService, FatalErrorHandler) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
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
 
TaskExecutorGateway - Interface in org.apache.flink.runtime.taskexecutor
TaskExecutor RPC gateway interface.
TaskExecutorLocalStateStoresManager - Class in org.apache.flink.runtime.state
This class holds the all TaskLocalStateStoreImpl objects for a task executor (manager).
TaskExecutorLocalStateStoresManager(boolean, File[], Executor) - Constructor for class org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager
 
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, long, ClusterInformation) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
Create a new TaskExecutorRegistrationSuccess message.
TaskExecutorToResourceManagerConnection - Class in org.apache.flink.runtime.taskexecutor
The connection between a TaskExecutor and the ResourceManager.
TaskExecutorToResourceManagerConnection(Logger, RpcService, String, ResourceID, int, HardwareDescription, String, ResourceManagerId, Executor, RegistrationConnectionListener<TaskExecutorToResourceManagerConnection, TaskExecutorRegistrationSuccess>) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskExecutorToResourceManagerConnection
 
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
 
TaskInputSplitProvider - Class in org.apache.flink.runtime.taskmanager
Implementation using ActorGateway to forward the messages.
TaskInputSplitProvider(ActorGateway, JobID, JobVertexID, ExecutionAttemptID, FiniteDuration) - Constructor for class org.apache.flink.runtime.taskmanager.TaskInputSplitProvider
 
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
 
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
 
TaskManagerActions - Interface in org.apache.flink.runtime.taskmanager
Interface for the communication of the Task with the TaskManager.
TaskManagerCliOptions - Class in org.apache.flink.runtime.taskmanager
The command line parameters passed to the TaskManager.
TaskManagerCliOptions() - Constructor for class org.apache.flink.runtime.taskmanager.TaskManagerCliOptions
 
TaskManagerConfiguration - Class in org.apache.flink.runtime.taskexecutor
Configuration object for TaskExecutor.
TaskManagerConfiguration(int, String[], Time, Time, Time, Time, Time, Configuration, boolean, FlinkUserCodeClassLoaders.ResolveOrder, String[], String, String) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
TaskManagerDetailsHandler - Class in org.apache.flink.runtime.rest.handler.taskmanager
Handler which serves detailed TaskManager information.
TaskManagerDetailsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, 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 TaskManagerDetailsHandler which serves the TaskManager details.
TaskManagerDetailsInfo - Class in org.apache.flink.runtime.rest.messages.taskmanager
Message containing base information about a TaskExecutor and more detailed metrics.
TaskManagerDetailsInfo(ResourceID, String, int, long, int, int, HardwareDescription, TaskManagerMetricsInfo) - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsInfo
 
TaskManagerDetailsInfo(TaskManagerInfo, TaskManagerMetricsInfo) - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsInfo
 
taskManagerDirectMemoryLimitMB() - Method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
 
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
 
TaskManagerGateway - Interface in org.apache.flink.runtime.jobmanager.slots
Task manager gateway interface to communicate with the task manager.
taskManagerHeapSizeMB() - Method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
 
taskManagerID - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskManagerQueryScopeInfo
 
taskManagerId() - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
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(ResourceID, String, int, long, int, int, HardwareDescription) - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
 
TaskManagerJobMetricGroup - Class in org.apache.flink.runtime.metrics.groups
Special MetricGroup representing 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.
TaskManagerLogFileHandler - Class in org.apache.flink.runtime.rest.handler.taskmanager
Rest handler which serves the log files from TaskExecutor.
TaskManagerLogFileHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, UntypedResponseMessageHeaders<EmptyRequestBody, TaskManagerMessageParameters>, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, Time) - 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.
TaskManagerLogHandler - Class in org.apache.flink.runtime.rest.handler.legacy
Request handler that returns the TaskManager log/out files.
TaskManagerLogHandler(GatewayRetriever<JobManagerGateway>, Executor, CompletableFuture<String>, Time, TaskManagerLogHandler.FileMode, Configuration) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.TaskManagerLogHandler
 
TaskManagerLogHandler.FileMode - Enum in org.apache.flink.runtime.rest.handler.legacy
Used to control whether this handler serves the .log or .out file.
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 MetricGroup representing a TaskManager.
TaskManagerMetricGroup(MetricRegistry, String, String) - Constructor for class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
TaskManagerMetricsHandler - Class in org.apache.flink.runtime.rest.handler.job.metrics
Handler that returns TaskManager metrics.
TaskManagerMetricsHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.TaskManagerMetricsHandler
 
TaskManagerMetricsHandler - Class in org.apache.flink.runtime.rest.handler.legacy.metrics
Request handler that returns for a given task manager a list of all available metrics or the values for a set of metrics.
TaskManagerMetricsHandler(Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.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, 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
 
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
 
TaskManagerRegistration - Class in org.apache.flink.runtime.resourcemanager.slotmanager
 
TaskManagerRegistration(TaskExecutorConnection, Collection<SlotID>) - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
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, ResourceID) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
TaskManagerRuntimeInfo - Interface in org.apache.flink.runtime.taskmanager
Interface to access TaskManager information.
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
Container for TaskExecutor services such as the MemoryManager, IOManager, NetworkEnvironment.
TaskManagerServicesConfiguration - Class in org.apache.flink.runtime.taskexecutor
Configuration for the task manager services such as the network environment, the memory manager, the io manager and the metric registry.
TaskManagerServicesConfiguration(InetAddress, String[], String[], boolean, NetworkEnvironmentConfiguration, QueryableStateConfiguration, int, long, MemoryType, boolean, float, long) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
TaskManagersFilterQueryParameter - Class in org.apache.flink.runtime.rest.messages.job.metrics
MessageQueryParameter for selecting task managers when aggregating metrics.
TaskManagersHandler - Class in org.apache.flink.runtime.rest.handler.legacy
A request handler that provides an overview over all taskmanagers or details for a single one.
TaskManagersHandler(Executor, Time, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.TaskManagersHandler
 
TaskManagersHandler - Class in org.apache.flink.runtime.rest.handler.taskmanager
Returns an overview over all registered TaskManagers of the cluster.
TaskManagersHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, 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(String, ExecutionState, long, long, long, IOMetricsInfo, Map<ExecutionState, Integer>) - Constructor for class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo.TaskManagersInfo
 
TaskManagersInfo - Class in org.apache.flink.runtime.rest.messages.taskmanager
Class containing a collection of TaskManagerInfo.
TaskManagersInfo(Collection<TaskManagerInfo>) - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersInfo
 
TaskManagerSlot - Class in org.apache.flink.runtime.clusterframework.types
A TaskManagerSlot represents a slot located in a TaskManager.
TaskManagerSlot(SlotID, ResourceProfile, TaskExecutorConnection) - Constructor for class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
TaskManagerSlot.State - Enum in org.apache.flink.runtime.clusterframework.types
State of the TaskManagerSlot.
TaskManagerStdoutFileHandler - Class in org.apache.flink.runtime.rest.handler.taskmanager
Rest handler which serves the stdout file of the TaskExecutor.
TaskManagerStdoutFileHandler(CompletableFuture<String>, GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, UntypedResponseMessageHeaders<EmptyRequestBody, TaskManagerMessageParameters>, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, Time) - Constructor for class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerStdoutFileHandler
 
TaskManagerStdoutFileHeaders - Class in org.apache.flink.runtime.rest.messages.taskmanager
taskManagerTotalMemoryMB() - Method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
 
TaskMetricGroup - Class in org.apache.flink.runtime.metrics.groups
Special MetricGroup representing a Flink runtime Task.
TaskMetricGroup(MetricRegistry, TaskManagerJobMetricGroup, JobVertexID, AbstractID, String, int, int) - Constructor for class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
taskName() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
taskName - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
TaskQueryScopeInfo(String, String, int) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
 
TaskQueryScopeInfo(String, String, 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 - Class in org.apache.flink.runtime.taskexecutor.slot
Container for multiple Task belonging to the same slot.
TaskSlotTable - Class in org.apache.flink.runtime.taskexecutor.slot
Container for multiple TaskSlot instances.
TaskSlotTable(Collection<ResourceProfile>, TimerService<AllocationID>) - Constructor for class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
 
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 TaskStateManager and collaborates with the job manager through CheckpointResponder) as well as a task-manager-local state store.
TaskStateManagerImpl(JobID, ExecutionAttemptID, TaskLocalStateStore, JobManagerTaskRestore, CheckpointResponder) - 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) - 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
 
TaskSubmissionException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
Exception indicating a problem with the Task submission at the TaskException.
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
 
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
 
tell(Object) - Method in interface org.apache.flink.runtime.instance.ActorGateway
Sends a message asynchronously without a result.
tell(Object, ActorGateway) - Method in interface org.apache.flink.runtime.instance.ActorGateway
Sends a message asynchronously without a result with sender being the sender.
tell(Object) - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
Sends a message asynchronously without a result.
tell(Object, ActorGateway) - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
Sends a message asynchronously without a result with sender being the sender.
tell(Object) - Method in class org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
 
TempBarrier<T> - Class in org.apache.flink.runtime.operators
 
TempBarrier(AbstractInvokable, MutableObjectIterator<T>, TypeSerializerFactory<T>, MemoryManager, IOManager, int) - 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(Path) - Static method in class org.apache.flink.runtime.state.SnapshotDirectory
Creates a 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.client.JobClientActor
 
TERMINATED_PAYLOAD - Static variable in interface org.apache.flink.runtime.jobmaster.LogicalSlot
 
terminateJVM() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
terminateRpcEndpoint(RpcEndpoint, Time) - Static method in class org.apache.flink.runtime.rpc.RpcUtils
Shuts the given RpcEndpoint down and awaits its termination.
terminateRpcService(RpcService, Time) - Static method in class org.apache.flink.runtime.rpc.RpcUtils
Shuts the given rpc service down and waits for its termination.
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 - Variable in class org.apache.flink.runtime.rest.messages.JobTerminationMessageParameters
 
TerminationModeQueryParameter - Class in org.apache.flink.runtime.rest.messages
Termination mode for the JobCancellationHandler.
TerminationModeQueryParameter() - Constructor for class org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter
 
TerminationModeQueryParameter.TerminationMode - Enum in org.apache.flink.runtime.rest.messages
Supported termination modes.
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
 
testHash(int) - Method in class org.apache.flink.runtime.operators.util.BloomFilter
 
ThreadBase(ExceptionHandler<IOException>, String, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
Creates a new thread.
ticketCacheEntry() - Static method in class org.apache.flink.runtime.security.KerberosUtils
 
timeout - Variable in class org.apache.flink.runtime.client.JobClientActor
timeout for futures
timeout - Variable in class org.apache.flink.runtime.rest.handler.RedirectHandler
 
TimeoutListener<K> - Interface in org.apache.flink.runtime.taskexecutor.slot
Listener for timeout events by the TimerService.
timeoutPendingSlotRequest(SlotRequestId) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPool
 
timeoutSlot(AllocationID, UUID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.SlotActions
Timeout the task slot for the given allocation id.
TimerService<K> - Class in org.apache.flink.runtime.taskexecutor.slot
Service to register timeouts for a given key.
TimerService(ScheduledExecutorService, long) - Constructor for class org.apache.flink.runtime.taskexecutor.slot.TimerService
 
toArray() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
 
toArray(T1[]) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
 
toArray() - Method in class org.apache.flink.runtime.util.IntArrayList
 
toArray() - Method in class org.apache.flink.runtime.util.LongArrayList
 
toBuffer(AbstractEvent) - Static method in class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
 
toBufferConsumer(AbstractEvent) - Static method in class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
 
toFiniteDuration(Time) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
Converts Flink time into a FiniteDuration.
toJava(Future<T>) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
Converts a Scala Future to a CompletableFuture.
toJava(Option<T>) - Static method in class org.apache.flink.runtime.util.ScalaUtils
Converts a Scala Option to a Optional.
toJobExecutionResult(ClassLoader) - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
 
toJobExecutionResult(ClassLoader) - Method in class org.apache.flink.runtime.jobmaster.JobResult
Converts the JobResult to a JobExecutionResult.
toKeyedStateHandleSnapshotResult(SnapshotResult<StreamStateHandle>, KeyGroupRangeOffsets) - Static method in interface org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
Helper method that takes a SnapshotResult and a KeyGroupRangeOffsets and creates a SnapshotResult by combining the key groups offsets with all the present stream state handles.
toSerializedEvent(AbstractEvent) - Static method in class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
 
toString() - Method in class org.apache.flink.runtime.blob.BlobKey
 
toString() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
 
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.CheckpointTriggerResult
 
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.JobManagerTaskRestore
 
toString() - Method in class org.apache.flink.runtime.checkpoint.MasterState
 
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.savepoint.SavepointV1
 
toString() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
toString() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
 
toString() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
 
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.ContainerSpecification.Artifact
 
toString() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.CheckAndAllocateContainers
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.FatalErrorOccurred
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.GetClusterStatus
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.GetClusterStatusResponse
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.InfoMessage
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.NewLeaderAvailable
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.NotifyResourceStarted
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.ReconnectResourceManager
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListener
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListenerSuccessful
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterResourceManager
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterResourceManagerSuccessful
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.RemoveResource
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.ResourceRemoved
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.SetWorkerPoolSize
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.ShutdownClusterAfterJob
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.StopCluster
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.StopClusterSuccessful
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.TriggerRegistrationAtJobManager
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.UnRegisterInfoMessageListener
 
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.deployment.InputChannelDeploymentDescriptor
 
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.ResultPartitionLocation
 
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.executiongraph.Execution
 
toString() - Method in class org.apache.flink.runtime.executiongraph.ExecutionAndAllocationFuture
 
toString() - Method in class org.apache.flink.runtime.executiongraph.ExecutionEdge
 
toString() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
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.executiongraph.restart.FailureRateRestartStrategy
 
toString() - Method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
 
toString() - Method in class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
 
toString() - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
 
toString() - Method in class org.apache.flink.runtime.instance.HardwareDescription
 
toString() - Method in class org.apache.flink.runtime.instance.Instance
 
toString() - Method in class org.apache.flink.runtime.instance.SharedSlot
 
toString() - Method in class org.apache.flink.runtime.instance.SimpleSlot
 
toString() - Method in class org.apache.flink.runtime.instance.Slot
 
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.EndOfPartitionEvent
 
toString() - Method in class org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
 
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.consumer.BufferOrEvent
 
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.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.JobEdge
 
toString() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
 
toString() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
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.jobmanager.scheduler.CoLocationConstraint
 
toString() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
toString() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
toString() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
toString() - Method in class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
 
toString() - Method in class org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess
 
toString() - Method in class org.apache.flink.runtime.jobmaster.ResourceManagerAddress
 
toString() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotAndLocality
 
toString() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.MultiTaskSlot
 
toString() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.SingleTaskSlot
 
toString() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager
 
toString() - Method in class org.apache.flink.runtime.leaderelection.LeaderAddressAndId
 
toString() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
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.checkpoint.NotifyCheckpointComplete
 
toString() - Method in class org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
 
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.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.BitSet
 
toString() - Method in class org.apache.flink.runtime.operators.util.BloomFilter
 
toString() - Method in class org.apache.flink.runtime.query.KvStateLocation
 
toString() - Method in class org.apache.flink.runtime.query.KvStateMessage.LookupKvStateLocation
 
toString() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
 
toString() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
 
toString() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
 
toString() - Method in class org.apache.flink.runtime.registration.RegistrationResponse.Decline
 
toString() - Method in class org.apache.flink.runtime.registration.RegistrationResponse.Success
 
toString() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
 
toString() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSample
 
toString() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoEntry
 
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 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.rpc.messages.LocalFencedMessage
 
toString() - Method in class org.apache.flink.runtime.rpc.messages.LocalRpcInvocation
 
toString() - Method in class org.apache.flink.runtime.rpc.messages.RemoteFencedMessage
 
toString() - Method in class org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation
 
toString() - Method in class org.apache.flink.runtime.rpc.messages.UnfencedMessage
 
toString() - Method in class org.apache.flink.runtime.state.BoundedInputStream
 
toString() - Method in class org.apache.flink.runtime.state.CheckpointStorageLocationReference
 
toString() - Method in class org.apache.flink.runtime.state.DirectoryKeyedStateHandle
 
toString() - Method in class org.apache.flink.runtime.state.DirectoryStateHandle
 
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.FsStateBackend
 
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
 
toString() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
 
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.KeyGroupsStateHandle
 
toString() - Method in class org.apache.flink.runtime.state.LocalRecoveryConfig
 
toString() - Method in class org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
 
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.MemoryBackendCheckpointStorage
 
toString() - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
 
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.RegisteredBroadcastBackendStateMetaInfo
 
toString() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
 
toString() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo
 
toString() - Method in class org.apache.flink.runtime.state.SharedStateRegistry.Result
 
toString() - Method in class org.apache.flink.runtime.state.SharedStateRegistry
 
toString() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
 
toString() - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
 
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.QueryableStateConfiguration
 
toString() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
toString() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
 
toString() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
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.LeaderConnectionInfo
 
toString() - Method in class org.apache.flink.runtime.util.OperatorSubtaskDescriptionText
 
toString() - Method in class org.apache.flink.runtime.webmonitor.history.ArchivedJson
 
totalNumberOfSlots() - Method in class org.apache.flink.runtime.clusterframework.messages.GetClusterStatusResponse
 
toTime(FiniteDuration) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
Converts FiniteDuration into Flink time.
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.
transform(N, T, StateTransformationFunction<S, T>) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
transform(N, T, StateTransformationFunction<S, T>) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
transform(N, T, StateTransformationFunction<S, T>) - Method in class org.apache.flink.runtime.state.heap.StateTable
Applies the given StateTransformationFunction to the state (1st input argument), using the given value as second input argument.
TransientBlobCache - Class in org.apache.flink.runtime.blob
Provides access to transient BLOB files stored at the BlobServer.
TransientBlobCache(Configuration, 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 BlobServer when they are retrieved.
TRANSPORT_TYPE - Static variable in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
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
 
triggerCheckpoint(long, 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, CheckpointProperties, String, boolean) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
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(CheckpointMetaData, CheckpointOptions) - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
This method is called to trigger a checkpoint, asynchronously by the checkpoint coordinator.
triggerCheckpoint(ExecutionAttemptID, JobID, long, long, CheckpointOptions) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
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 - Class in org.apache.flink.runtime.messages.checkpoint
This message is sent from the JobManager to the TaskManager to tell a certain task to trigger its checkpoint.
TriggerCheckpoint(JobID, ExecutionAttemptID, long, long, CheckpointOptions) - Constructor for class org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
 
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.
triggerCheckpointBarrier(long, long, CheckpointOptions) - Method in class org.apache.flink.runtime.taskmanager.Task
Calls the invokable to trigger a checkpoint.
triggerCheckpointOnBarrier(CheckpointMetaData, CheckpointOptions, CheckpointMetrics) - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
This method is called when a checkpoint is triggered as a result of receiving checkpoint barriers on all input streams.
triggerCheckWorkers() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
This method causes the resource framework master to asynchronouslyre-examine the set of available and pending workers containers, and release or allocate containers if needed.
triggerConnectingToJobManager(String) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Causes the resource manager to announce itself at the new leader JobManager and obtains its connection information and currently known TaskManagers.
triggerConnectingToJobManager(String) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
triggerFullRecovery() - Method in class org.apache.flink.runtime.executiongraph.restart.ExecutionGraphRestartCallback
 
triggerFullRecovery() - Method in interface org.apache.flink.runtime.executiongraph.restart.RestartCallback
Triggers a full recovery in the target ExecutionGraph.
TriggerHandler(CompletableFuture<String>, GatewayRetriever<? extends T>, Time, Map<String, String>, MessageHeaders<B, TriggerResponse, M>) - Constructor for class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.TriggerHandler
 
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.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
MessagePathParameter for 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
 
triggerMasterHooks(Collection<MasterTriggerRestoreHook<?>>, long, long, Executor, Time) - Static method in class org.apache.flink.runtime.checkpoint.hooks.MasterHooks
Triggers all given master hooks and returns state objects for each hook that produced a state.
triggerNextSuperstep() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
 
triggerOperation(HandlerRequest<B, M>, 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, RescalingTriggerMessageParameters>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingTriggerHandler
 
triggerOperation(HandlerRequest<SavepointDisposalRequest, EmptyMessageParameters>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalTriggerHandler
 
triggerOperation(HandlerRequest<SavepointTriggerRequestBody, SavepointTriggerMessageParameters>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointTriggerHandler
 
triggerPartitionProducerStateCheck(JobID, IntermediateDataSetID, ResultPartitionID) - Method in class org.apache.flink.runtime.taskmanager.Task
 
triggerPartitionProducerStateCheck(JobID, IntermediateDataSetID, ResultPartitionID) - Method in interface org.apache.flink.runtime.taskmanager.TaskActions
Check the execution state of the execution producing a result partition.
TriggerRegistrationAtJobManager - Class in org.apache.flink.runtime.clusterframework.messages
Causes the resource manager to try and apply at the leader JobManager.
TriggerRegistrationAtJobManager(ActorRef) - Constructor for class org.apache.flink.runtime.clusterframework.messages.TriggerRegistrationAtJobManager
 
TriggerRegistrationAtJobManager(String) - Constructor for class org.apache.flink.runtime.clusterframework.messages.TriggerRegistrationAtJobManager
 
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
 
triggerSavepoint(long, String) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Triggers a savepoint with the given savepoint directory as a target.
triggerSavepoint(JobID, String, boolean, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
 
triggerSavepoint(String, boolean, Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
triggerSavepoint(String, boolean, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Triggers taking a savepoint of the executed job.
triggerSavepoint(JobID, String, boolean) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
 
triggerSavepoint(JobID, String, boolean, Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
Triggers a savepoint with the given savepoint directory as a target.
triggerStackTraceSample(ExecutionJobVertex) - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTrackerImpl
Deprecated.
triggerStackTraceSample(ExecutionVertex[], int, Time, int) - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator
Triggers a stack trace sample to all tasks.
tryAdd(AbstractCheckpointStats) - Method in class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointStatsCache
Try to add the checkpoint to the cache.
tryAssignPayload(LogicalSlot.Payload) - Method in class org.apache.flink.runtime.instance.SharedSlot
 
tryAssignPayload(LogicalSlot.Payload) - Method in class org.apache.flink.runtime.instance.SimpleSlot
Atomically sets the executed vertex, if no vertex has been assigned to this slot so far.
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
 
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.
tryLoadWebContent(GatewayRetriever<? extends T>, CompletableFuture<String>, Time, 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.
tryReconnect() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
 
trySetCount(ZooKeeperVersionedValue<Integer>, int) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
 

U

uncaughtException(Thread, Throwable) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
 
uncaughtException(Thread, Throwable) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
 
uncaughtException(Thread, Throwable) - Method in class org.apache.flink.runtime.util.FatalExitExceptionHandler
 
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
 
UnfencedMessage<P> - Class in org.apache.flink.runtime.rpc.messages
Wrapper class indicating a message which is not required to match the fencing token as it is used by the FencedMainThreadExecutable to run code in the main thread without a valid fencing token.
UnfencedMessage(P) - Constructor for class org.apache.flink.runtime.rpc.messages.UnfencedMessage
 
unhandledError(String, Throwable) - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
unhandledError(String, Throwable) - Method in class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
 
UnilateralSortMerger<E> - Class in org.apache.flink.runtime.operators.sort
The UnilateralSortMerger is a full fledged sorter.
UnilateralSortMerger(MemoryManager, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, double, int, float, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
UnilateralSortMerger(MemoryManager, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, double, int, int, float, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
UnilateralSortMerger(MemoryManager, List<MemorySegment>, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, int, int, float, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
UnilateralSortMerger(MemoryManager, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, double, int, int, float, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
UnilateralSortMerger(MemoryManager, List<MemorySegment>, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, int, int, float, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
UnilateralSortMerger.ChannelWithBlockCount - Class in org.apache.flink.runtime.operators.sort
 
UnilateralSortMerger.CircularElement<E> - Class in org.apache.flink.runtime.operators.sort
Class representing buffers that circulate between the reading, sorting and spilling thread.
UnilateralSortMerger.CircularQueues<E> - Class in org.apache.flink.runtime.operators.sort
Collection of queues that are used for the communication between the threads.
UnilateralSortMerger.ReadingThread<E> - Class in org.apache.flink.runtime.operators.sort
The thread that consumes the input data and puts it into a buffer that will be sorted.
UnilateralSortMerger.SortingThread<E> - Class in org.apache.flink.runtime.operators.sort
The thread that sorts filled buffers.
UnilateralSortMerger.SpillingThread - Class in org.apache.flink.runtime.operators.sort
The thread that handles the spilling of intermediate results and sets up the merging.
UnilateralSortMerger.ThreadBase<E> - Class in org.apache.flink.runtime.operators.sort
Base class for all working threads in this sort-merger.
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
 
UnionInputGate - Class in org.apache.flink.runtime.io.network.partition.consumer
Input gate wrapper to union the input from multiple input gates.
UnionInputGate(InputGate...) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
UnionWithTempOperator<T> - Class in org.apache.flink.runtime.operators
 
UnionWithTempOperator() - Constructor for class org.apache.flink.runtime.operators.UnionWithTempOperator
 
UNKNOWN - Static variable in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
 
UNKNOWN - Static variable in class org.apache.flink.runtime.util.EnvironmentInformation
 
UnknownKvStateLocation - Exception in org.apache.flink.runtime.query
Thrown if there is no KvStateLocation found for the requested registration name.
UnknownKvStateLocation(String) - Constructor for exception org.apache.flink.runtime.query.UnknownKvStateLocation
 
UnknownTaskExecutorException - Exception in org.apache.flink.runtime.resourcemanager.exceptions
Exception denoting that a requested TaskExecutor could not be found.
UnknownTaskExecutorException(ResourceID) - Constructor for exception org.apache.flink.runtime.resourcemanager.exceptions.UnknownTaskExecutorException
 
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.HeartbeatManagerImpl
 
unregister(Metric, String, AbstractMetricGroup) - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
Un-registers the given Metric with 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.
unregisterAllTaskManagers() - Method in class org.apache.flink.runtime.instance.InstanceManager
Unregisters all currently registered TaskManagers from the InstanceManager.
unregisterAllTimeouts() - Method in class org.apache.flink.runtime.taskexecutor.slot.TimerService
Unregister all timeouts.
unregisterChannelToBeRemovedAtShudown(FileIOChannel.ID) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Removes a channel from the list of channels that are to be removed at shutdown.
UnregisteredJobManagerJobMetricGroup() - Constructor for class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredJobManagerJobMetricGroup
 
UnregisteredJobManagerJobMetricGroupFactory - Enum in org.apache.flink.runtime.jobmaster.factories
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.UnregisteredOperatorMetricGroup - Class in org.apache.flink.runtime.metrics.groups
A safe drop-in replacement for OperatorMetricGroups.
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
 
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
 
UnRegisterInfoMessageListener - Class in org.apache.flink.runtime.clusterframework.messages
This message signals to the resource master to register the sender as an info message listener.
unRegisterInfoMessageListener(String) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
Unregisters an info message listener.
unRegisterInfoMessageListener(String) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Unregisters an infoMessage listener
unregisterJob(JobID) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
unregisterJob(JobID) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
Unregisters a job from the library cache manager.
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.
unregisterOpenChannelToBeRemovedAtShudown(FileIOChannel) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Removes a channel reader/writer from the list of channels that are to be removed at shutdown.
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).
unregisterReference(SharedStateRegistryKey) - Method in class org.apache.flink.runtime.state.SharedStateRegistry
Releases one reference to the given shared state in the registry.
unregisterSlotRequest(AllocationID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Cancels and removes a pending slot request with the given allocation id.
unregisterTask(JobID, ExecutionAttemptID) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
unregisterTask(JobID, ExecutionAttemptID) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
Unregisters a job task execution from the library cache manager.
unregisterTask(Task) - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
unregisterTaskManager(InstanceID, boolean) - Method in class org.apache.flink.runtime.instance.InstanceManager
Unregisters the TaskManager with the given instance id.
unregisterTaskManager(InstanceID) - Method in class 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.
unregisterTaskManagersAndReleaseResources() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
 
unregisterTimeout(K) - Method in class org.apache.flink.runtime.taskexecutor.slot.TimerService
Unregister the timeout for the given key.
unsynchronizedGetNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
unsynchronizedGetNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
Makes a best effort to get the current size of the queue.
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.io.network.buffer.NetworkBuffer
 
unwrap() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
 
update(long) - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogram
 
update() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricFetcher
This method can be used to signal this MetricFetcher that the metrics are still in use and should be updated.
update(List<V>) - Method in class org.apache.flink.runtime.state.heap.HeapListState
 
update(V) - Method in class org.apache.flink.runtime.state.heap.HeapValueState
 
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 to the given list of values.
updateAccumulators(AccumulatorSnapshot) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Updates the accumulators during the runtime of a job.
updateAllocation(AllocationID, JobID) - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
updateCoLocationGroup(CoLocationGroup) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
updateGlobalAggregatesAndReset(String[], Value[]) - Method in class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
 
updateInputChannel(InputChannelDeploymentDescriptor) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
updateKvStateLocationOracle(JobID, KvStateLocationOracle) - Method in interface org.apache.flink.runtime.query.KvStateClientProxy
Updates the active Job Manager in 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.
updatePartitions(ExecutionAttemptID, Iterable<PartitionInfo>, Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
updatePartitions(ExecutionAttemptID, Iterable<PartitionInfo>, Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Update the task where the given partitions can be found.
updatePartitions(ExecutionAttemptID, Iterable<PartitionInfo>, Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
updatePartitions(ExecutionAttemptID, Iterable<PartitionInfo>, Time) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
updatePartitions(ExecutionAttemptID, Iterable<PartitionInfo>, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Update the task where the given partitions can be found.
updateState(TaskExecutionState) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Updates the state of one of the ExecutionVertex's Execution attempts.
updateStatistics(BufferConsumer) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
updateStatistics(Buffer) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
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(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 class org.apache.flink.runtime.taskmanager.ActorGatewayTaskManagerActions
 
updateTaskExecutionState(TaskExecutionState) - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerActions
Notifies the task manager about the task execution state update.
uploadDir - Variable in class org.apache.flink.runtime.rest.RestServerEndpoint
 
uploadJarFiles(InetSocketAddress, Configuration, JobID, List<Path>) - Static method in class org.apache.flink.runtime.blob.BlobClient
Uploads the JAR files to the PermanentBlobService of the BlobServer at the given address with HA as configured.
uploadUserJars(InetSocketAddress, Configuration) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Uploads the previously added user JAR files to the job manager through the job manager's BLOB server.
UPPER_BOUND_MAX_PARALLELISM - Static variable in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
The (inclusive) upper bound for max parallelism
UpTimeGauge - Class in org.apache.flink.runtime.executiongraph.metrics
A gauge that returns (in milliseconds) how long a job has been running.
UpTimeGauge(ExecutionGraph) - Constructor for class org.apache.flink.runtime.executiongraph.metrics.UpTimeGauge
 
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.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.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.JobTerminationHeaders
 
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
 
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
 
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.OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractBroadcastStateMetaInfoReader
 
userCodeClassLoader - Variable in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractOperatorBackendStateMetaInfoReader
 
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
 
useTicketCache() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
 

V

validateAndNormalizeUri(URI) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
Checks and normalizes the given URI.
validateClassLoadable(ClassNotFoundException, ClassLoader) - Static method in class org.apache.flink.runtime.util.ClassLoaderUtil
Checks, whether the class that was not found in the given exception, can be resolved through the given class loader.
validateRunsInMainThread() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Validates that the method call happens in the RPC endpoint's main thread.
value - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.GaugeDump
 
value() - Method in class org.apache.flink.runtime.state.heap.HeapValueState
 
VALUE_NOT_SET - Static variable in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
valueOf(String) - Static method in enum org.apache.flink.runtime.akka.ListeningBehaviour
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointDeclineReason
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.CheckpointType
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.clusterframework.ApplicationStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.clusterframework.types.TaskManagerSlot.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.dispatcher.Dispatcher.DefaultJobManagerRunnerFactory
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.execution.ExecutionState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders.ResolveOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils.AddressResolution
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.highavailability.RunningJobsRegistry.JobSchedulingStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.io.disk.iomanager.IOManager.IOMode
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.serialization.RecordSerializer.SerializationResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
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.jobgraph.DistributionPattern
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.jobgraph.JobStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.jobgraph.ScheduleMode
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.JobManagerMode
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.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.RescalingBehaviour
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.MiniClusterConfiguration.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.util.LocalStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.rest.handler.legacy.backpressure.VoidBackPressureStatsTracker
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.rest.handler.legacy.TaskManagerLogHandler.FileMode
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.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.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.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.util.RestConstants
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils.AkkaProtocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.rpc.akka.messages.Processing
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.rpc.messages.HandshakeSuccessMessage
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.OperatorStateHandle.Mode
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.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.WebMonitorExtension.EmptyWebMonitorExtension
Returns the enum constant of this type with the specified name.
valueOrNull(Object) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
values() - Static method in enum org.apache.flink.runtime.akka.ListeningBehaviour
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.CheckpointDeclineReason
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.CheckpointType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.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.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.clusterframework.types.TaskManagerSlot.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.Dispatcher.DefaultJobManagerRunnerFactory
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.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.execution.librarycache.FlinkUserCodeClassLoaders.ResolveOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils.AddressResolution
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.highavailability.RunningJobsRegistry.JobSchedulingStatus
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.disk.iomanager.IOManager.IOMode
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.serialization.RecordSerializer.SerializationResult
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.DataExchangeMode
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.ResultPartitionType
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.JobStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.jobgraph.ScheduleMode
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.JobManagerMode
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.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.RescalingBehaviour
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyMap
 
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.MiniClusterConfiguration.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.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.rest.handler.legacy.backpressure.VoidBackPressureStatsTracker
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.TaskManagerLogHandler.FileMode
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.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.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.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.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.rpc.akka.AkkaRpcServiceUtils.AkkaProtocol
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.rpc.akka.messages.Processing
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.rpc.messages.HandshakeSuccessMessage
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() - Method in class org.apache.flink.runtime.state.heap.HeapMapState
 
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.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.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.WebMonitorExtension.EmptyWebMonitorExtension
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
 
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 all memory available.
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.savepoint.SavepointV1
The savepoint version.
VERSION - Static variable in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
The savepoint version.
VERSION - Static variable in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
VERSION - Static variable in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
 
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
 
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 - Variable in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
vertexId() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
VertexTaskDetail(int, ExecutionState, int, String, long, long, long, IOMetricsInfo) - Constructor for class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
 
ViewUpdater - Class in org.apache.flink.runtime.metrics
The ViewUpdater is responsible for updating all metrics that implement the View interface.
ViewUpdater(ScheduledExecutorService) - Constructor for class org.apache.flink.runtime.metrics.ViewUpdater
 
visit(String, Object) - Method in class org.apache.flink.runtime.util.DependencyVisitor.AnnotationVisitorImpl
 
visit(int, int, String, String, String, String[]) - Method in class org.apache.flink.runtime.util.DependencyVisitor
 
visitAnnotation(String, String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.AnnotationVisitorImpl
 
visitAnnotation(String, boolean) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitAnnotation(String, boolean) - Method in class org.apache.flink.runtime.util.DependencyVisitor
 
visitAnnotationDefault() - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitArray(String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.AnnotationVisitorImpl
 
visitClassType(String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.SignatureVisitorImpl
 
visitEnum(String, String, String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.AnnotationVisitorImpl
 
visitField(int, String, String, String, Object) - Method in class org.apache.flink.runtime.util.DependencyVisitor
 
visitFieldInsn(int, String, String, String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitInnerClassType(String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.SignatureVisitorImpl
 
visitLdcInsn(Object) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitLocalVariable(String, String, String, Label, Label, int) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitMethod(int, String, String, String, String[]) - Method in class org.apache.flink.runtime.util.DependencyVisitor
 
visitMethodInsn(int, String, String, String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitMethodInsn(int, String, String, String, boolean) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitMultiANewArrayInsn(String, int) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitParameterAnnotation(int, String, boolean) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitParameterType() - Method in class org.apache.flink.runtime.util.DependencyVisitor.SignatureVisitorImpl
 
visitReturnType() - Method in class org.apache.flink.runtime.util.DependencyVisitor.SignatureVisitorImpl
 
visitTryCatchBlock(Label, Label, Label, String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitTypeAnnotation(int, TypePath, String, boolean) - Method in class org.apache.flink.runtime.util.DependencyVisitor.FieldVisitorImpl
 
visitTypeInsn(int, String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
VoidBackPressureStatsTracker - Enum in org.apache.flink.runtime.rest.handler.legacy.backpressure
BackPressureStatsTracker implementation which always returns no back pressure statistics.
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.
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
 
VoidNamespaceTypeInfo - Class in org.apache.flink.runtime.state
TypeInformation for VoidNamespace.
VoidNamespaceTypeInfo() - Constructor for class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
 

W

waitForAll(Collection<? extends CompletableFuture<?>>) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
Creates a future that is complete once all of the given futures have completed.
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.
waitForSolutionSetUpdate() - Method in class org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrier
Waits (blocking) on barrier.
waitUntilTerminal() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
wasQuarantinedBy(String, ActorSystem) - Method in class org.apache.flink.runtime.akka.DefaultQuarantineHandler
 
wasQuarantinedBy(String, ActorSystem) - Method in interface org.apache.flink.runtime.akka.QuarantineHandler
Callback when the given actor system was quarantined by the given remote actor system.
WebContentHandlerSpecification - Class in org.apache.flink.runtime.rest.handler.legacy.files
Rest handler specification for the web content handler.
WebHandler - Interface in org.apache.flink.runtime.rest.handler
Marker interface for web handlers which can describe their paths.
WebMonitor - Interface in org.apache.flink.runtime.webmonitor
Interface for web monitors.
WebMonitorEndpoint<T extends RestfulGateway> - Class in org.apache.flink.runtime.webmonitor
Rest endpoint which serves the web frontend REST calls.
WebMonitorEndpoint(RestServerEndpointConfiguration, GatewayRetriever<? extends T>, Configuration, RestHandlerConfiguration, GatewayRetriever<ResourceManagerGateway>, TransientBlobService, Executor, MetricQueryServiceRetriever, LeaderElectionService, FatalErrorHandler) - Constructor for class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
 
WebMonitorExtension - Interface in org.apache.flink.runtime.webmonitor
Interface for WebMonitorEndpoint extensions.
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 and stdout file.
withLocalState(T, T) - Static method in class org.apache.flink.runtime.state.SnapshotResult
 
WorkerDoneEvent - Class in org.apache.flink.runtime.iterative.event
Completion event sent from each IterationHead to the IterationSynchronizationSinkTask.
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, HardwareDescription) - Constructor for class org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
 
workerStarted(ResourceID) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Callback when a worker was started.
workerStarted(ResourceID) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
workerStarted(ResourceID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
Callback when a worker was started.
workerStarted(ResourceID) - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
 
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 Collector to 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
 
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.
WrappedJobException(Throwable) - Constructor for exception org.apache.flink.runtime.jobmaster.JobResult.WrappedJobException
 
wrapSingleHandle(T) - Static method in class org.apache.flink.runtime.state.ChainedStateHandle
 
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.EndOfPartitionEvent
 
write(DataOutputView) - Method in class org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
 
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(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
write(byte[]) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
write(byte[], int, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
write(DataInputView, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
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.
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(FSDataOutputStream) - Method in interface org.apache.flink.runtime.state.BackendWritableBroadcastState
 
write(int) - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
 
write(byte[]) - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
 
write(byte[], int, int) - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
 
write(int) - Method in class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
 
write(byte[], int, int) - Method in class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
 
write(int) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
 
write(byte[], int, 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(byte[], int, int) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
 
write(FSDataOutputStream) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
 
write(DataOutputView) - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
write(int) - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
 
write(byte[], int, int) - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
 
write(int) - Method in class org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
 
write(byte[]) - Method in class org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
 
write(byte[], int, int) - Method in class org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
 
write(DataOutputView) - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
 
write(int) - Method in class org.apache.flink.runtime.util.ForwardingOutputStream
 
write(byte[]) - Method in class org.apache.flink.runtime.util.ForwardingOutputStream
 
write(byte[], int, int) - Method in class org.apache.flink.runtime.util.ForwardingOutputStream
 
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
 
writeBroadcastStateMetaInfo(DataOutputView) - Method in interface org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.BroadcastStateMetaInfoWriter
 
writeBroadcastStateMetaInfo(DataOutputView) - Method in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.BroadcastStateMetaInfoWriterV3
 
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
 
writeFloat(float) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeInt(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeIOMetricsAsJson(JsonGenerator) - Method in class org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
Writes the IO metrics contained in this object to the given JsonGenerator.
writeLeaderInformation(UUID) - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
Writes the current leader's address as well the given leader session ID to ZooKeeper.
writeLong(long) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeMappingsInKeyGroup(DataOutputView, int) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTableSnapshot
 
writeMemory - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
writeMemory - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The memory segments used to stage data to be written.
writeOperatorStateMetaInfo(DataOutputView) - Method in interface org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoWriter
 
writeOperatorStateMetaInfo(DataOutputView) - Method in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoWriterV1
 
writeOperatorStateMetaInfo(DataOutputView) - Method in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoWriterV2
 
writeShort(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeStateMetaInfo(DataOutputView) - Method in interface org.apache.flink.runtime.state.KeyedBackendStateMetaInfoSnapshotReaderWriters.KeyedBackendStateMetaInfoWriter
 
writeTo(ByteBuf) - Method in class org.apache.flink.runtime.executiongraph.ExecutionAttemptID
 
writeTo(ByteBuf) - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
 
writeTo(ByteBuf) - Method in class org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
 
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, LargeRecordHandler<T>) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
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) - 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, LargeRecordHandler<T>) - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
 
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) - 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, LargeRecordHandler<T>) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
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.
writeUTF(String) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 

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.

Z

ZooKeeperCheckpointIDCounter - Class in org.apache.flink.runtime.checkpoint
CheckpointIDCounter instances for JobManagers running in HighAvailabilityMode.ZOOKEEPER.
ZooKeeperCheckpointIDCounter(CuratorFramework, String) - Constructor for class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
Creates a ZooKeeperCheckpointIDCounter instance.
ZooKeeperCheckpointRecoveryFactory - Class in org.apache.flink.runtime.checkpoint
ZooKeeperCheckpointRecoveryFactory(CuratorFramework, Configuration, Executor) - Constructor for class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
 
ZooKeeperCompletedCheckpointStore - Class in org.apache.flink.runtime.checkpoint
ZooKeeperCompletedCheckpointStore(int, CuratorFramework, String, RetrievableStateStorageHelper<CompletedCheckpoint>, Executor) - Constructor for class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
ZooKeeperHaServices - Class in org.apache.flink.runtime.highavailability.zookeeper
An implementation of the HighAvailabilityServices using Apache ZooKeeper.
ZooKeeperHaServices(CuratorFramework, Executor, Configuration, BlobStoreService) - Constructor for class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
ZooKeeperLeaderElectionService - Class in org.apache.flink.runtime.leaderelection
Leader election service for multiple JobManager.
ZooKeeperLeaderElectionService(CuratorFramework, String, String) - Constructor for class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
Creates a ZooKeeperLeaderElectionService object.
ZooKeeperLeaderRetrievalService - Class in org.apache.flink.runtime.leaderretrieval
The counterpart to the ZooKeeperLeaderElectionService.
ZooKeeperLeaderRetrievalService(CuratorFramework, String) - Constructor for class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
Creates a leader retrieval service which uses ZooKeeper to retrieve the leader information.
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
 
ZooKeeperRunningJobsRegistry - Class in org.apache.flink.runtime.highavailability.zookeeper
A zookeeper based registry for running jobs, highly available.
ZooKeeperRunningJobsRegistry(CuratorFramework, Configuration) - Constructor for class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperRunningJobsRegistry
 
ZooKeeperSharedCount - Class in org.apache.flink.runtime.zookeeper
Wrapper class for a SharedCount so 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 SharedValue so 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 RetrievableStateStorageHelper and writes the returned state handle to ZooKeeper.
ZooKeeperStateHandleStore(CuratorFramework, RetrievableStateStorageHelper<T>, Executor) - Constructor for class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
ZooKeeperStateHandleStore.RemoveCallback<T extends Serializable> - Interface in org.apache.flink.runtime.zookeeper
Callback interface for remove calls
ZooKeeperSubmittedJobGraphStore - Class in org.apache.flink.runtime.jobmanager
SubmittedJobGraph instances for JobManagers running in HighAvailabilityMode.ZOOKEEPER.
ZooKeeperSubmittedJobGraphStore(CuratorFramework, String, RetrievableStateStorageHelper<SubmittedJobGraph>, Executor) - Constructor for class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
Submitted job graph store backed by ZooKeeper
ZooKeeperUtilityFactory - Class in org.apache.flink.runtime.zookeeper
Creates ZooKeeper utility classes without exposing the CuratorFramework dependency.
ZooKeeperUtilityFactory(Configuration, String) - Constructor for class org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
 
ZooKeeperUtils - Class in org.apache.flink.runtime.util
 
ZooKeeperUtils.SecureAclProvider - Class in org.apache.flink.runtime.util
 
ZooKeeperUtils.ZkClientACLMode - Enum in org.apache.flink.runtime.util
 
ZooKeeperVersionedValue<T> - Class in org.apache.flink.runtime.zookeeper
Wrapper class for a VersionedValue so 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
 
_getLong(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
 
_getUnsignedMedium(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
 
_setLong(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
 
_setShort(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
 
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 _ 
Skip navigation links

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