- 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
-
- call() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncIOCallable
-
This method implements the strategy for the actual IO operation:
1) Open the IO handle
2) Perform IO operation
3) Close IO handle
- 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 interface org.apache.flink.runtime.concurrent.Future
-
Tries to cancel the future's operation.
- cancel(boolean) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkCompletableFuture
-
- cancel(boolean) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
-
- 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
-
- 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() - 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(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
-
- 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
-
- cancelExecution() - Method in class org.apache.flink.runtime.taskmanager.Task
-
Cancels the task execution.
- 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() - 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
-
- 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
-
- canEqual(Object) - Method in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
-
Deprecated.
- canEqual(Object) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- canEqual(Object) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- 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
.
- 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
-
- ChannelReaderInputView - Class in org.apache.flink.runtime.io.disk.iomanager
-
- 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 IOReadableWritable> - Interface in org.apache.flink.runtime.io.network.api.writer
-
The
ChannelSelector
determines to which logical channels a record
should be written to.
- ChannelWriterOutputView - Class in org.apache.flink.runtime.io.disk.iomanager
-
- 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.
- checkParallelismPreconditions(int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
-
- CHECKPOINT_DIRECTORY_URI_CONF_KEY - Static variable in class org.apache.flink.runtime.state.filesystem.FsStateBackendFactory
-
The key under which the config stores the directory where checkpoints should be stored
- CheckpointBarrier - Class in org.apache.flink.runtime.io.network.api
-
Checkpoint barriers are used to align checkpoints throughout the streaming topology.
- CheckpointBarrier() - Constructor for class org.apache.flink.runtime.io.network.api.CheckpointBarrier
-
- CheckpointBarrier(long, long) - Constructor for class org.apache.flink.runtime.io.network.api.CheckpointBarrier
-
- 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, ExternalizedCheckpointSettings, ExecutionVertex[], ExecutionVertex[], ExecutionVertex[], CheckpointIDCounter, CompletedCheckpointStore, String, Executor) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- 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
-
- 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
-
- 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
-
- CheckpointIDCounter - Interface in org.apache.flink.runtime.checkpoint
-
A checkpoint ID counter.
- checkpointIdToPath(long) - Static method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
-
Convert a checkpoint id into a ZooKeeper path.
- 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.
- CheckpointMetaData - Class in org.apache.flink.runtime.checkpoint
-
Encapsulates all the meta data for a checkpoint.
- CheckpointMetaData(long, long) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointMetaData
-
- CheckpointMetaData(long, long, long, long, long, long) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointMetaData
-
- CheckpointMetaData(long, long, CheckpointMetrics) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointMetaData
-
- 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
-
- CheckpointProperties - Class in org.apache.flink.runtime.checkpoint
-
The configuration of a checkpoint, such as whether
The checkpoint should be persisted
The checkpoint must be full, or may be incremental (not yet implemented)
The checkpoint format must be the common (cross backend) format,
or may be state-backend specific (not yet implemented)
when the checkpoint should be garbage collected
- 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
.
- CheckpointStatsCounts - Class in org.apache.flink.runtime.checkpoint
-
Counts of checkpoints.
- CheckpointStatsHistory - Class in org.apache.flink.runtime.checkpoint
-
An array based history of checkpoint stats.
- 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>, JobSnapshottingSettings, MetricGroup) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
-
Creates a new checkpoint stats tracker.
- CheckpointStreamFactory - Interface in org.apache.flink.runtime.state
-
- CheckpointStreamFactory.CheckpointStateOutputStream - Class in org.apache.flink.runtime.state
-
- CheckpointStreamFactory.CheckpointStateOutputStream() - Constructor for class org.apache.flink.runtime.state.CheckpointStreamFactory.CheckpointStateOutputStream
-
- 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.
- 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
-
- clear() - Method in class org.apache.flink.runtime.io.network.api.serialization.AdaptiveSpanningRecordDeserializer
-
- 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() - 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.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.state.GenericFoldingState
-
- clear() - Method in class org.apache.flink.runtime.state.GenericListState
-
- clear() - Method in class org.apache.flink.runtime.state.GenericReducingState
-
- clear() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
- clear() - Method in class org.apache.flink.runtime.util.DataOutputSerializer
-
- 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
-
- 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
-
- clearCurrentBuffer() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
-
- clearCurrentBuffer() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
-
- clearPartitions() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
This method clears all partitions currently residing (partially) in memory.
- 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
-
- clone() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
-
- close() - Method in class org.apache.flink.migration.runtime.state.AbstractCloseableHandle
-
Deprecated.
Closes the handle.
- close() - Method in class org.apache.flink.migration.runtime.state.AbstractStateBackend.DataInputViewHandle
-
Deprecated.
- close() - Method in class org.apache.flink.migration.runtime.state.memory.AbstractMemStateSnapshot
-
Deprecated.
- close() - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskState
-
Deprecated.
- close() - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskStateList
-
Deprecated.
- close() - Method in class org.apache.flink.runtime.blob.BlobClient
-
- close() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
-
- close() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataOutputStream
-
- 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(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.state.AbstractKeyedStateBackend
-
- close() - Method in class org.apache.flink.runtime.state.BoundedInputStream
-
- close() - Method in interface org.apache.flink.runtime.state.CheckpointStreamFactory
-
Closes the stream factory, releasing all internal resources, but does not delete any
persistent checkpoint data.
- close() - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- close() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
-
- 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
-
- 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.StateInitializationContextImpl
-
- close() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
-
- close() - Method in class org.apache.flink.runtime.util.NonClosingStreamDecorator
-
- 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.
- 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
-
- 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.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
-
- closeAndGetHandle() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
-
- closeChainedTasks(List<ChainedDriver<?, ?>>, AbstractInvokable) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Closes all chained tasks, in the order as they are stored in the array.
- closeConnection(KvStateServerAddress) - Method in class org.apache.flink.runtime.query.netty.KvStateClient
-
Closes the connection to the given server address if it exists.
- 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.
- 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
-
- closeUserCode(Function) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
- 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(IN, MutableObjectIterator<IN>) - Constructor for class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable
-
- CoGroupRawDriver.SimpleIterable.SimpleIterator<IN> - Class in org.apache.flink.runtime.operators
-
- CoGroupRawDriver.SimpleIterable.SimpleIterator(IN, MutableObjectIterator<IN>) - Constructor for class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable.SimpleIterator
-
- 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
-
- 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
-
- 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
-
- CombiningUnilateralSortMerger.CombiningSpillingThread(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.CombiningUnilateralSortMerger.CombiningSpillingThread
-
- 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) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
-
- compare(int, int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- compareTo(BlobKey) - Method in class org.apache.flink.runtime.blob.BlobKey
-
- compareTo(BlockLocation) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopBlockLocation
-
- compareTo(TaskManagerLocation) - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
- CompletableFuture<T> - Interface in org.apache.flink.runtime.concurrent
-
Flink's completable future abstraction.
- complete(T) - Method in interface org.apache.flink.runtime.concurrent.CompletableFuture
-
Completes the future with the given value.
- complete(T) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkCompletableFuture
-
- completed(T) - Static method in class org.apache.flink.runtime.concurrent.impl.FlinkCompletableFuture
-
- CompletedCheckpoint - Class in org.apache.flink.runtime.checkpoint
-
A successful checkpoint describes a checkpoint after all required tasks acknowledged it (with their state)
and that is considered completed.
- CompletedCheckpoint(JobID, long, long, long, Map<JobVertexID, TaskState>) - Constructor for class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- CompletedCheckpoint(JobID, long, long, long, Map<JobVertexID, TaskState>, CheckpointProperties, String) - Constructor for class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- 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.
- CompletedCheckpointStore - Interface in org.apache.flink.runtime.checkpoint
-
- completedExceptionally(Throwable) - Static method in class org.apache.flink.runtime.concurrent.impl.FlinkCompletableFuture
-
- completeExceptionally(Throwable) - Method in interface org.apache.flink.runtime.concurrent.CompletableFuture
-
Completes the future with the given exception.
- completeExceptionally(Throwable) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkCompletableFuture
-
- 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.
- compositeBuffer() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
-
- compositeBuffer(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
-
- 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
-
- compositeDirectBuffer() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
-
- compositeDirectBuffer(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
-
- 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
-
- 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
-
- 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
-
- 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
-
- connecDataSet(IntermediateDataSet) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
- 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
-
- ConnectionUtils.LeaderConnectingAddressListener() - Constructor for class org.apache.flink.runtime.net.ConnectionUtils.LeaderConnectingAddressListener
-
- connectNewDataSetAsInput(JobVertex, DistributionPattern) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- 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
-
- 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(Path, Path, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
-
- ContainerSpecification.Artifact.Builder - Class in org.apache.flink.runtime.clusterframework
-
- ContainerSpecification.Artifact.Builder() - Constructor for class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
-
- contains(Object) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- 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.
- containsAll(Collection<?>) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- containsKey(K) - Method in class org.apache.flink.runtime.util.LRUCacheMap
-
- containsKeyGroup(int) - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
-
- convertKeyedBackendState(HashMap<String, KvStateSnapshot<?, ?, ?, ?>>, int, long) - Static method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0Serializer
-
This is public so that we can use it when restoring a legacy snapshot
in AbstractStreamOperatorTestHarness
.
- convertOperatorAndFunctionState(StreamTaskState) - Static method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0Serializer
-
This is public so that we can use it when restoring a legacy snapshot
in AbstractStreamOperatorTestHarness
.
- convertStateHandle(StateHandle<?>) - Static method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0Serializer
-
This is public so that we can use it when restoring a legacy snapshot
in AbstractStreamOperatorTestHarness
.
- copy(Serializable) - Method in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
-
Deprecated.
- copy(Serializable, Serializable) - Method in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
-
Deprecated.
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
-
Deprecated.
- copy(Path, Path, boolean) - Static method in class org.apache.flink.runtime.filecache.FileCache
-
- 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
-
- 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
-
- 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
-
- 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(Path, boolean, int, short, long) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- create(Path, boolean) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- create(Path, boolean, int, short, long) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
-
- create(Path, boolean) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
-
- 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() - Static method in class org.apache.flink.runtime.util.LRUCache
-
- create() - Static method in class org.apache.flink.runtime.util.LRUCacheMap
-
- 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
-
- createAndAddResultDataSet(ResultPartitionType) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- createAndAddResultDataSet(IntermediateDataSetID, ResultPartitionType) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- 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
-
- 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, boolean) - 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, boolean) - 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
-
- 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.
- createCheckpointIDCounter(JobID) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
-
- 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
-
- createCheckpointStateOutputStream(long, long) - Method in interface org.apache.flink.runtime.state.CheckpointStreamFactory
-
- createCheckpointStateOutputStream(long, long) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
-
- createCheckpointStateOutputStream(long, long) - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory
-
- createCheckpointStore(JobID, ClassLoader) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
-
- createCheckpointStore(JobID, ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
-
- createCheckpointStore(JobID, ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
-
- createClient() - Method in class org.apache.flink.runtime.blob.BlobCache
-
- createClient() - Method in class org.apache.flink.runtime.blob.BlobServer
-
- createClient() - Method in interface org.apache.flink.runtime.blob.BlobService
-
- createClientSSLContext() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- createCompletedCheckpoints(CuratorFramework, Configuration, JobID, int, Executor) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- 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
-
- createDetailsForJob(AccessExecutionGraph) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
-
- 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
-
- createFoldingState(TypeSerializer<N>, FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- createFoldingState(TypeSerializer<N>, FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- createFromConfig(Configuration) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackendFactory
-
- createFromConfig(Configuration) - Method in interface org.apache.flink.runtime.state.StateBackendFactory
-
Creates the state backend, optionally using the given configuration.
- 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.migration.MigrationNamespaceSerializerProxy
-
Deprecated.
- 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.
- createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
-
Creates a new
AbstractKeyedStateBackend
that is responsible for keeping keyed state
and can be checkpointed to checkpoint streams.
- 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
-
- 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.
- createKvStateTaskRegistry(JobID, JobVertexID) - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- createLeaderElectionService(Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- createLeaderElectionService(CuratorFramework, Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- createLeaderRetrievalService(Configuration) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
-
- createLeaderRetrievalService(Configuration, boolean) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
-
- createLeaderRetrievalService(Configuration, ActorRef) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
-
Creates a
LeaderRetrievalService
that either uses the distributed leader election
configured in the configuration, or, in standalone mode, the given actor reference.
- createLeaderRetrievalService(Configuration) - Static method in class org.apache.flink.runtime.util.StandaloneUtils
-
- createLeaderRetrievalService(Configuration, boolean) - Static method in class org.apache.flink.runtime.util.StandaloneUtils
-
- createLeaderRetrievalService(Configuration, boolean, String) - Static method in class org.apache.flink.runtime.util.StandaloneUtils
-
- createLeaderRetrievalService(Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- createListState(TypeSerializer<N>, ListStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- 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
-
- createNewMap() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
Creates a new map for use in Heap based state.
- createOperatorStateBackend(Environment, String) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
-
Creates a new
OperatorStateBackend
that can be used for storing partitionable operator
state in checkpoint streams.
- createPartitionRequestClient(ConnectionID) - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
-
- 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
-
- createReadView(BufferProvider, 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
-
- 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
-
- 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
-
- createRestartStrategyFactory(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
-
- 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
-
- createServerSSLContext() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- createSharedCount(String, int) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
-
- createSharedValue(String, byte[]) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
-
- 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
-
- 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
- createSSLServerContext(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
Creates the SSL Context for the server if SSL is configured
- createStreamFactory(JobID, String) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
-
- createStreamFactory(JobID, String) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
- createStreamFactory(JobID, String) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
-
- createSubmittedJobGraphs(CuratorFramework, Configuration, Executor) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- createSubpartitionView(int, BufferProvider, BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Returns the requested subpartition.
- createSubpartitionView(ResultPartitionID, int, BufferProvider, BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
-
- createSubpartitionView(ResultPartitionID, int, BufferProvider, BufferAvailabilityListener) - Method in interface org.apache.flink.runtime.io.network.partition.ResultPartitionProvider
-
Returns the requested intermediate result partition input view.
- createTaskRegistry(JobID, JobVertexID) - Method in class org.apache.flink.runtime.query.KvStateRegistry
-
- 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
-
- createValueState(TypeSerializer<N>, ValueStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- createValueState(TypeSerializer<N>, ValueStateDescriptor<V>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- 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
-
- 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
-
- 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
-
- 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.
- 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
-
- generate() - Static method in class org.apache.flink.runtime.clusterframework.types.ResourceID
-
Generate a random resource id.
- generatePlan(JobGraph) - Static method in class org.apache.flink.runtime.jobgraph.jsonplan.JsonPlanGenerator
-
- 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
-
- GenericFoldingState<N,T,ACC,W extends ValueState<ACC> & KvState<N>> - Class in org.apache.flink.runtime.state
-
- GenericFoldingState(ValueState<ACC>, FoldFunction<T, ACC>) - Constructor for class org.apache.flink.runtime.state.GenericFoldingState
-
Creates a new
FoldingState
that wraps the given
ValueState
.
- GenericListState<N,T,W extends ValueState<ArrayList<T>> & KvState<N>> - Class in org.apache.flink.runtime.state
-
- GenericListState(ValueState<ArrayList<T>>) - Constructor for class org.apache.flink.runtime.state.GenericListState
-
Creates a new
ListState
that wraps the given
ValueState
.
- 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
-
- GenericReducingState<N,T,W extends ValueState<T> & KvState<N>> - Class in org.apache.flink.runtime.state
-
- GenericReducingState(ValueState<T>, ReduceFunction<T>) - Constructor for class org.apache.flink.runtime.state.GenericReducingState
-
Creates a new
ReducingState
that wraps the given
ValueState
.
- get(JobID, String) - Method in class org.apache.flink.runtime.blob.BlobClient
-
Downloads the BLOB identified by the given job ID and key from the BLOB server.
- get(BlobKey) - Method in class org.apache.flink.runtime.blob.BlobClient
-
Downloads the BLOB identified by the given BLOB key from the BLOB server.
- 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() - Method in interface org.apache.flink.runtime.concurrent.Future
-
Gets the result value of the future.
- get(long, TimeUnit) - Method in interface org.apache.flink.runtime.concurrent.Future
-
Gets the result value of the future.
- get() - Method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
-
- get(long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
-
- 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(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() - Method in class org.apache.flink.runtime.state.GenericFoldingState
-
- get() - Method in class org.apache.flink.runtime.state.GenericListState
-
- get() - Method in class org.apache.flink.runtime.state.GenericReducingState
-
- get() - Method in class org.apache.flink.runtime.state.heap.HeapFoldingState
-
- get() - Method in class org.apache.flink.runtime.state.heap.HeapListState
-
- get() - Method in class org.apache.flink.runtime.state.heap.HeapReducingState
-
- get(int) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- get() - Static method in class org.apache.flink.runtime.state.VoidNamespace
-
- 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
-
- get(K) - Method in class org.apache.flink.runtime.util.LRUCacheMap
-
- get(Throwable, ClassLoader) - Static method in exception org.apache.flink.runtime.util.SerializedThrowable
-
- get(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Gets a state handle from ZooKeeper.
- getAccessTime() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
-
- 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
-
- 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.
- 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.
- 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
-
- getActorGateway() - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
-
- getActorGatewayFuture() - Method in class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderGatewayListener
-
- 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 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.query.netty.KvStateServer
-
Returns the address of this server.
- getAddress() - Method in class org.apache.flink.runtime.util.LeaderConnectionInfo
-
- 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
-
- 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
-
- getAggregateState() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
-
- getAggregateState() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- 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
-
- 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.
- 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).
- getAlignmentDurationNanos() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetaData
-
- 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.
- getAll() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Gets all available state handles from ZooKeeper.
- getAllAggregators() - Method in class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
-
- getAllCheckpoints() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
- getAllCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
-
- getAllCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
-
- 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
-
- getAllocatedSlot() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the allocated slot that this slot refers to.
- 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
-
- getAllSortedByName() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Gets all available state handles from ZooKeeper sorted by name (ascending).
- 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.ComponentMetricGroup
-
- 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
-
- getAllWriters() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- 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
-
- getAndRemove(String) - Method in class org.apache.flink.runtime.iterative.concurrent.Broker
-
blocking retrieval and removal of the object to share
- 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
-
- getArchivedExecutionConfig() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getArchivedExecutionConfig() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Returns the serializable ArchivedExecutionConfig
- getArtifacts() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
-
Get the container artifacts.
- getAssignedResource() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getAssignedResourceLocation() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
- getAssignedResourceLocation() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
-
- getAssignedResourceLocation() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- 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.
- getAsyncDurationMillis() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetaData
-
- getAsyncDurationMillis() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- getAttemptId() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
- 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
-
- getAverage() - Method in class org.apache.flink.runtime.checkpoint.MinMaxAvgStats
-
Calculates the average over all seen values.
- getBasePath() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Gets the base directory where all state-containing files are stored.
- getBlobServerPort() - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
-
- 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
-
- getBlockSize() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
-
- 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
-
- getBroadcastOperatorState(ListStateDescriptor<S>) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- getBroadcastSerializableListState(String) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- 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.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
-
- 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 class 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
-
- 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
-
- getByteArray() - Method in class org.apache.flink.runtime.util.DataOutputSerializer
-
- getBytesBufferedInAlignment() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetaData
-
- 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.
- getBytesWritten() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
Gets the number of pay-load bytes already written.
- 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
-
- getCause() - Method in class org.apache.flink.runtime.query.netty.message.KvStateRequestFailure
-
Returns the failure cause.
- 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
-
- 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
-
- getCheckpointById(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
-
- getCheckpointCoordinator() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
- getCheckpointCoordinator() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getCheckpointCoordinator() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getCheckpointId() - Method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0
-
- 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.io.network.api.CancelCheckpointMarker
-
- getCheckpointId() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
-
- 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.SerializedCheckpointData
-
Gets the checkpointId of the checkpoint.
- getCheckpointId() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
-
- getCheckpointIdCounter() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- getCheckpointInterval() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobSnapshottingSettings
-
- getCheckpointMetaData() - Method in class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
-
- getCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
-
- getCheckpointStatsTracker() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
- getCheckpointStatsTracker() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getCheckpointStatsTracker() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- 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.JobSnapshottingSettings
-
- 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
-
- 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 class org.apache.flink.runtime.execution.librarycache.FallbackLibraryCacheManager
-
- getClassLoader(JobID) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
-
Returns the user code class loader associated with id.
- getClasspaths() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- getClientChannelHandlers() - Method in interface org.apache.flink.runtime.io.network.netty.NettyProtocol
-
- 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
-
- getClosableRegistry() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
-
- 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
-
- getCoLocationGroup() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getCoLocationGroup() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getComparatorWithCurrentReference() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator
-
- getComparatorWithCurrentReference() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator
-
- getCompletionFuture() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
Returns the completion future.
- 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.operators.util.TaskConfig
-
Gets the configuration that holds the actual values encoded.
- getConfiguration() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
-
Gets the configuration that the TaskManager was started with.
- 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
-
- getConsumedPartitionId() - Method in class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
-
- getConsumedPartitionLocation() - Method in class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
-
- 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
-
- getConvergenceCriterion(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getConvergenceCriterionAggregatorName() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getCopyOfBuffer() - Method in class org.apache.flink.runtime.util.DataOutputSerializer
-
- getCount() - Method in class org.apache.flink.runtime.checkpoint.MinMaxAvgStats
-
Returns the count of all seen values.
- getCounts() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
-
Returns the snapshotted checkpoint counts.
- 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
-
- 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
-
- getCurrentAssignedResource() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getCurrentAssignedResourceLocation() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
- 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 class org.apache.flink.runtime.io.network.api.serialization.AdaptiveSpanningRecordDeserializer
-
- getCurrentBuffer() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
-
- getCurrentBuffer() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
-
- getCurrentBuffer() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
-
- 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.KeyedStateBackend
-
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.KeyedStateBackend
-
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.
- getData() - Method in class org.apache.flink.migration.runtime.state.memory.AbstractMemStateSnapshot
-
Deprecated.
- getData() - Method in class org.apache.flink.migration.runtime.state.memory.ByteStreamStateHandle
-
Deprecated.
- 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
-
- getDefaultAcl() - Method in class org.apache.flink.runtime.util.ZooKeeperUtils.SecureAclProvider
-
- getDefaultBlockSize() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- getDefaultBlockSize() - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
-
- getDefaultElement() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
-
- getDefaultIOMode() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- getDelegateStateHandle() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
-
- getDelegateStateHandle() - Method in class org.apache.flink.runtime.state.OperatorStateHandle
-
- getDelimiter() - Method in class org.apache.flink.runtime.metrics.MetricRegistry
-
Returns the global delimiter.
- getDelimiter(int) - Method in class 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
-
- 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.
- getDirectMemoryStatsAsString(BufferPoolMXBean) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
-
Returns a String with the direct memory footprint.
- 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.migration.runtime.checkpoint.KeyGroupState
-
Deprecated.
- getDuration() - Method in class org.apache.flink.migration.runtime.checkpoint.SubtaskState
-
Deprecated.
- getDuration() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- 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
-
- getEndKeyGroup() - Method in class org.apache.flink.runtime.state.KeyGroupRange
-
- getEndOffsetExclusive() - Method in class org.apache.flink.runtime.state.BoundedInputStream
-
- getEndTime() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- 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.
- getEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
-
- getExecutedVertex() - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
Gets the task execution attempt currently executed in this slot.
- 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
-
- 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.taskmanager.RuntimeEnvironment
-
- getExecutionContext() - Method in class org.apache.flink.runtime.query.QueryableStateClient
-
Returns the execution context of this client.
- getExecutionGraph() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getExecutionId() - Method in interface org.apache.flink.runtime.execution.Environment
-
Gets the ID of the task execution attempt.
- getExecutionId() - Method in 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
-
- 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.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.
- getExternalizedCheckpointSettings() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobSnapshottingSettings
-
- getExternalPath() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getExternalPath() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
-
Returns the external path if this checkpoint was persisted externally.
- getExternalPath() - Method in class org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
-
Returns the external path if this checkpoint was persisted externally.
- 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 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.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.AccessExecutionGraph
-
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.ArchivedExecutionGraph
-
- 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.ExecutionGraph
-
- getFailureCauseAsString() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getFailureMessage() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
-
Returns the failure message or null
if no cause was provided.
- getFailureTimestamp() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
-
Returns the timestamp when this checkpoint failed.
- getFile(BlobKey) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
-
- getFile(BlobKey) - Method in class org.apache.flink.runtime.execution.librarycache.FallbackLibraryCacheManager
-
- getFile(BlobKey) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
-
Returns a file handle to the file identified by the blob key.
- getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
-
- 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
-
- getFilePath() - Method in class org.apache.flink.migration.runtime.state.filesystem.AbstractFileStateHandle
-
Deprecated.
Gets the path where this handle's state is stored.
- getFilePath() - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
-
Gets the path where this handle's state is stored.
- getFileSize() - Method in class org.apache.flink.migration.runtime.state.filesystem.AbstractFileStateHandle
-
Deprecated.
Returns the file size in bytes.
- getFileStatus(Path) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- getFileStatus(Path) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
-
- getFileSystem() - Method in class org.apache.flink.migration.runtime.state.filesystem.AbstractFileStateHandle
-
Deprecated.
Gets the file system that stores the file state.
- getFinishedJobs() - Method in class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
-
- 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
-
- getFunctionState() - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskState
-
Deprecated.
- 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.
- 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.
- 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
-
- getHadoopConfiguration() - Static method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
Returns a new Hadoop Configuration object using the path to the hadoop conf configured
in the main configuration (flink-conf.yaml).
- getHadoopConfiguration() - Method in class org.apache.flink.runtime.security.SecurityUtils.SecurityConfiguration
-
- getHadoopFileSystem() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
Gets the underlying Hadoop FileSystem.
- getHadoopInputStream() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
-
Gets the wrapped Hadoop input stream.
- getHadoopOutputStream() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataOutputStream
-
Gets the wrapped Hadoop output stream.
- getHadoopWrapperClassNameForFileSystem(String) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- getHandleName() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
-
- 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
-
- getHistory() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
-
Returns the snapshotted checkpoint history.
- getHomeDirectory() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- getHomeDirectory() - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
-
- getHost() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- getHost() - Method in class org.apache.flink.runtime.query.KvStateServerAddress
-
Returns the host address of the KvStateServer.
- getHostname() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
Gets the hostname of the TaskManager.
- getHostname() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
-
Gets host name of the interface that the TaskManager uses to communicate.
- getHosts() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopBlockLocation
-
- 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.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.
- getImplicitConvergenceCriterion(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getImplicitConvergenceCriterionAggregatorName() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getIndexInSubtaskGroup() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the index of this subtask in the subtask group.
- getInitialTableSize(int, int, int, int) - Static method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
- 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
-
- 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
-
- 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() - 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
-
- getInstanceId() - Method in class org.apache.flink.runtime.messages.StackTrace
-
- 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
-
- getInternalFileStatus() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
-
- 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.
- 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.
- getIoHandle() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncIOCallable
-
Returns the IO handle.
- getIOManager() - Method in interface org.apache.flink.runtime.execution.Environment
-
- 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.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
-
- 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
-
- 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
-
- getJobGraph() - Method in class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
-
- 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 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.instance.Slot
-
Returns the ID of the job this allocated slot belongs to.
- 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.slots.AllocatedSlot
-
Returns the ID of the job this allocated slot belongs to.
- getJobId() - Method in class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
-
- getJobId() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- 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.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.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
.
- getJobManagerFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
-
- getJobManagerJobFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
-
- getJobManagerMode() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- 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 thie 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
-
- getJobResultFuture() - Method in class org.apache.flink.runtime.client.JobListeningContext
-
- getJobsCancelled() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsWithIDsOverview
-
- getJobsFailed() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsWithIDsOverview
-
- getJobsFinished() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsWithIDsOverview
-
- getJobsRunningOrPending() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsWithIDsOverview
-
- getJobState() - Method in class org.apache.flink.runtime.client.JobStatusMessage
-
- getJobVertex(JobVertexID) - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
- 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.migration.runtime.checkpoint.TaskState
-
Deprecated.
- getJobVertexID() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
- 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
-
- 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.taskmanager.RuntimeEnvironment
-
- getJobVertexId() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getJobVertexIds() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
-
- 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
-
- 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".
- 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
-
- getKeyGroupId(int) - Method in class org.apache.flink.runtime.state.KeyGroupRange
-
- getKeyGroupId(int) - Method in interface org.apache.flink.runtime.state.KeyGroupsList
-
- getKeyGroupId() - Method in class org.apache.flink.runtime.state.KeyGroupStatePartitionStreamProvider
-
Returns the key group that corresponds to the data in the provided stream.
- getKeyGroupIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
-
- 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 interface org.apache.flink.runtime.state.KeyedStateBackend
-
Returns the key groups for this backend.
- getKeyGroupRange() - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
-
- getKeyGroupsStateHandles(Collection<KeyGroupsStateHandle>, KeyGroupRange) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
-
- getKeyGroupsStateHandles() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
-
- getKeyGroupState() - Method in class org.apache.flink.migration.runtime.checkpoint.KeyGroupState
-
Deprecated.
- getKeySerializer() - Method in class org.apache.flink.migration.runtime.state.filesystem.AbstractFsStateSnapshot
-
Deprecated.
- getKeySerializer() - Method in class org.apache.flink.migration.runtime.state.memory.AbstractMemStateSnapshot
-
Deprecated.
- getKeySerializer() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- getKeySerializer() - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
-
- getKeySerializerProxy() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
-
- getKeytab() - Method in class org.apache.flink.runtime.security.SecurityUtils.SecurityConfiguration
-
- getKvState(int) - Method in class org.apache.flink.migration.runtime.checkpoint.TaskState
-
Deprecated.
- getKvState(KvStateID) - Method in class org.apache.flink.runtime.query.KvStateRegistry
-
Returns the KvState instance identified by the given KvStateID or
null
if none is registered.
- getKvState(KvStateServerAddress, KvStateID, byte[]) - Method in class org.apache.flink.runtime.query.netty.KvStateClient
-
Returns a future holding the serialized request result.
- getKvState(JobID, String, int, byte[]) - Method in class org.apache.flink.runtime.query.QueryableStateClient
-
Returns a future holding the serialized request result.
- 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.
- getKvStateId() - Method in class org.apache.flink.runtime.query.netty.message.KvStateRequest
-
Returns the ID of the requested 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.
- getKvStateLocationRegistry() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getKvStateLookupInfo(JobID, String) - Method in interface org.apache.flink.runtime.query.KvStateLocationLookupService
-
Returns a future holding the
KvStateLocation
for the given job
and KvState registration name.
- getKvStateRegistry() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- getKvStates() - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskState
-
Deprecated.
- 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 KvStateServerAddress 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 - 10.
- getLastHeartBeat() - Method in class org.apache.flink.runtime.instance.Instance
-
Gets the timestamp of the last heartbeat.
- 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.
- getLatestCheckpoint() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
- getLatestCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
-
- getLatestCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
-
- getLatestCompletedCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
-
- getLatestFailedCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
-
- getLatestRestoredCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
-
Returns the latest restored checkpoint.
- getLatestSavepoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
-
- getLeaderConnectionInfoFuture() - Method in class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderConnectionInfoListener
-
- getLeaderSessionID() - Method in class org.apache.flink.runtime.akka.FlinkUntypedActor
-
Returns the current leader session ID associcated 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
-
- getLegacyOperatorState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
Deprecated.
- getLegacyOperatorState() - Method in class org.apache.flink.runtime.state.TaskStateHandles
-
Deprecated.
- getLen() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
-
- getLength() - Method in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
-
Deprecated.
- getLength() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopBlockLocation
-
- 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
-
- 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
-
- getLocality() - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
Gets the locality information attached to this slot.
- getLocation() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
-
Gets the location assigned to this slot.
- getLocationConstraint() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getLocationConstraint(int) - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
-
- getLocationConstraint() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- 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
-
- getLoginContextNames() - Method in class org.apache.flink.runtime.security.SecurityUtils.SecurityConfiguration
-
- getLRU() - Method in class org.apache.flink.runtime.util.LRUCache
-
- getLRU() - Method in class org.apache.flink.runtime.util.LRUCacheMap
-
- getManagedKeyedState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
- getManagedKeyedState() - Method in class org.apache.flink.runtime.state.TaskStateHandles
-
- getManagedOperatorState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
- getManagedOperatorState() - Method in class org.apache.flink.runtime.state.TaskStateHandles
-
- 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
-
- getMaxConcurrentCheckpoints() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobSnapshottingSettings
-
- 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.
- 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.
- getMaxParallelism() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
- 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.
- getMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the memory needed in MB
- getMemoryManager() - Method in interface org.apache.flink.runtime.execution.Environment
-
- 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.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 class org.apache.flink.runtime.io.network.buffer.Buffer
-
- getMemorySegment() - Method in class org.apache.flink.runtime.operators.util.BloomFilter.BitSet
-
- 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.
- 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
-
- getMetaInfo() - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- 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
-
- getMetrics() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetaData
-
- getMinimum() - Method in class org.apache.flink.runtime.checkpoint.MinMaxAvgStats
-
Returns the minimum seen value.
- getMinPauseBetweenCheckpoints() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobSnapshottingSettings
-
- getMode() - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy.StateMetaInfo
-
- getModificationTime() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
-
- 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.state.OperatorBackendSerializationProxy.StateMetaInfo
-
- getName() - Method in class org.apache.flink.runtime.state.RegisteredBackendStateMetaInfo
-
- getNamedStateSerializationProxies() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
-
- getNamedStateSerializationProxies() - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
-
- getNamespaceSerializer() - Method in class org.apache.flink.migration.runtime.state.filesystem.AbstractFsStateSnapshot
-
Deprecated.
- getNamespaceSerializer() - Method in class org.apache.flink.migration.runtime.state.memory.AbstractMemStateSnapshot
-
Deprecated.
- getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.RegisteredBackendStateMetaInfo
-
- getNamespaceSerializerSerializationProxy() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy.StateMetaInfo
-
- 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.
- getNetworkBufferPool() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- 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.partition.ResultSubpartitionView
-
Returns the next
Buffer
instance of this queue iterator.
- getNextBufferOrEvent() - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
- 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.taskmanager.TaskInputSplitProvider
-
- getNextPathNum() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
- getNextRecord(T) - Method in class org.apache.flink.runtime.io.network.api.serialization.AdaptiveSpanningRecordDeserializer
-
- 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() - Method in class org.apache.flink.runtime.io.network.buffer.Buffer
-
- 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(T) - Method in interface org.apache.flink.runtime.concurrent.Future
-
Gets the value of the future.
- getNow(T) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
-
- getNumberCollectedKvStates() - Method in class org.apache.flink.migration.runtime.checkpoint.TaskState
-
Deprecated.
- getNumberCollectedStates() - Method in class org.apache.flink.migration.runtime.checkpoint.TaskState
-
Deprecated.
- getNumberCollectedStates() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
- 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.
- 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
-
- 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.
- 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.
- 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.executiongraph.TaskInformation
-
- getNumberOfKeyGroups() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- getNumberOfKeyGroups() - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
-
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.
- getNumberOfKeyGroups() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
-
- 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
-
- getNumberOfOutputChannels() - Method in class org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
- 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
-
- 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
-
- getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
- getNumberOfReferenceHolders(JobID) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
-
- getNumberOfRegisteredBufferPools() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- getNumberOfRegisteredTaskManagers() - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- 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
-
- 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 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
-
- 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.
- 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
-
- getNumConnections() - Method in class org.apache.flink.runtime.query.netty.AtomicKvStateRequestStats
-
- getNumFailed() - Method in class org.apache.flink.runtime.query.netty.AtomicKvStateRequestStats
-
- getNumIds() - Method in class org.apache.flink.runtime.state.SerializedCheckpointData
-
Gets the number of IDs in the checkpoint.
- 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.
- getNumRequests() - Method in class org.apache.flink.runtime.query.netty.AtomicKvStateRequestStats
-
- getNumRequiredComparators() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
-
- getNumSlotsAvailable() - Method in class org.apache.flink.runtime.messages.webmonitor.StatusOverview
-
- getNumSlotsTotal() - Method in class org.apache.flink.runtime.messages.webmonitor.StatusOverview
-
- getNumSuccessful() - Method in class org.apache.flink.runtime.query.netty.AtomicKvStateRequestStats
-
- getNumTargetKeyGroups() - Method in class 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
-
- getNumTaskManagersConnected() - Method in class org.apache.flink.runtime.messages.webmonitor.StatusOverview
-
- getNumTasks() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getNumVerticesPerExecutionState() - 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
-
- getOffset() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopBlockLocation
-
- getOffsetForKeyGroup(int) - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
-
- getOffsets() - Method in class org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
-
- getOldTaskStates() - Method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0
-
- getOpenFileHandlesLimit() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Tries to retrieve the maximum number of open file handles.
- getOperatorDescription() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getOperatorFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
-
- 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
-
- getOperatorState() - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskState
-
Deprecated.
- getOperatorState(ListStateDescriptor<S>) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- getOperatorStateHandles() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
-
- 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
-
- 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.
- 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.migration.runtime.checkpoint.TaskState
-
Deprecated.
- getParallelism() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
- 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.
- 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
-
- 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
-
- 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 class org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
- 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
-
- getPartitionType() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- getPath() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
-
- getPath() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
-
Returns the path to the underlying temporary file.
- 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).
- getPendingCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- getPipelineBreakingExchange(ExecutionMode) - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
-
- getPort() - Method in class org.apache.flink.runtime.blob.BlobCache
-
- 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 service.
- getPort() - Method in class org.apache.flink.runtime.query.KvStateServerAddress
-
Returns the port of the KvStateServer.
- getPos() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
-
- getPos() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataOutputStream
-
- 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.executiongraph.ExecutionVertex
-
Gets the location preferences of this task, determined by the locations of the predecessors from which
it receives input data.
- 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.SecurityUtils.SecurityConfiguration
-
- 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
-
- 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.
- getPushChainDriverClass() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
-
- getQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Returns the metric query service scope for this group.
- 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.SubtaskState
-
- getRawKeyedState() - Method in class org.apache.flink.runtime.state.TaskStateHandles
-
- 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.SubtaskState
-
- getRawOperatorState() - Method in class org.apache.flink.runtime.state.TaskStateHandles
-
- 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).
- 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.
- 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
- getRecoveryMode(Configuration) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
-
- getRecursionLevel() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
Gets this partition's recursion level.
- getRecycler() - Method in class org.apache.flink.runtime.io.network.buffer.Buffer
-
- getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
-
- 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
-
- 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
-
- getReplication() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
-
- getReporterConfigurations() - Method in class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
-
- getReporters() - Method in class org.apache.flink.runtime.metrics.MetricRegistry
-
- getRequestId() - Method in class org.apache.flink.runtime.query.netty.message.KvStateRequest
-
Returns the request ID.
- getRequestId() - Method in class org.apache.flink.runtime.query.netty.message.KvStateRequestFailure
-
Returns the request ID responding to.
- getRequestId() - Method in class org.apache.flink.runtime.query.netty.message.KvStateRequestResult
-
Returns the request ID responding to.
- 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
- 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
- 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
-
- 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
- getResourceManagerProps(Class<? extends FlinkResourceManager>, Configuration, LeaderRetrievalService) - Static method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
- getResourceProfile() - Method in class org.apache.flink.runtime.jobmanager.slots.AllocatedSlot
-
Gets the resource profile of the slot.
- getResources() - Method in class org.apache.flink.runtime.instance.Instance
-
- getRestartStrategy() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- 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.
- 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
-
- 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.
- getRunningJobs() - Method in class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
-
- getSampleId() - Method in class org.apache.flink.runtime.messages.StackTraceSampleResponse
-
- getSamples() - Method in class org.apache.flink.runtime.messages.StackTraceSampleResponse
-
- getSavepointRestoreSettings() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns the configured savepoint restore setting.
- 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 class org.apache.flink.runtime.metrics.MetricRegistry
-
- getScopeFormats() - Method in class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
-
- getSecurityModules() - Method in class org.apache.flink.runtime.security.SecurityUtils.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.
- getSendAndReceiveBufferSize() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getSerializableListState(String) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- getSerializedAccumulatorResults() - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
-
- getSerializedData() - Method in class org.apache.flink.migration.runtime.state.memory.SerializedStateHandle
-
- getSerializedData() - Method in class org.apache.flink.runtime.state.SerializedCheckpointData
-
Gets the binary data for the serialized elements.
- getSerializedExecutionConfig() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
-
- getSerializedExecutionConfig() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- getSerializedJobInformation() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Return the sub task's serialized job information.
- getSerializedJobInformation() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getSerializedKeyAndNamespace() - Method in class org.apache.flink.runtime.query.netty.message.KvStateRequest
-
Returns the serialized key and namespace to request from the KvState
instance.
- getSerializedResult() - Method in class org.apache.flink.runtime.query.netty.message.KvStateRequestResult
-
Returns the serialized result or null
if none available.
- getSerializedTaskInformation() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Return the sub task's serialized task information.
- getSerializedTaskInformation() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getSerializedValue(byte[]) - Method in class org.apache.flink.runtime.state.GenericFoldingState
-
- getSerializedValue(byte[]) - Method in class org.apache.flink.runtime.state.GenericListState
-
- getSerializedValue(byte[]) - Method in class org.apache.flink.runtime.state.GenericReducingState
-
- getSerializedValue(byte[]) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
- getSerializedValue(K, N) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
- getSerializedValue(K, N) - Method in class org.apache.flink.runtime.state.heap.HeapListState
-
- getSerializedValue(byte[]) - Method in interface org.apache.flink.runtime.state.KvState
-
Returns the serialized value for the given key and namespace.
- getSerializer(T) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializers
-
- getSerializer(int) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializers
-
- getServerChannelHandlers() - Method in interface org.apache.flink.runtime.io.network.netty.NettyProtocol
-
- 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.
- 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", ...
- getSimpleName() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- 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 class org.apache.flink.runtime.io.network.buffer.Buffer
-
- 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.
- getSizeOfSerializedState() - Method in class org.apache.flink.migration.runtime.state.memory.SerializedStateHandle
-
Gets the size of the serialized state.
- getSlotAllocationId() - Method in class org.apache.flink.runtime.jobmanager.slots.AllocatedSlot
-
Gets the ID under which the slot is allocated, which uniquely identifies the slot.
- getSlotForTask(ExecutionVertex) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
-
Gets a slot suitable for the given task vertex.
- getSlotForTask(ExecutionVertex, CoLocationConstraint) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
-
Gets a slot for a task that has a co-location constraint.
- getSlotNumber() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the number of the slot.
- getSlotNumber() - Method in class org.apache.flink.runtime.jobmanager.slots.AllocatedSlot
-
Gets the number of the slot.
- getSlotProvider() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getSlotSharingGroup() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getSlotSharingGroup() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Gets the slot sharing group that this vertex is associated with.
- getSlotSharingGroup() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- getSnapshot() - Method in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
-
Creates a snapshot of this accumulator registry.
- getSnapshotSettings() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Gets the settings for asynchronous snapshots.
- getSnapshottingSettings() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
-
Returns the job's snapshotting settings which are derived from the
CheckpointConfig.
- 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
- getStackTrace() - Method in class org.apache.flink.runtime.messages.StackTrace
-
- 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
-
- getState() - Method in class org.apache.flink.migration.runtime.checkpoint.SubtaskState
-
Deprecated.
- getState(int) - Method in class org.apache.flink.migration.runtime.checkpoint.TaskState
-
Deprecated.
- getState(ClassLoader) - Method in class org.apache.flink.migration.runtime.state.AbstractStateBackend.DataInputViewHandle
-
Deprecated.
- getState(ClassLoader) - Method in class org.apache.flink.migration.runtime.state.filesystem.FileSerializableStateHandle
-
Deprecated.
- getState(ClassLoader) - Method in class org.apache.flink.migration.runtime.state.filesystem.FileStreamStateHandle
-
Deprecated.
- getState(ClassLoader) - Method in class org.apache.flink.migration.runtime.state.memory.ByteStreamStateHandle
-
Deprecated.
- getState(ClassLoader) - Method in class org.apache.flink.migration.runtime.state.memory.SerializedStateHandle
-
- getState(ClassLoader) - Method in interface org.apache.flink.migration.runtime.state.StateHandle
-
Deprecated.
This retrieves and return the state represented by the handle.
- getState(ClassLoader) - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskStateList
-
Deprecated.
- getState(int) - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
- getState() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
- 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(ValueStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
-
- getState() - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- getState(ClassLoader) - Method in interface org.apache.flink.runtime.state.StateHandle
-
This retrieves and return the state represented by the handle.
- getStateDesc() - Method in class org.apache.flink.migration.runtime.state.filesystem.AbstractFsStateSnapshot
-
Deprecated.
- getStateName() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy.StateMetaInfo
-
- getStateNameToPartitionOffsets() - Method in class org.apache.flink.runtime.state.OperatorStateHandle
-
- getStates() - Method in class org.apache.flink.migration.runtime.checkpoint.TaskState
-
Deprecated.
- getStates() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
- getStateSerializer() - Method in class org.apache.flink.migration.runtime.state.filesystem.AbstractFsStateSnapshot
-
Deprecated.
- getStateSerializer() - Method in class org.apache.flink.migration.runtime.state.memory.AbstractMemStateSnapshot
-
Deprecated.
- getStateSerializer() - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- getStateSerializer() - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy.StateMetaInfo
-
- getStateSerializer() - Method in class org.apache.flink.runtime.state.RegisteredBackendStateMetaInfo
-
- getStateSerializerSerializationProxy() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy.StateMetaInfo
-
- getStateSize() - Method in class org.apache.flink.migration.runtime.checkpoint.KeyGroupState
-
Deprecated.
- getStateSize() - Method in class org.apache.flink.migration.runtime.checkpoint.SubtaskState
-
Deprecated.
- getStateSize() - Method in class org.apache.flink.migration.runtime.checkpoint.TaskState
-
Deprecated.
- getStateSize() - Method in class org.apache.flink.migration.runtime.state.AbstractStateBackend.DataInputViewHandle
-
Deprecated.
- getStateSize() - Method in class org.apache.flink.migration.runtime.state.filesystem.AbstractFsStateSnapshot
-
Deprecated.
- getStateSize() - Method in class org.apache.flink.migration.runtime.state.filesystem.FileSerializableStateHandle
-
Deprecated.
Returns the file size in bytes.
- getStateSize() - Method in class org.apache.flink.migration.runtime.state.filesystem.FileStreamStateHandle
-
Deprecated.
Returns the file size in bytes.
- getStateSize() - Method in class org.apache.flink.migration.runtime.state.memory.AbstractMemStateSnapshot
-
Deprecated.
- getStateSize() - Method in class org.apache.flink.migration.runtime.state.memory.ByteStreamStateHandle
-
Deprecated.
- getStateSize() - Method in class org.apache.flink.migration.runtime.state.memory.SerializedStateHandle
-
- getStateSize() - Method in interface org.apache.flink.migration.runtime.state.StateObject
-
Deprecated.
Returns the size of the state in bytes.
- getStateSize() - Method in class org.apache.flink.migration.state.MigrationStreamStateHandle
-
Deprecated.
- getStateSize() - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskStateList
-
Deprecated.
- 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.PendingCheckpointStats
-
- 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
-
- 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.state.ChainedStateHandle
-
- 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.KeyGroupsStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.MultiStreamStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.OperatorStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.RetrievableStreamStateHandle
-
- getStateSize() - Method in interface org.apache.flink.runtime.state.StateObject
-
Returns the size of the state in bytes.
- 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
-
- getStateTimestamp(ExecutionState) - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
- 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
-
- 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.KeyedBackendSerializationProxy.StateMetaInfo
-
- getStateType() - Method in class org.apache.flink.runtime.state.RegisteredBackendStateMetaInfo
-
- 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
-
- 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
-
- getStopException() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncIOCallable
-
Returns Exception that might happen on stop.
- getStopException() - Method in interface org.apache.flink.runtime.io.async.AsyncStoppable
-
- getStorageDir() - Method in class org.apache.flink.runtime.blob.BlobCache
-
- getStream() - Method in class org.apache.flink.runtime.state.StatePartitionStreamProvider
-
Returns a stream with the data of one state partition.
- getStreamStateHandle() - Method in class org.apache.flink.migration.runtime.state.AbstractStateBackend.DataInputViewHandle
-
Deprecated.
- 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
-
- 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.
- getSubtaskState() - Method in class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
-
- getSubtaskStates() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
- getSubtaskStatesById() - Method in class org.apache.flink.migration.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.
- 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.
- getSyncDurationMillis() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetaData
-
- getSyncDurationMillis() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- 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.
- getTargetSlotNumber() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Gets the number of the slot into which the task is to be deployed.
- 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 class org.apache.flink.runtime.io.network.NetworkEnvironment
-
- getTaskExecutionId() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
-
- 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
-
- getTaskKvStateRegistry() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the registry for
KvState
instances.
- getTaskKvStateRegistry() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- 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.Slot
-
Gets the actor gateway that can be used to send messages to the TaskManager.
- getTaskManagerGateway() - Method in class org.apache.flink.runtime.jobmanager.slots.AllocatedSlot
-
Gets the actor gateway that can be used to send messages to the TaskManager.
- 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
-
- 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.Slot
-
Gets the location info of the TaskManager that offers this slot.
- getTaskManagerLocation() - Method in class org.apache.flink.runtime.jobmanager.slots.AllocatedSlot
-
Gets the location info of the TaskManager that offers this slot.
- 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.
- 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
-
- getTaskState(JobVertexID) - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getTaskStateHandles() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
- getTaskStateHandles() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getTaskStates() - Method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0
-
- getTaskStates() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getTaskStates() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- getTaskStates() - Method in interface org.apache.flink.runtime.checkpoint.savepoint.Savepoint
-
Returns the snapshotted task states.
- getTaskStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
-
- 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".
- getTimeout() - Method in class org.apache.flink.runtime.client.JobListeningContext
-
- 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.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
-
- getTmpDirectories() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
-
Gets the list of temporary file directories.
- getTotalNumberOfBuffers() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getTotalNumberOfBuffers() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
- getTotalNumberOfBytes() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- 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
-
- getTotalNumPages() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Gets the total number of memory pages managed by this memory manager.
- getTransportType() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getTriggerTimestamp() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the timestamp when the checkpoint was triggered.
- getType() - Method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
-
- getType() - Method in exception org.apache.flink.runtime.broadcast.InitializationTypeConflictException
-
- getUdfRuntimeContext() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- getUnwrappedKvStates(Set<Integer>) - Method in class org.apache.flink.migration.runtime.checkpoint.TaskState
-
Deprecated.
Retrieve the set of key-value state key groups specified by the given key group partition set.
- getUri() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- getUri() - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
-
- getURL(BlobKey) - Method in class org.apache.flink.runtime.blob.BlobCache
-
Returns the URL for the BLOB with the given key.
- getURL(BlobKey) - Method in class org.apache.flink.runtime.blob.BlobServer
-
Method which retrieves the URL of a file associated with a blob key.
- getURL(BlobKey) - Method in interface org.apache.flink.runtime.blob.BlobService
-
This method returns the URL of the file associated with the provided blob key.
- getUseLargeRecordHandler() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getUserAccumulators() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getUserAccumulators() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- 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.
- 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.
- getUserMap() - Method in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
-
Gets the map for user-defined accumulators.
- getUserRunning() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Gets the name of the user that is running the JVM.
- getValue() - Method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
-
- getValue() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
-
- getValue() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperVersionedValue
-
- 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.
- 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.migration.runtime.checkpoint.savepoint.SavepointV0
-
- getVersion() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
-
- 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.JobSnapshottingSettings
-
- getVerticesToConfirm() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobSnapshottingSettings
-
- 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.JobSnapshottingSettings
-
- getWaitForSolutionSetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getWebUIPort() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- getWorkerIndex() - Method in class org.apache.flink.runtime.iterative.event.WorkerDoneEvent
-
- getWorkingDirectory() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- getWorkingDirectory() - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
-
- 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
-
- getWriters() - Method in class org.apache.flink.runtime.operators.shipping.OutputCollector
-
List of writers that are associated with this output collector
- 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.SecurityUtils.SecurityConfiguration
-
- getZooKeeperServiceName() - Method in class org.apache.flink.runtime.security.SecurityUtils.SecurityConfiguration
-
- 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.
- gracefulShutdown(long, TimeUnit, ExecutorService...) - Static method in class org.apache.flink.runtime.concurrent.Executors
-
- 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.
- 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
-
- id - Variable in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
-
The ID of the underlying channel.
- includeLegacyJobVertexIDs(Map<JobVertexID, ExecutionJobVertex>) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- increaseBackoff() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Increases the current backoff and returns whether the operation was successful.
- increment() - Method in class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
-
Increments the reference count and returns whether it was successful.
- 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
-
- 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
-
- 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.
- initBroadcastInputReaders() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- 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
-
- 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(URI) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- initialize(URI) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
-
- 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
-
- 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
- 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
-
- initialPartitionBuffersCount - Variable in class org.apache.flink.runtime.operators.hash.ReOpenableHashPartition
-
- initInputReaders() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- 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
-
- 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.EntryIterator() - Constructor for class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.EntryIterator
-
- InPlaceMutableHashTable.HashTableProber<PT> - Class in org.apache.flink.runtime.operators.hash
-
A prober for accessing the table.
- InPlaceMutableHashTable.HashTableProber(TypeComparator<PT>, TypePairComparator<PT, T>) - Constructor for class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
-
- 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.
- InPlaceMutableHashTable.ReduceFacade(ReduceFunction<T>, Collector<T>, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.ReduceFacade
-
- 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
-
- 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.
- InputChannel.BufferAndAvailability(Buffer, boolean) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputChannel.BufferAndAvailability
-
- 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>) - 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, 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.
- 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.
- 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(SecurityUtils.SecurityConfiguration) - Method in class org.apache.flink.runtime.security.modules.HadoopModule
-
- install(SecurityUtils.SecurityConfiguration) - Method in class org.apache.flink.runtime.security.modules.JaasModule
-
- install(SecurityUtils.SecurityConfiguration) - Method in interface org.apache.flink.runtime.security.modules.SecurityModule
-
Install the security module.
- install(SecurityUtils.SecurityConfiguration) - Method in class org.apache.flink.runtime.security.modules.ZooKeeperModule
-
- install(SecurityUtils.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.
- INSTANCE - Static variable in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
-
Deprecated.
- INSTANCE - Static variable in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0Serializer
-
- instance() - Static method in class org.apache.flink.runtime.broadcast.DefaultBroadcastVariableInitializer
-
- INSTANCE - Static variable in class org.apache.flink.runtime.checkpoint.RoundRobinOperatorStateRepartitioner
-
- 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
-
- INSTANCE - Static variable in class org.apache.flink.runtime.iterative.event.TerminationEvent
-
- INSTANCE - Static variable in class org.apache.flink.runtime.state.VoidNamespace
-
- INSTANCE - Static variable in class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- INSTANCE - Static variable in class org.apache.flink.runtime.util.ExecutorThreadFactory
-
- 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.
- instantiateMetrics(TaskIOMetricGroup) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
-
Insantiates all metrics.
- instantiateMetrics(TaskIOMetricGroup) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
-
- instantiateNetworkMetrics(MetricGroup, NetworkEnvironment) - Static method in class org.apache.flink.runtime.metrics.util.MetricUtils
-
- instantiateStatusMetrics(MetricGroup) - 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(JobVertex) - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateDataSet
-
- IntermediateDataSet(IntermediateDataSetID, JobVertex) - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateDataSet
-
- 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
-
- 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.
- 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
-
- 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
-
- ioBuffer() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
-
- ioBuffer(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
-
- ioBuffer(int, int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
-
- 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
-
- 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.
- 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.
- isAssignedAndAlive() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
-
- isBlocking() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
- isBuffer() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileSegment
-
- isBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.Buffer
-
- 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
-
- isCanceled() - Method in class org.apache.flink.runtime.instance.Slot
-
Checks of the slot has been cancelled.
- 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.
- 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.migration.runtime.state.AbstractCloseableHandle
-
Deprecated.
Checks whether this handle has been closed.
- 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.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
-
- isCompatibleWith(RegisteredBackendStateMetaInfo<?, ?>) - Method in class org.apache.flink.runtime.state.RegisteredBackendStateMetaInfo
-
- isCompleted() - Method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
-
Returns whether the checkpoint has completed successfully.
- isConsumable() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
-
- isConverged(int, LongValue) - Method in class org.apache.flink.runtime.iterative.convergence.WorksetEmptyConvergenceCriterion
-
- 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
-
- isDir() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
-
- isDirectBufferPooled() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
-
- 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
-
- isDisposed() - Method in class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
-
Returns whether the reference count has reached the disposed state.
- isDistributedFS() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- isDistributedFS() - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
-
- isDone() - Method in interface org.apache.flink.runtime.concurrent.Future
-
Checks if the future has been completed.
- isDone() - Method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
-
- isDone() - Method in class org.apache.flink.runtime.state.DoneFuture
-
- isEmpty() - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskState
-
Deprecated.
Checks if this state object actually contains any state, or if all of the state
fields are null.
- isEmpty() - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskStateList
-
Deprecated.
- 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.util.EvictingBoundedList
-
- isEmpty() - Method in class org.apache.flink.runtime.util.IntArrayList
-
- isEmpty() - Method in class org.apache.flink.runtime.util.LongArrayList
-
- isEmpty() - Method in class org.apache.flink.runtime.util.LRUCache
-
- isEmpty() - Method in class org.apache.flink.runtime.util.LRUCacheMap
-
- isEndOfSuperstep() - Method in class org.apache.flink.runtime.iterative.task.SyncEventHandler
-
- isEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
-
- isExactlyOnce() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobSnapshottingSettings
-
- isFailed() - Method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
-
Returns whether the checkpoint has failed.
- 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 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
-
- isFullBuffer() - Method in enum org.apache.flink.runtime.io.network.api.serialization.RecordSerializer.SerializationResult
-
- 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
-
- isFullyAcknowledged() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- isGloballyTerminalState() - Method in enum org.apache.flink.runtime.jobgraph.JobStatus
-
- isHighAvailabilityModeActivated(Configuration) - Static method in enum org.apache.flink.runtime.jobmanager.HighAvailabilityMode
-
Returns true if the defined recovery mode supports high availability.
- isIdReference() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
- isImmutableType() - Method in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
-
Deprecated.
- isImmutableType() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- isImmutableType() - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- isInFinalState() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- 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.
- isLeader() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
-
- isLocal() - Method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
-
- isMatching(ResourceProfile) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Check whether required resource profile can be matched
- 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
-
- isNetworkStrategy() - Method in enum org.apache.flink.runtime.operators.shipping.ShipStrategyType
-
- isNullOrEmpty(ChainedStateHandle<?>) - Static method in class org.apache.flink.runtime.state.ChainedStateHandle
-
- isOldSavepointKeyedState(Collection<KeyGroupsStateHandle>) - Static method in class org.apache.flink.migration.MigrationUtil
-
- isOutputVertex() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- isPersistent() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
- 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.
- 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
-
- isRecycled() - Method in class org.apache.flink.runtime.io.network.buffer.Buffer
-
- isRegistered(InstanceID) - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- isRegistered(ResourceID) - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- isReleased() - Method in class org.apache.flink.runtime.instance.Slot
-
Checks of the slot has been released.
- isReleased() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
- isReleased() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
-
- isRemote() - Method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
-
- isRestored() - Method in interface org.apache.flink.runtime.state.ManagedInitializationContext
-
Returns true, if some managed 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.operators.sort.UnilateralSortMerger.ThreadBase
-
Checks whether this thread is still alive.
- isSavepoint(CheckpointProperties) - Static method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
-
Returns whether the checkpoint properties describe a standard savepoint.
- isScheduleLocalOnly() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- 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.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.MetricRegistry
-
Returns whether this registry has been shutdown.
- 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.
- 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
-
- isStopped() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncIOCallable
-
Check if the IO operation is stopped
- isStopped() - Method in interface org.apache.flink.runtime.io.async.AsyncStoppable
-
Check whether the operation is stopped
- 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
-
- isUnknown() - Method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
-
- isWorksetIteration - Variable in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- isWorksetUpdate - Variable in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- isZooKeeperRecoveryMode(Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- 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
-
- 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 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() - Constructor for class org.apache.flink.runtime.iterative.task.IterationHeadTask
-
- IterationIntermediateTask<S extends Function,OT> - Class in org.apache.flink.runtime.iterative.task
-
An intermediate iteration task, which runs a
Driver
inside.
- IterationIntermediateTask() - Constructor for class org.apache.flink.runtime.iterative.task.IterationIntermediateTask
-
- IterationSynchronizationSinkTask - Class in org.apache.flink.runtime.iterative.task
-
The task responsible for synchronizing all iteration heads, implemented as an output task.
- IterationSynchronizationSinkTask() - Constructor for class org.apache.flink.runtime.iterative.task.IterationSynchronizationSinkTask
-
- IterationTailTask<S extends Function,OT> - Class in org.apache.flink.runtime.iterative.task
-
An iteration tail, which runs a driver inside.
- IterationTailTask() - Constructor for class org.apache.flink.runtime.iterative.task.IterationTailTask
-
- 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.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.KeyGroupRange
-
- iterator() - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
-
- 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.
- 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
-
- 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.fs.hdfs.HadoopDataInputStream
-
- read(byte[], int, int) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
-
- 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.KeyedBackendSerializationProxy.StateMetaInfo
-
- read(DataInputView) - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
-
- read(DataInputView) - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy.StateMetaInfo
-
- read(byte[], int, int) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- read(byte[]) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- read() - Method in class org.apache.flink.runtime.util.NonClosingStreamDecorator
-
- read(byte[]) - Method in class org.apache.flink.runtime.util.NonClosingStreamDecorator
-
- read(byte[], int, int) - Method in class org.apache.flink.runtime.util.NonClosingStreamDecorator
-
- 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
-
- readBoolean() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- readByte() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readByte() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- readChar() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readChar() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- readDouble() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readDouble() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- reader - Variable in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
- Reader<T extends 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
-
- 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
-
- readFloat() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- readFully(byte[]) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readFully(byte[], int, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readFully(byte[]) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- readFully(byte[], int, int) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- readInt() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readInt() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- 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
-
- readLine() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- readLong() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readLong() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- 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
-
- readShort() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readShort() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- readUnsignedByte() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readUnsignedByte() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- readUnsignedShort() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readUnsignedShort() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- readUTF() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readUTF() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- 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
-
- ReconnectResourceManager - Class in org.apache.flink.runtime.clusterframework.messages
-
This message signals that the ResourceManager should reconnect to the JobManager.
- ReconnectResourceManager(ActorRef) - Constructor for class org.apache.flink.runtime.clusterframework.messages.ReconnectResourceManager
-
- RecordDeserializer<T extends 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
-
- RecordReader<T extends IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.reader
-
- 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 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
-
- RecordWriter<T extends 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
-
- recover() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
- 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.jobmanager.StandaloneSubmittedJobGraphStore
-
- recoverJobGraph(JobID) - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
-
- recoverJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
-
- recursionLevel - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
-
- recycle() - Method in class org.apache.flink.runtime.io.network.buffer.Buffer
-
- recycle(MemorySegment) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferRecycler
-
- 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
-
- 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
-
- refresh() - Method in class org.apache.flink.runtime.security.DynamicConfiguration
-
- register(Metric, String, AbstractMetricGroup) - Method in class org.apache.flink.runtime.metrics.MetricRegistry
-
Registers a new Metric
with this registry.
- register(Logger) - Static method in class org.apache.flink.runtime.util.SignalHandler
-
Register some signal handlers.
- 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.
- registerCloseable(Closeable) - Method in class org.apache.flink.migration.runtime.state.AbstractCloseableHandle
-
Deprecated.
- registerConsumer() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- RegisteredBackendStateMetaInfo<N,S> - Class in org.apache.flink.runtime.state
-
Compound meta information for a registered state in a keyed state backend.
- RegisteredBackendStateMetaInfo(KeyedBackendSerializationProxy.StateMetaInfo<N, S>) - Constructor for class org.apache.flink.runtime.state.RegisteredBackendStateMetaInfo
-
- RegisteredBackendStateMetaInfo(StateDescriptor.Type, String, TypeSerializer<N>, TypeSerializer<S>) - Constructor for class org.apache.flink.runtime.state.RegisteredBackendStateMetaInfo
-
- registeredPartitions - Variable in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
-
- 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.
- RegisterInfoMessageListenerSuccessful - Class in org.apache.flink.runtime.clusterframework.messages
-
This message signals to the application client that the registration was successful.
- registerJob(JobID, Collection<BlobKey>, Collection<URL>) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
-
- registerJob(JobID, Collection<BlobKey>, Collection<URL>) - Method in class org.apache.flink.runtime.execution.librarycache.FallbackLibraryCacheManager
-
- registerJob(JobID, Collection<BlobKey>, Collection<URL>) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
-
Registers a job with its required jar files and classpaths.
- registerJobStatusListener(JobStatusListener) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- registerKvState(JobID, JobVertexID, KeyGroupRange, String, KvState<?>) - Method in class org.apache.flink.runtime.query.KvStateRegistry
-
Registers the KvState instance and returns the assigned ID.
- registerKvState(KeyGroupRange, String, KvState<?>) - 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(KvStateRegistryListener) - Method in class org.apache.flink.runtime.query.KvStateRegistry
-
Registers a listener with the registry.
- 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.
- 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
-
- registerTask(JobID, ExecutionAttemptID, Collection<BlobKey>, Collection<URL>) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
-
- registerTask(JobID, ExecutionAttemptID, Collection<BlobKey>, Collection<URL>) - Method in class org.apache.flink.runtime.execution.librarycache.FallbackLibraryCacheManager
-
- registerTask(JobID, ExecutionAttemptID, Collection<BlobKey>, 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
-
- registerTaskManager(TaskManagerGateway, TaskManagerLocation, HardwareDescription, int) - Method in class org.apache.flink.runtime.instance.InstanceManager
-
Registers a task manager.
- registerWriterForIncomingTaskEvents(ResultPartitionID, ResultPartitionWriter) - Method in class org.apache.flink.runtime.io.network.TaskEventDispatcher
-
- 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
-
- 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(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.
- releaseAll(Object) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Releases all memory segments for the given owner.
- releaseAllReferencesFromTask(BatchTask<?, ?>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableManager
-
- 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
-
- releaseArrays() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- releaseBroadcastVariables(String, int, DistributedRuntimeUDFContext) - Method in class org.apache.flink.runtime.operators.BatchTask
-
- 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
-
- releaseSlot() - Method in class org.apache.flink.runtime.instance.SharedSlot
-
- releaseSlot() - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
- releaseSlot() - Method in class org.apache.flink.runtime.instance.Slot
-
This method cancels and releases the slot and all its sub-slots.
- 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
-
- remainingCapacity() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
-
Returns the remaining capacity of the backing array.
- 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
-
- 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(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() - Method in class org.apache.flink.runtime.util.EmptyIterator
-
- remove(K) - Method in class org.apache.flink.runtime.util.LRUCacheMap
-
- remove() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator.ValuesIterator
-
- remove() - Method in class org.apache.flink.runtime.util.NonReusingMutableToRegularIteratorWrapper
-
- remove() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator.ValuesIterator
-
- remove() - Method in class org.apache.flink.runtime.util.ReusingMutableToRegularIteratorWrapper
-
- remove() - Method in class org.apache.flink.runtime.util.SingleElementIterator
-
- remove(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Removes a state handle from ZooKeeper.
- remove(String, BackgroundCallback) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Removes a state handle from ZooKeeper asynchronously.
- removeAll(Collection<?>) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- removeAndDiscardAllState() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Discards all available state handles and removes them from ZooKeeper.
- removeAndDiscardState(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Discards a state handle and removes it from ZooKeeper.
- removeInstanceListener(InstanceListener) - Method in class org.apache.flink.runtime.instance.InstanceManager
-
- removeJob(JobID) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
-
- removeJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
-
- removeJobGraph(JobID) - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
-
- removeJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
-
- removeJobMetricsGroup(JobID, TaskManagerJobMetricGroup) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
-
- removeLast() - Method in class org.apache.flink.runtime.util.IntArrayList
-
- removeLong(int) - Method in class org.apache.flink.runtime.util.LongArrayList
-
- removeLRU() - Method in class org.apache.flink.runtime.util.LRUCache
-
- removeLRU() - Method in class org.apache.flink.runtime.util.LRUCacheMap
-
- 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.
- removeSavepoint(String) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointStore
-
Removes the savepoint meta data w/o loading and disposing it.
- removeSlotListener() - Method in class org.apache.flink.runtime.instance.Instance
-
Removes the listener that receives notifications for slot availability.
- removeTaskMetricGroup(AbstractID) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
-
- removeVertexFromGroup(JobVertexID) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
-
- rename(Path, Path) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
-
- rename(Path, Path) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
-
- 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.
- reportActiveConnection() - Method in class org.apache.flink.runtime.query.netty.AtomicKvStateRequestStats
-
- reportActiveConnection() - Method in class org.apache.flink.runtime.query.netty.DisabledKvStateRequestStats
-
- reportActiveConnection() - Method in interface org.apache.flink.runtime.query.netty.KvStateRequestStats
-
Reports an active connection.
- reporterIndex - Variable in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
-
- reportFailedRequest() - Method in class org.apache.flink.runtime.query.netty.AtomicKvStateRequestStats
-
- reportFailedRequest() - Method in class org.apache.flink.runtime.query.netty.DisabledKvStateRequestStats
-
- reportFailedRequest() - Method in interface org.apache.flink.runtime.query.netty.KvStateRequestStats
-
Reports a failure during a request.
- 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
-
- reportInactiveConnection() - Method in class org.apache.flink.runtime.query.netty.AtomicKvStateRequestStats
-
- reportInactiveConnection() - Method in class org.apache.flink.runtime.query.netty.DisabledKvStateRequestStats
-
- reportInactiveConnection() - Method in interface org.apache.flink.runtime.query.netty.KvStateRequestStats
-
Reports an inactive connection.
- reportRequest() - Method in class org.apache.flink.runtime.query.netty.AtomicKvStateRequestStats
-
- reportRequest() - Method in class org.apache.flink.runtime.query.netty.DisabledKvStateRequestStats
-
- reportRequest() - Method in interface org.apache.flink.runtime.query.netty.KvStateRequestStats
-
Reports an incoming request.
- reportSuccessfulRequest(long) - Method in class org.apache.flink.runtime.query.netty.AtomicKvStateRequestStats
-
- reportSuccessfulRequest(long) - Method in class org.apache.flink.runtime.query.netty.DisabledKvStateRequestStats
-
- reportSuccessfulRequest(long) - Method in interface org.apache.flink.runtime.query.netty.KvStateRequestStats
-
Reports a successfully handled request.
- requestBuffer() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
Returns a
Buffer
instance from the buffer provider, if one is available.
- requestBufferBlocking() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
Returns a
Buffer
instance from the buffer provider.
- 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
-
- 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
-
- RequestJobsOverview - Class in org.apache.flink.runtime.messages.webmonitor
-
This message requests an overview of how many jobs are in which status.
- RequestJobsWithIDsOverview - Class in org.apache.flink.runtime.messages.webmonitor
-
This message requests an overview of how many jobs are in which status.
- requestMemorySegment() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- 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
-
- 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.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
-
- 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
-
- RequestQueue() - Constructor for class org.apache.flink.runtime.io.disk.iomanager.RequestQueue
-
- 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.
- 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.
- 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.
- 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
-
- 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.
- 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.
- 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
-
- RequiresLeaderSessionID - Interface in org.apache.flink.runtime.messages
-
Marks messages to be sent wrapped in a
JobManagerMessages.LeaderSessionMessage
- 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.NonClosingStreamDecorator
-
- 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
-
- resetEndOfSuperstep() - Method in class org.apache.flink.runtime.iterative.task.SyncEventHandler
-
- resetForNewExecution() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- resetForNewExecution() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- 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 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.
- RESOURCE_MANAGER_NAME - Static variable in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
The default name of the resource manager actor
- 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
-
- ResourceIDRetrievable - Interface in org.apache.flink.runtime.clusterframework.types
-
An interface to retrieve the ResourceID of an object.
- resourceManager() - Method in class org.apache.flink.runtime.clusterframework.messages.ReconnectResourceManager
-
- resourceManager() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterResourceManager
-
- ResourceProfile - Class in org.apache.flink.runtime.clusterframework.types
-
Describe the resource profile of the slot, either when requiring or offering it.
- ResourceProfile(double, long) - Constructor for class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Creates a new ResourceProfile.
- 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.
- restart() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- restart(ExecutionGraph) - Method in class org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy
-
- restart(ExecutionGraph) - Method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
-
- restart(ExecutionGraph) - Method in class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
-
- restart(ExecutionGraph) - Method in interface org.apache.flink.runtime.executiongraph.restart.RestartStrategy
-
- RestartStrategy - Interface in org.apache.flink.runtime.executiongraph.restart
-
- RestartStrategyFactory - Class in org.apache.flink.runtime.executiongraph.restart
-
- RestartStrategyFactory() - Constructor for class org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
-
- restore(Collection<OperatorStateHandle>) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- restore(Collection<KeyGroupsStateHandle>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- restore(Collection<S>) - Method in interface org.apache.flink.runtime.state.Snapshotable
-
Restores state that was previously snapshotted from the provided parameters.
- 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.
- restoreSavepoint() - Method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
-
Returns whether to restore from savepoint.
- 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
-
- 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
-
- ResultPartitionProvider - Interface in org.apache.flink.runtime.io.network.partition
-
- ResultPartitionType - Enum in org.apache.flink.runtime.io.network.partition
-
- ResultPartitionWriter - Class in org.apache.flink.runtime.io.network.api.writer
-
A buffer-oriented runtime result writer.
- ResultPartitionWriter(ResultPartition) - Constructor for class org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
- ResultSubpartition - Class in org.apache.flink.runtime.io.network.partition
-
- ResultSubpartition(int, ResultPartition) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
- ResultSubpartitionView - Interface in org.apache.flink.runtime.io.network.partition
-
- retain() - Method in class org.apache.flink.runtime.io.network.buffer.Buffer
-
- retainAll(Collection<?>) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- RetrievableStateHandle<T extends Serializable> - Interface in org.apache.flink.runtime.state
-
- 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
-
- retrieveClassLoader(JobID, ActorGateway, Configuration) - 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.
- 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
-
- 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(Callable<Future<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.
- returnAllocatedSlot(Slot) - Method in class org.apache.flink.runtime.instance.Instance
-
Returns a slot that has been allocated from this instance.
- returnAllocatedSlot(Slot) - Method in interface org.apache.flink.runtime.jobmanager.slots.SlotOwner
-
- 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
-
- 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
-
- 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
-
- 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.
- 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
-
- 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 IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.writer
-
- 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
-
- RoundRobinOperatorStateRepartitioner() - Constructor for class org.apache.flink.runtime.checkpoint.RoundRobinOperatorStateRepartitioner
-
- run() - Method in class org.apache.flink.runtime.blob.BlobServer
-
- run() - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
-
Cleans up blobs which are not referenced anymore
- 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 it code
- run() - Method in class org.apache.flink.runtime.util.JvmShutdownSafeguard
-
- run() - Method in class org.apache.flink.runtime.util.ProcessShutDownThread
-
- 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
-
- runSecured(Callable<T>) - Method in interface org.apache.flink.runtime.security.SecurityContext
-
- 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
-
- RuntimeEnvironment(JobID, JobVertexID, ExecutionAttemptID, ExecutionConfig, TaskInfo, Configuration, Configuration, ClassLoader, MemoryManager, IOManager, BroadcastVariableManager, AccumulatorRegistry, TaskKvStateRegistry, InputSplitProvider, Map<String, Future<Path>>, ResultPartitionWriter[], InputGate[], 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.
- Savepoint - Interface in org.apache.flink.runtime.checkpoint.savepoint
-
Savepoints are manually-triggered snapshots from which a program can be
resumed on submission.
- SavepointLoader - Class in org.apache.flink.runtime.checkpoint.savepoint
-
The SavepointLoader is a utility to load and verify a Savepoint, and to create a checkpoint from it.
- SavepointRestoreSettings - Class in org.apache.flink.runtime.jobgraph
-
Savepoint restore settings.
- SavepointSerializer<T extends Savepoint> - Interface in org.apache.flink.runtime.checkpoint.savepoint
-
- SavepointSerializers - Class in org.apache.flink.runtime.checkpoint.savepoint
-
- SavepointSerializers() - Constructor for class org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializers
-
- SavepointStore - Class in org.apache.flink.runtime.checkpoint.savepoint
-
A file system based savepoint store.
- SavepointStore() - Constructor for class org.apache.flink.runtime.checkpoint.savepoint.SavepointStore
-
- SavepointV0 - Class in org.apache.flink.migration.runtime.checkpoint.savepoint
-
Savepoint version 0.
- SavepointV0(long, Collection<TaskState>) - Constructor for class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0
-
- SavepointV0Serializer - Class in org.apache.flink.migration.runtime.checkpoint.savepoint
- 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
-
- scalaFuture - Variable in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
-
- scheduleAll(SlotProvider, boolean) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- ScheduledUnit - Class in org.apache.flink.runtime.jobmanager.scheduler
-
- ScheduledUnit(Execution) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- ScheduledUnit(Execution, SlotSharingGroup) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- ScheduledUnit(Execution, SlotSharingGroup, CoLocationConstraint) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- scheduleForExecution(SlotProvider, boolean) - 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(SlotProvider) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- scheduleForExecution(SlotProvider, boolean) - Method in class org.apache.flink.runtime.executiongraph.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.
- 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(ExecutionContext) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
-
Creates a new scheduler.
- 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_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.
- ScopeFormats() - Constructor for class org.apache.flink.runtime.metrics.scope.ScopeFormats
-
Creates all default scope formats.
- ScopeFormats(String, String, String, String, String, String) - Constructor for class org.apache.flink.runtime.metrics.scope.ScopeFormats
-
Creates all scope formats, based on the given scope format strings.
- ScopeFormats(JobManagerScopeFormat, JobManagerJobScopeFormat, TaskManagerScopeFormat, TaskManagerJobScopeFormat, TaskScopeFormat, OperatorScopeFormat) - Constructor for class org.apache.flink.runtime.metrics.scope.ScopeFormats
-
Creates a ScopeFormats
with the given 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
-
- SecurityContext - Interface in org.apache.flink.runtime.security
-
A security context with may be required to run a Callable.
- 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.
- SecurityModule.SecurityInstallException(String) - Constructor for exception org.apache.flink.runtime.security.modules.SecurityModule.SecurityInstallException
-
- SecurityModule.SecurityInstallException(String, Throwable) - Constructor for exception org.apache.flink.runtime.security.modules.SecurityModule.SecurityInstallException
-
- SecurityUtils - Class in org.apache.flink.runtime.security
-
- SecurityUtils.SecurityConfiguration - Class in org.apache.flink.runtime.security
-
The global security configuration.
- SecurityUtils.SecurityConfiguration(Configuration) - Constructor for class org.apache.flink.runtime.security.SecurityUtils.SecurityConfiguration
-
Create a security configuration from the global configuration.
- SecurityUtils.SecurityConfiguration(Configuration, Configuration) - Constructor for class org.apache.flink.runtime.security.SecurityUtils.SecurityConfiguration
-
Create a security configuration from the global configuration.
- SecurityUtils.SecurityConfiguration(Configuration, Configuration, List<? extends Class<? extends SecurityModule>>) - Constructor for class org.apache.flink.runtime.security.SecurityUtils.SecurityConfiguration
-
Create a security configuration from the global configuration.
- seek(long) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
-
- seek(long) - Method in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
-
- SeekableFileChannelInputView - Class in org.apache.flink.runtime.io.disk
-
- 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.
- 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
-
- SEND_RECEIVE_BUFFER_SIZE - Static variable in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- sendEndOfSuperstep() - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
- sendInfoMessage(String) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
-
- sendReadRequest(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
Sends a new read requests, if further requests remain.
- sendScheduleOrUpdateConsumersMessage() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- 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
-
- SerializableObject - Class in org.apache.flink.runtime.util
-
A simple object that only implements
Serializable
, so it can be used
in serializable classes.
- SerializableObject() - Constructor for class org.apache.flink.runtime.util.SerializableObject
-
- 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(Serializable, DataOutputView) - Method in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
-
Deprecated.
- serialize(SavepointV1, DataOutputStream) - Method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0Serializer
-
- serialize(T, DataOutputStream) - Method in interface org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializer
-
Serializes a savepoint to an output stream.
- 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(ArrayList<T>, DataOutputView) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- serialize(VoidNamespace, DataOutputView) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- SerializedCheckpointData - Class in org.apache.flink.runtime.state
-
This class represents serialized checkpoint data for a collection of elements.
- SerializedCheckpointData(long, byte[], int) - Constructor for class org.apache.flink.runtime.state.SerializedCheckpointData
-
Creates a SerializedCheckpointData object for the given serialized data.
- SerializedJobExecutionResult - Class in org.apache.flink.runtime.client
-
- SerializedJobExecutionResult(JobID, long, Map<String, SerializedValue<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
-
- SerializedStateHandle<T extends Serializable> - Class in org.apache.flink.migration.runtime.state.memory
-
A state handle that represents its state in serialized form as bytes.
- SerializedStateHandle(T) - Constructor for class org.apache.flink.migration.runtime.state.memory.SerializedStateHandle
-
Creates a new serialized state handle, eagerly serializing the given state object.
- SerializedStateHandle(byte[]) - Constructor for class org.apache.flink.migration.runtime.state.memory.SerializedStateHandle
-
Creates a new serialized state handle, based in the given already serialized data.
- SerializedThrowable - Exception in org.apache.flink.runtime.util
-
Utility class for dealing with user-defined Throwable types that are serialized (for
example during RPC/Actor communication), but cannot be resolved with the default
class loader.
- SerializedThrowable(Throwable) - Constructor for exception org.apache.flink.runtime.util.SerializedThrowable
-
Create a new SerializedThrowable.
- SerializedUpdateBuffer - Class in org.apache.flink.runtime.iterative.io
-
- 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
-
- serializeKeyAndNamespace(K, TypeSerializer<K>, N, TypeSerializer<N>) - Static method in class org.apache.flink.runtime.query.netty.message.KvStateRequestSerializer
-
Serializes the key and namespace into a
ByteBuffer
.
- serializeKvStateRequest(ByteBufAllocator, long, KvStateID, byte[]) - Static method in class org.apache.flink.runtime.query.netty.message.KvStateRequestSerializer
-
Allocates a buffer and serializes the KvState request into it.
- serializeKvStateRequestFailure(ByteBufAllocator, long, Throwable) - Static method in class org.apache.flink.runtime.query.netty.message.KvStateRequestSerializer
-
Allocates a buffer and serializes the KvState request failure into it.
- serializeKvStateRequestResult(ByteBufAllocator, long, byte[]) - Static method in class org.apache.flink.runtime.query.netty.message.KvStateRequestSerializer
-
Allocates a buffer and serializes the KvState request result into it.
- serializeOld(SavepointV0, DataOutputStream) - Method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0Serializer
-
- 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
-
- serializer1 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- serializer2 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- serializeServerFailure(ByteBufAllocator, Throwable) - Static method in class org.apache.flink.runtime.query.netty.message.KvStateRequestSerializer
-
Allocates a buffer and serializes the server failure into it.
- serializeValue(T, TypeSerializer<T>) - Static method in class org.apache.flink.runtime.query.netty.message.KvStateRequestSerializer
-
Serializes the value with the given serializer.
- 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, Map<N, Map<K, ST>>) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- 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.CheckpointMetaData
-
- setAlignmentDurationNanos(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- setAllowQueuedScheduling(boolean) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- setAsyncDurationMillis(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetaData
-
- setAsyncDurationMillis(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- setBitsLocation(MemorySegment, int) - Method in class org.apache.flink.runtime.operators.util.BloomFilter
-
- 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
-
- setBuffer(ByteBuffer) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- setBuffer(byte[], int, int) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- 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.
- setBytesBufferedInAlignment(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetaData
-
- setBytesBufferedInAlignment(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- setCachable(boolean) - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
-
- 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.
- setClientConnectTimeoutSeconds(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- setClientNumThreads(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- setConfigDir(String) - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- setConfigDir(String) - Method in class org.apache.flink.runtime.taskmanager.TaskManagerCliOptions
-
- 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.GenericFoldingState
-
- setCurrentNamespace(N) - Method in class org.apache.flink.runtime.state.GenericListState
-
- setCurrentNamespace(N) - Method in class org.apache.flink.runtime.state.GenericReducingState
-
- setCurrentNamespace(N) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
- setCurrentNamespace(N) - Method in interface org.apache.flink.runtime.state.KvState
-
Sets the current namespace, which will be used when using the state access methods.
- 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
-
- setEnvironment(Environment) - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Sets the environment of this task.
- 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
-
- setExecutedVertex(Execution) - 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.
- setExecutionConfig(ExecutionConfig) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Sets a serialized copy of the passed ExecutionConfig.
- setExtract(boolean) - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
-
- 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
-
- setFunctionState(StateHandle<Serializable>) - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskState
-
Deprecated.
- 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
-
- setInitialState(TaskStateHandles) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Sets the initial state for the execution.
- setInitialState(TaskStateHandles) - Method in interface org.apache.flink.runtime.jobgraph.tasks.StatefulTask
-
Sets the initial state of the operator, upon recovery.
- 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
-
- setJobManagerMode(String) - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- 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.
- setKvStates(HashMap<String, KvStateSnapshot<?, ?, ?, ?>>) - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskState
-
Deprecated.
- setLastOutputCollector(Collector<OT>) - Method in class org.apache.flink.runtime.operators.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(RegisteredBackendStateMetaInfo<N, ST>) - 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.
- setMode(OperatorStateHandle.Mode) - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy.StateMetaInfo
-
- 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
- setName(String) - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy.StateMetaInfo
-
- setNamespaceSerializerSerializationProxy(TypeSerializerSerializationProxy<N>) - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy.StateMetaInfo
-
- setNextBuffer(Buffer) - Method in class org.apache.flink.runtime.io.network.api.serialization.AdaptiveSpanningRecordDeserializer
-
- setNextBuffer(Buffer) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
-
- setNextBuffer(Buffer) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
-
- setNextBuffer(Buffer) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
-
- setNextBuffer(Buffer) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
-
- setNextMemorySegment(MemorySegment, int) - Method in class org.apache.flink.runtime.io.network.api.serialization.AdaptiveSpanningRecordDeserializer
-
- setNextMemorySegment(MemorySegment, int) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
-
- setNextMemorySegment(MemorySegment, int) - 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.
- 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
-
- setOperatorState(StateHandle<?>) - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskState
-
Deprecated.
- 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
-
- setReadPosition(long) - Method in class org.apache.flink.runtime.io.disk.RandomAccessInputView
-
- setReadPosition(long) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- 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
-
- 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
-
- setSavepointRestoreSettings(SavepointRestoreSettings) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Sets the savepoint restore settings.
- setScheduleLocalOnly(boolean) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- setScheduleMode(ScheduleMode) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- setScheduleMode(ScheduleMode) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- setSendAndReceiveBufferSize(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- setServerConnectBacklog(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- setServerNumThreads(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- 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 class org.apache.flink.runtime.io.network.buffer.Buffer
-
- setSlotAvailabilityListener(SlotAvailabilityListener) - Method in class org.apache.flink.runtime.instance.Instance
-
Sets the listener that receives notifications for slot availability.
- setSlotSharingGroup(SlotSharingGroup) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Associates this vertex with a slot sharing group for scheduling.
- setSnapshotSettings(JobSnapshottingSettings) - 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
-
- 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
- setStateName(String) - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy.StateMetaInfo
-
- setStateSerializer(TypeSerializer<S>) - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy.StateMetaInfo
-
- setStateSerializerSerializationProxy(TypeSerializerSerializationProxy<S>) - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy.StateMetaInfo
-
- setStateType(StateDescriptor.Type) - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy.StateMetaInfo
-
- 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.CheckpointMetaData
-
- setSyncDurationMillis(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- setTaskName(String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setTransportType(String) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- 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
-
- 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(JobID, 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(JobID, 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(AllocatedSlot, 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.
- SharedSlot(SharedSlot, SlotOwner, int, SlotSharingGroupAssignment, AbstractID) - Constructor for class org.apache.flink.runtime.instance.SharedSlot
-
Creates a new shared slot that is a sub-slot of the given parent shared slot, and that belongs
to the given task group.
- 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.
- shouldIncludeFinished() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
-
- shouldIncludeRunning() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
-
- shutdown() - Method in class org.apache.flink.runtime.blob.BlobCache
-
- shutdown() - Method in class org.apache.flink.runtime.blob.BlobServer
-
Shuts down the BLOB server.
- shutdown() - Method in interface org.apache.flink.runtime.blob.BlobService
-
Shutdown method which is called to terminate the blob service.
- 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
-
- 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 class org.apache.flink.runtime.execution.librarycache.FallbackLibraryCacheManager
-
- shutdown() - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
-
Shutdown method
- 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.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.memory.MemoryManager
-
Shuts the memory manager down, trying to release all the memory it managed.
- shutdown() - Method in class org.apache.flink.runtime.metrics.MetricRegistry
-
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.KvStateLocationLookupService
-
Shuts down the lookup service.
- shutDown() - Method in class org.apache.flink.runtime.query.netty.KvStateClient
-
Shuts down the client and closes all connections.
- shutDown() - Method in class org.apache.flink.runtime.query.netty.KvStateServer
-
Shuts down the server and all related thread pools.
- shutDown() - Method in class org.apache.flink.runtime.query.QueryableStateClient
-
Shuts down the client and all components.
- shutdown() - Method in class org.apache.flink.runtime.taskmanager.MemoryLogger
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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(JobID, 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(JobID, 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(AllocatedSlot, 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..
- 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, int, int, TaskActions, TaskIOMetricGroup) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- 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.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.util.EvictingBoundedList
-
- size() - Method in class org.apache.flink.runtime.util.IntArrayList
-
- size() - Method in class org.apache.flink.runtime.util.LongArrayList
-
- size() - Method in class org.apache.flink.runtime.util.LRUCache
-
- size() - Method in class org.apache.flink.runtime.util.LRUCacheMap
-
- skip(long) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
-
- skip(long) - Method in class org.apache.flink.runtime.state.BoundedInputStream
-
- skip(long) - Method in class org.apache.flink.runtime.util.NonClosingStreamDecorator
-
- skipBytes(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- skipBytes(int) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- skipBytesToRead(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- skipBytesToRead(int) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
-
- skipBytesToWrite(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
- skipBytesToWrite(int) - Method in class org.apache.flink.runtime.util.DataOutputSerializer
-
- 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(JobID, SlotOwner, TaskManagerLocation, int, TaskManagerGateway, SharedSlot, AbstractID) - Constructor for class org.apache.flink.runtime.instance.Slot
-
Base constructor for slots.
- Slot(AllocatedSlot, SlotOwner, int, SharedSlot, AbstractID) - Constructor for class org.apache.flink.runtime.instance.Slot
-
Base constructor for slots.
- SlotAvailabilityListener - Interface in org.apache.flink.runtime.jobmanager.scheduler
-
A SlotAvailabilityListener can be notified when new
Slot
s become available on an
Instance
.
- SlotOwner - Interface in org.apache.flink.runtime.jobmanager.slots
-
Interface for components that hold slots and to which slots get released / recycled.
- SlotProvider - Interface in org.apache.flink.runtime.instance
-
The slot provider is responsible for preparing slots for ready-to-run tasks.
- 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
-
- snapshot(long, long, CheckpointStreamFactory) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- snapshot(long, long, CheckpointStreamFactory) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- snapshot(long, long, CheckpointStreamFactory) - Method in interface org.apache.flink.runtime.state.Snapshotable
-
- Snapshotable<S extends StateObject> - Interface in org.apache.flink.runtime.state
-
Interface for operations that can perform snapshots of their state.
- 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
-
- 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.
- 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 IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.serialization
-
- 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 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
-
- 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.
- 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
-
- SSLStoreOverlay.Builder() - Constructor for class org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay.Builder
-
- 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
-
- 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
-
- 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
-
- StandaloneLeaderElectionService - Class in org.apache.flink.runtime.leaderelection
-
- StandaloneLeaderElectionService() - Constructor for class org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
-
- StandaloneLeaderRetrievalService - Class in org.apache.flink.runtime.leaderretrieval
-
- StandaloneLeaderRetrievalService(String) - Constructor for class org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
-
Creates a StandaloneLeaderRetrievalService with the given JobManager address.
- 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
-
- StandaloneSubmittedJobGraphStore - Class in org.apache.flink.runtime.jobmanager
-
- 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
-
- start() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
-
- start() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
-
- start() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
-
- start() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
-
- start() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
-
- start(ResultPartitionProvider, TaskEventDispatcher, NetworkBufferPool) - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
-
- start(ResultPartitionProvider, TaskEventDispatcher, NetworkBufferPool) - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
-
- start(ResultPartitionProvider, TaskEventDispatcher, NetworkBufferPool) - 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
-
- start(SubmittedJobGraphStore.SubmittedJobGraphListener) - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
-
- 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.StandaloneLeaderRetrievalService
-
- start(LeaderRetrievalListener) - Method in class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
-
- start() - Method in interface org.apache.flink.runtime.query.KvStateLocationLookupService
-
Starts the lookup service.
- start() - Method in class org.apache.flink.runtime.query.netty.KvStateServer
-
Starts the server by binding to the configured bind address (blocking).
- start(String) - 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
-
- startCuratorFramework(Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Starts a CuratorFramework
instance and connects it to the given ZooKeeper
quorum.
- startJobClientActorSystem(Configuration) - 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.
- 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.MetricRegistry
-
Initializes the MetricQueryService.
- startReading() - Method in class org.apache.flink.runtime.operators.TempBarrier
-
- 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.
- 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.
- startWebMonitorIfConfigured(Configuration, ActorSystem, ActorRef, Logger) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Starts the web frontend.
- startWebRuntimeMonitor(Configuration, LeaderRetrievalService, ActorSystem) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
-
Starts the web runtime monitor.
- StateAssignmentOperation - Class in org.apache.flink.runtime.checkpoint
-
This class encapsulates the operation of assigning restored state when restoring from a checkpoint.
- StateAssignmentOperation(Logger, Map<JobVertexID, ExecutionJobVertex>, Map<JobVertexID, TaskState>, boolean) - Constructor for class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
-
- StateBackendFactory<T extends AbstractStateBackend> - Interface in org.apache.flink.runtime.state
-
A factory to create a specific state backend.
- stateDesc - Variable in class org.apache.flink.migration.runtime.state.filesystem.AbstractFsStateSnapshot
-
Deprecated.
StateDescriptor, for sanity checks
- stateDesc - Variable in class org.apache.flink.migration.runtime.state.memory.AbstractMemStateSnapshot
-
Deprecated.
StateDescriptor, for sanity checks
- stateDesc - Variable in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
This holds the name of the state and can create an initial default value for the state.
- StatefulTask - Interface in org.apache.flink.runtime.jobgraph.tasks
-
This interface must be implemented by any invokable that has recoverable state and participates
in checkpointing.
- StateHandle<T> - Interface in org.apache.flink.migration.runtime.state
-
Deprecated.
- StateHandle<T> - Interface in org.apache.flink.runtime.state
-
StateHandle is a general handle interface meant to abstract operator state fetching.
- 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
-
- StateInitializationContextImpl(boolean, OperatorStateStore, KeyedStateStore, Collection<KeyGroupsStateHandle>, Collection<OperatorStateHandle>, CloseableRegistry) - 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
- StateObject - Interface in org.apache.flink.migration.runtime.state
-
Deprecated.
- StateObject - Interface in org.apache.flink.runtime.state
-
Base of all types that represent checkpointed state.
- 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
-
- stateSerializer - Variable in class org.apache.flink.migration.runtime.state.filesystem.AbstractFsStateSnapshot
-
Deprecated.
Serializer for the state value
- stateSerializer - Variable in class org.apache.flink.migration.runtime.state.memory.AbstractMemStateSnapshot
-
Deprecated.
Serializer for the state value
- 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,ST> - Class in org.apache.flink.runtime.state.heap
-
- StateTable(RegisteredBackendStateMetaInfo<N, ST>, KeyGroupRange) - Constructor for class org.apache.flink.runtime.state.heap.StateTable
-
- StateUtil - Class in org.apache.flink.runtime.state
-
- 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
-
- StatusOverview - Class in org.apache.flink.runtime.messages.webmonitor
-
- StatusOverview(int, int, int, int, int, int, int) - Constructor for class org.apache.flink.runtime.messages.webmonitor.StatusOverview
-
- StatusOverview(int, int, int, JobsOverview, JobsOverview) - Constructor for class org.apache.flink.runtime.messages.webmonitor.StatusOverview
-
- stddev - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
-
- stdOutFile - Variable in class org.apache.flink.runtime.webmonitor.WebMonitorUtils.LogFileLocation
-
- stop() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
-
- stop() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
-
- stop() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
-
- 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 class org.apache.flink.runtime.io.async.AbstractAsyncIOCallable
-
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
-
- stop() - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
-
- 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.StandaloneLeaderRetrievalService
-
- stop() - Method in class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
-
- 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.
- 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
-
- 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.
- 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
-
- 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.
- 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.
- storeSavepoint(String, T) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointStore
-
Stores the savepoint.
- StreamStateHandle - Interface in org.apache.flink.migration.runtime.state
-
Deprecated.
- StreamStateHandle - Interface in org.apache.flink.runtime.state
-
A
StateObject
that represents state that was written to a stream.
- StreamTaskState - Class in org.apache.flink.migration.streaming.runtime.tasks
-
Deprecated.
- StreamTaskState() - Constructor for class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskState
-
Deprecated.
- StreamTaskStateList - Class in org.apache.flink.migration.streaming.runtime.tasks
-
Deprecated.
- StreamTaskStateList(StreamTaskState[]) - Constructor for class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskStateList
-
Deprecated.
- 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, 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(ActorSystem, Configuration, LeaderRetrievalService, 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.
- submitJobAndWait(ActorSystem, Configuration, LeaderRetrievalService, 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(ActorGateway, Configuration, JobGraph, FiniteDuration, 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.
- SubmittedJobGraph - Class in org.apache.flink.runtime.jobmanager
-
- SubmittedJobGraph(JobGraph, JobInfo) - Constructor for class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
-
- SubmittedJobGraphStore - Interface in org.apache.flink.runtime.jobmanager
-
- SubmittedJobGraphStore.SubmittedJobGraphListener - Interface in org.apache.flink.runtime.jobmanager
-
- subscribe(EventListener<TaskEvent>, Class<? extends TaskEvent>) - Method in class org.apache.flink.runtime.io.network.api.TaskEventHandler
-
- subscribeToEvent(EventListener<TaskEvent>, Class<? extends TaskEvent>) - Method in class org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
- 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 of a new config key to the value of a deprecated config key.
- subsume() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- 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
-
- SubtaskState - Class in org.apache.flink.migration.runtime.checkpoint
-
Deprecated.
- SubtaskState(SerializedValue<StateHandle<?>>, long, long) - Constructor for class org.apache.flink.migration.runtime.checkpoint.SubtaskState
-
Deprecated.
- SubtaskState - Class in org.apache.flink.runtime.checkpoint
-
Container for the chained state of one parallel subtask of an operator/task.
- SubtaskState(ChainedStateHandle<StreamStateHandle>, ChainedStateHandle<OperatorStateHandle>, ChainedStateHandle<OperatorStateHandle>, KeyGroupsStateHandle, KeyGroupsStateHandle) - 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.
- 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
-
- SuperstepKickoffLatch() - Constructor for class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
-
- SuperstepKickoffLatchBroker - Class in org.apache.flink.runtime.iterative.concurrent
-
- supplyAsync(Callable<T>, Executor) - Static method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
-
Creates a future whose value is determined by the asynchronously executed callable.
- 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.
- swap(int, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- swap(int, int) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
-
Swap items at the given addresses.
- swap(int, int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- switchBuffers() - Method in class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
-
- sync() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataOutputStream
-
- 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
-
- 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
-
- 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
-