- cachable - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
-
- cachable - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
-
- calculateCutoffMB(Configuration, long) - Static method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
-
Calcuate cutoff memory size used by container, it will throw an
IllegalArgumentException
if the config is invalid or return the cutoff value if valid.
- calculateHeapSizeMB(long, Configuration) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
Calculates the amount of heap memory to use (to set via -Xmx and -Xms)
based on the total memory to use and the given configuration parameters.
- calculateNetworkBufferMemory(long, Configuration) - Static method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
-
Calculates the amount of memory used for network buffers based on the total memory to use and
the according configuration parameters.
- calculateNewNetworkBufferMemory(Configuration, long) - Static method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
-
Calculates the amount of memory used for network buffers inside the current JVM instance
based on the available heap or the max heap size and the according configuration parameters.
- calculatePreferredLocations(LocationPreferenceConstraint) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Calculates the preferred locations based on the location preference constraint.
- calculateTotalBuffers(SingleInputGate) - Method in class org.apache.flink.runtime.io.network.metrics.AbstractBuffersUsageGauge
-
- calculateTotalBuffers(SingleInputGate) - Method in class org.apache.flink.runtime.io.network.metrics.CreditBasedInputBuffersUsageGauge
-
- calculateTotalBuffers(SingleInputGate) - Method in class org.apache.flink.runtime.io.network.metrics.ExclusiveBuffersUsageGauge
-
- calculateTotalBuffers(SingleInputGate) - Method in class org.apache.flink.runtime.io.network.metrics.FloatingBuffersUsageGauge
-
- calculateTotalBuffers(SingleInputGate) - Method in class org.apache.flink.runtime.io.network.metrics.InputBufferPoolUsageGauge
-
- calculateUsedBuffers(SingleInputGate) - Method in class org.apache.flink.runtime.io.network.metrics.AbstractBuffersUsageGauge
-
- calculateUsedBuffers(SingleInputGate) - Method in class org.apache.flink.runtime.io.network.metrics.CreditBasedInputBuffersUsageGauge
-
- calculateUsedBuffers(SingleInputGate) - Method in class org.apache.flink.runtime.io.network.metrics.ExclusiveBuffersUsageGauge
-
- calculateUsedBuffers(SingleInputGate) - Method in class org.apache.flink.runtime.io.network.metrics.FloatingBuffersUsageGauge
-
- calculateUsedBuffers(SingleInputGate) - Method in class org.apache.flink.runtime.io.network.metrics.InputBufferPoolUsageGauge
-
- call() - Method in class org.apache.flink.runtime.state.AsyncSnapshotCallable
-
- callAsync(Callable<V>, Time) - Method in interface org.apache.flink.runtime.rpc.MainThreadExecutable
-
Execute the callable in the main thread of the underlying RPC endpoint and return a future for
the callable result.
- CallAsync - Class in org.apache.flink.runtime.rpc.messages
-
Message for asynchronous callable invocations
- CallAsync(Callable<?>) - Constructor for class org.apache.flink.runtime.rpc.messages.CallAsync
-
- callAsync(Callable<V>, Time) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Execute the callable in the main thread of the underlying RPC service, returning a future for
the result of the callable.
- callAsyncWithoutFencing(Callable<V>, Time) - Method in class org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
-
- callAsyncWithoutFencing(Callable<V>, Time) - Method in interface org.apache.flink.runtime.rpc.FencedMainThreadExecutable
-
Run the given callable in the main thread without attaching a fencing token.
- callAsyncWithoutFencing(Callable<V>, Time) - Method in class org.apache.flink.runtime.rpc.FencedRpcEndpoint
-
Run the given callable in the main thread of the RpcEndpoint without checking the fencing
token.
- callInternal() - Method in class org.apache.flink.runtime.state.AsyncSnapshotCallable
-
This method implements the (async) snapshot logic.
- 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.
- canBeReleased() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- canBeReleased() - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Checks whether the task executor can be released.
- canBeSubsumed() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
Checks whether this checkpoint can be subsumed or whether it should always continue, regardless
of newer checkpoints in progress.
- cancel(boolean) - Method in class org.apache.flink.runtime.concurrent.ScheduledFutureAdapter
-
- cancel() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- cancel() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- cancel() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
Cancels all currently running vertex executions.
- cancel() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
Cancels this ExecutionVertex.
- cancel() - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatMonitor
-
Cancel this monitor.
- cancel() - Method in class org.apache.flink.runtime.heartbeat.HeartbeatMonitorImpl
-
- cancel() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- cancel() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
This method is called when a task is canceled either as a result of a user abort or an execution failure.
- cancel(Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- cancel(Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Cancels the currently executed job.
- cancel() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- cancel() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.CrossDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.DataSinkTask
-
- cancel() - Method in class org.apache.flink.runtime.operators.DataSourceTask
-
- cancel() - Method in interface org.apache.flink.runtime.operators.Driver
-
This method is invoked when the driver must aborted in mid processing.
- cancel() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.JoinDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.MapDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.NoOpDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.ReduceDriver
-
- cancel() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
-
- cancel() - Method in class org.apache.flink.runtime.registration.RetryingRegistration
-
Cancels the registration procedure.
- cancel(ExecutionVertexID) - Method in class org.apache.flink.runtime.scheduler.DefaultExecutionSlotAllocator
-
- cancel(ExecutionVertexID) - Method in interface org.apache.flink.runtime.scheduler.ExecutionSlotAllocator
-
Cancel an ongoing slot request.
- cancel() - Method in class org.apache.flink.runtime.scheduler.LegacyScheduler
-
- cancel() - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
-
- cancel(boolean) - Method in class org.apache.flink.runtime.state.AsyncSnapshotCallable.AsyncSnapshotTask
-
- cancel() - Method in class org.apache.flink.runtime.state.AsyncSnapshotCallable
-
- 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
-
- cancelCleanupTask() - Method in class org.apache.flink.runtime.blob.AbstractBlobCache
-
Cancels any cleanup task that subclasses may be executing.
- cancelCleanupTask() - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
-
- cancelCleanupTask() - Method in class org.apache.flink.runtime.blob.TransientBlobCache
-
- cancelConsumption() - Method in interface org.apache.flink.runtime.io.network.partition.PartitionProducerStateProvider.ResponseHandle
-
Cancel the partition consumptions as a result of state check.
- cancelExecution() - Method in class org.apache.flink.runtime.taskmanager.Task
-
Cancels the task execution.
- cancelJob(JobID, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- cancelJob(JobID) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- cancelJob(JobID, Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Cancel the given job.
- cancelRequestFor(InputChannelID) - Method in interface org.apache.flink.runtime.io.network.NetworkClientHandler
-
- cancelSlotRequest(SlotRequestId, SlotSharingGroupId, Throwable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl
-
- cancelSlotRequest(SlotRequestId, SlotSharingGroupId, Throwable) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotProvider
-
- cancelSlotRequest(AllocationID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- cancelSlotRequest(AllocationID) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Cancel the slot allocation requests from the resource manager.
- cancelStackTraceSample(int, Throwable) - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator
-
Cancels a pending sample.
- cancelStreamRegistry - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
Registry for all opened streams, so they can be closed if the task using this backend is closed.
- cancelStreamRegistry - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
-
- cancelStreamRegistry - Variable in class org.apache.flink.runtime.state.DefaultOperatorStateBackendBuilder
-
- cancelTask(ExecutionAttemptID, Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Cancel the given task.
- cancelTask(ExecutionAttemptID, Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
-
- cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
-
- cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
-
- cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
-
- cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
-
- cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
-
- cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
-
- cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
-
- cancelTask() - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
-
- cancelTask(ExecutionAttemptID, Time) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- cancelTask(ExecutionAttemptID, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Cancel the given task.
- CancelTaskException - Exception in org.apache.flink.runtime.execution
-
Thrown to trigger a canceling of the executing task.
- CancelTaskException(Throwable) - Constructor for exception org.apache.flink.runtime.execution.CancelTaskException
-
- CancelTaskException(String) - Constructor for exception org.apache.flink.runtime.execution.CancelTaskException
-
- CancelTaskException() - Constructor for exception org.apache.flink.runtime.execution.CancelTaskException
-
- cancelTasks(Set<ExecutionVertexID>) - Method in class org.apache.flink.runtime.executiongraph.failover.AdaptedRestartPipelinedRegionStrategyNG
-
- cancelWithFuture() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
Cancels all currently running vertex executions.
- canEqual(Object) - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-
- canRestart() - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.FailureHandlingResult
-
Returns whether the restarting can be conducted.
- canRestart() - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.FailureRateRestartBackoffTimeStrategy
-
- canRestart() - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.FixedDelayRestartBackoffTimeStrategy
-
- canRestart() - Method in interface org.apache.flink.runtime.executiongraph.failover.flip1.RestartBackoffTimeStrategy
-
Returns whether a restart should be conducted.
- 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
.
- canRestart() - Method in class org.apache.flink.runtime.executiongraph.restart.ThrowingRestartStrategy
-
- capacity() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- capacity(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- CaseInsensitiveOrderComparator() - Constructor for class org.apache.flink.runtime.rest.RestServerEndpoint.RestHandlerUrlComparator.CaseInsensitiveOrderComparator
-
- ChainedAllReduceDriver<IT> - Class in org.apache.flink.runtime.operators.chaining
-
- ChainedAllReduceDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
-
- ChainedDriver<IT,OT> - Class in org.apache.flink.runtime.operators.chaining
-
The interface to be implemented by drivers that do not run in an own task context, but are chained to other
tasks.
- ChainedDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- ChainedFlatMapDriver<IT,OT> - Class in org.apache.flink.runtime.operators.chaining
-
- ChainedFlatMapDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
-
- ChainedMapDriver<IT,OT> - Class in org.apache.flink.runtime.operators.chaining
-
- ChainedMapDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
-
- ChainedReduceCombineDriver<T> - Class in org.apache.flink.runtime.operators.chaining
-
Chained version of ReduceCombineDriver.
- ChainedReduceCombineDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
-
- ChainedStateHandle<T extends StateObject> - Class in org.apache.flink.runtime.state
-
Handle to state handles for the operators in an operator chain.
- ChainedStateHandle(List<? extends T>) - Constructor for class org.apache.flink.runtime.state.ChainedStateHandle
-
Wraps a list to the state handles for the operators in a chain.
- chainedTasks - Variable in class org.apache.flink.runtime.operators.BatchTask
-
A list of chained drivers, if there are any.
- ChainedTerminationCriterionDriver<IT,OT> - Class in org.apache.flink.runtime.operators.chaining
-
- ChainedTerminationCriterionDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
-
- channelIndex - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
- channelRead0(ChannelHandlerContext, HttpObject) - Method in class org.apache.flink.runtime.rest.FileUploadHandler
-
- channelRead0(ChannelHandlerContext, RoutedRequest) - Method in class org.apache.flink.runtime.rest.handler.LeaderRetrievalHandler
-
- channelRead0(ChannelHandlerContext, RoutedRequest) - Method in class org.apache.flink.runtime.rest.handler.legacy.ConstantTextHandler
-
- channelRead0(ChannelHandlerContext, HttpRequest) - Method in class org.apache.flink.runtime.rest.handler.PipelineErrorHandler
-
- channelRead0(ChannelHandlerContext, HttpRequest) - Method in class org.apache.flink.runtime.rest.handler.router.RouterHandler
-
- ChannelReaderInputView - Class in org.apache.flink.runtime.io.disk.iomanager
-
A
DataInputView
that is backed by a
BlockChannelReader
, making it effectively a data input
stream.
- ChannelReaderInputView(BlockChannelReader<MemorySegment>, List<MemorySegment>, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
Creates a new channel reader that reads from the given channel until the last block
(as marked by a
ChannelWriterOutputView
) is found.
- ChannelReaderInputView(BlockChannelReader<MemorySegment>, List<MemorySegment>, int, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
Creates a new channel reader that reads from the given channel, expecting a specified
number of blocks in the channel.
- ChannelReaderInputViewIterator<E> - Class in org.apache.flink.runtime.io.disk
-
A simple iterator over the input read though an I/O channel.
- ChannelReaderInputViewIterator(IOManager, FileIOChannel.ID, List<MemorySegment>, List<MemorySegment>, TypeSerializer<E>, int) - Constructor for class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
-
- ChannelReaderInputViewIterator(IOManager, FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>, List<MemorySegment>, List<MemorySegment>, TypeSerializer<E>, int) - Constructor for class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
-
- ChannelReaderInputViewIterator(BlockChannelReader<MemorySegment>, LinkedBlockingQueue<MemorySegment>, List<MemorySegment>, List<MemorySegment>, TypeSerializer<E>, int) - Constructor for class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
-
- ChannelReaderInputViewIterator(AbstractChannelReaderInputView, List<MemorySegment>, TypeSerializer<E>) - Constructor for class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
-
- ChannelSelector<T extends org.apache.flink.core.io.IOReadableWritable> - Interface in org.apache.flink.runtime.io.network.api.writer
-
The
ChannelSelector
determines to which logical channels a record
should be written to.
- ChannelWithBlockCount(FileIOChannel.ID, int) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ChannelWithBlockCount
-
- ChannelWriterOutputView - Class in org.apache.flink.runtime.io.disk.iomanager
-
A
DataOutputView
that is backed by a
BlockChannelWriter
, making it effectively a data output
stream.
- ChannelWriterOutputView(BlockChannelWriter<MemorySegment>, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
Creates an new ChannelWriterOutputView that writes to the given channel and buffers data
in the given memory segments.
- ChannelWriterOutputView(BlockChannelWriter<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
Creates an new ChannelWriterOutputView that writes to the given channel.
- check(SchedulingExecutionVertex) - Method in class org.apache.flink.runtime.scheduler.strategy.InputDependencyConstraintChecker
-
- checkBatchSlotTimeout() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
-
- checkConfigParameter(boolean, Object, String, String) - Static method in class org.apache.flink.runtime.util.ConfigurationParserUtils
-
Validates a condition for a config parameter and displays a standard exception, if the
the condition does not hold.
- 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.
- checkFailureCounter(CheckpointException, long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointFailureManager
-
- checkIdleSlot() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
-
Check the available slots, release the slot that is idle for a long time.
- checkNotShutdown() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
-
- checkParallelismPreconditions(List<OperatorState>, ExecutionJobVertex) - Method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
-
- checkParallelismPreconditions(int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
-
- CHECKPOINT_DIR_PREFIX - Static variable in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
-
The prefix of the directory containing the data exclusive to a checkpoint.
- CHECKPOINT_SHARED_STATE_DIR - Static variable in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
-
The name of the directory for shared checkpoint state.
- CHECKPOINT_TASK_OWNED_STATE_DIR - Static variable in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
-
The name of the directory for state not owned/released by the master, but by the TaskManagers.
- CheckpointAlignment(long, long) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
-
- CheckpointAlignment(MinMaxAvgStatistics, MinMaxAvgStatistics) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
-
- CheckpointBarrier - Class in org.apache.flink.runtime.io.network.api
-
Checkpoint barriers are used to align checkpoints throughout the streaming topology.
- CheckpointBarrier(long, long, CheckpointOptions) - Constructor for class org.apache.flink.runtime.io.network.api.CheckpointBarrier
-
- CheckpointConfigHandler - Class in org.apache.flink.runtime.rest.handler.job.checkpoints
-
Handler which serves the checkpoint configuration.
- CheckpointConfigHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, CheckpointConfigInfo, JobMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointConfigHandler
-
- CheckpointConfigHeaders - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
- CheckpointConfigInfo - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
- CheckpointConfigInfo(CheckpointConfigInfo.ProcessingMode, long, long, long, int, CheckpointConfigInfo.ExternalizedCheckpointInfo) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo
-
- CheckpointConfigInfo.ExternalizedCheckpointInfo - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Contains information about the externalized checkpoint configuration.
- CheckpointConfigInfo.ProcessingMode - Enum in org.apache.flink.runtime.rest.messages.checkpoints
-
Processing mode.
- CheckpointConfigInfo.ProcessingModeDeserializer - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Processing mode deserializer.
- CheckpointConfigInfo.ProcessingModeSerializer - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
- CheckpointCoordinator - Class in org.apache.flink.runtime.checkpoint
-
The checkpoint coordinator coordinates the distributed snapshots of operators and state.
- CheckpointCoordinator(JobID, CheckpointCoordinatorConfiguration, ExecutionVertex[], ExecutionVertex[], ExecutionVertex[], CheckpointIDCounter, CompletedCheckpointStore, StateBackend, Executor, SharedStateRegistryFactory, CheckpointFailureManager) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- CheckpointCoordinatorConfiguration - Class in org.apache.flink.runtime.jobgraph.tasks
-
- CheckpointCoordinatorConfiguration(long, long, long, int, CheckpointRetentionPolicy, boolean, boolean, int) - Constructor for class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
-
- CheckpointCoordinatorDeActivator - Class in org.apache.flink.runtime.checkpoint
-
This actor listens to changes in the JobStatus and activates or deactivates the periodic
checkpoint scheduler.
- CheckpointCoordinatorDeActivator(CheckpointCoordinator) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointCoordinatorDeActivator
-
- CheckpointCoordinatorGateway - Interface in org.apache.flink.runtime.checkpoint
-
- CheckpointDuration(long, long) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
-
- CheckpointDuration(MinMaxAvgStatistics, MinMaxAvgStatistics) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
-
- CheckpointedStateScope - Enum in org.apache.flink.runtime.state
-
The scope for a chunk of checkpointed state.
- CheckpointException - Exception in org.apache.flink.runtime.checkpoint
-
Base class for checkpoint related exceptions.
- CheckpointException(CheckpointFailureReason) - Constructor for exception org.apache.flink.runtime.checkpoint.CheckpointException
-
- CheckpointException(String, CheckpointFailureReason) - Constructor for exception org.apache.flink.runtime.checkpoint.CheckpointException
-
- CheckpointException(CheckpointFailureReason, Throwable) - Constructor for exception org.apache.flink.runtime.checkpoint.CheckpointException
-
- CheckpointException(String, CheckpointFailureReason, Throwable) - Constructor for exception org.apache.flink.runtime.checkpoint.CheckpointException
-
- CheckpointFailureManager - Class in org.apache.flink.runtime.checkpoint
-
The checkpoint failure manager which centralized manage checkpoint failure processing logic.
- CheckpointFailureManager(int, CheckpointFailureManager.FailJobCallback) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointFailureManager
-
- CheckpointFailureManager.FailJobCallback - Interface in org.apache.flink.runtime.checkpoint
-
A callback interface about how to fail a job.
- CheckpointFailureReason - Enum in org.apache.flink.runtime.checkpoint
-
Various reasons why a checkpoint was failure.
- CheckpointIDCounter - Interface in org.apache.flink.runtime.checkpoint
-
A checkpoint ID counter.
- CheckpointIdPathParameter - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Path parameter for the checkpoint id of type
Long
.
- CheckpointIdPathParameter() - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointIdPathParameter
-
- checkpointIdPathParameter - Variable in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointMessageParameters
-
- checkpointIdToPath(long) - Static method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
-
Convert a checkpoint id into a ZooKeeper path.
- CheckpointingStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
- CheckpointingStatistics(CheckpointingStatistics.Counts, CheckpointingStatistics.Summary, CheckpointingStatistics.LatestCheckpoints, List<CheckpointStatistics>) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
-
- CheckpointingStatistics.Counts - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Checkpoint counts.
- CheckpointingStatistics.LatestCheckpoints - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Statistics about the latest checkpoints.
- CheckpointingStatistics.RestoredCheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Statistics for a restored checkpoint.
- CheckpointingStatistics.Summary - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Checkpoint summary.
- CheckpointingStatisticsHandler - Class in org.apache.flink.runtime.rest.handler.job.checkpoints
-
Handler which serves the checkpoint statistics.
- CheckpointingStatisticsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, CheckpointingStatistics, JobMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointingStatisticsHandler
-
- CheckpointingStatisticsHeaders - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
- CheckpointingStatisticsHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
-
- CheckpointListener - Interface in org.apache.flink.runtime.state
-
This interface must be implemented by functions/operations that want to receive
a commit notification once a checkpoint has been completely acknowledged by all
participants.
- CheckpointMessageParameters - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Message parameters for checkpoint related messages.
- CheckpointMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointMessageParameters
-
- CheckpointMetaData - Class in org.apache.flink.runtime.checkpoint
-
Encapsulates all the meta data for a checkpoint.
- CheckpointMetaData(long, long) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointMetaData
-
- CheckpointMetadataOutputStream - Class in org.apache.flink.runtime.state
-
An output stream for checkpoint metadata.
- CheckpointMetadataOutputStream() - Constructor for class org.apache.flink.runtime.state.CheckpointMetadataOutputStream
-
- CheckpointMetrics - Class in org.apache.flink.runtime.checkpoint
-
A collection of simple metrics, around the triggering of a checkpoint.
- CheckpointMetrics() - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- CheckpointMetrics(long, long, long, long) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- CheckpointOptions - Class in org.apache.flink.runtime.checkpoint
-
Options for performing the checkpoint.
- CheckpointOptions(CheckpointType, CheckpointStorageLocationReference) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointOptions
-
- CheckpointProperties - Class in org.apache.flink.runtime.checkpoint
-
The configuration of a checkpoint.
- CheckpointRecoveryFactory - Interface in org.apache.flink.runtime.checkpoint
-
A factory for per Job checkpoint recovery components.
- CheckpointResponder - Interface in org.apache.flink.runtime.taskmanager
-
Responder for checkpoint acknowledge and decline messages in the
Task
.
- CheckpointRetentionPolicy - Enum in org.apache.flink.runtime.checkpoint
-
Policy for whether checkpoints are retained after a job terminates.
- Checkpoints - Class in org.apache.flink.runtime.checkpoint
-
A utility class with the methods to write/load/dispose the checkpoint and savepoint metadata.
- checkpointsMatch(Collection<CompletedCheckpoint>, Collection<CompletedCheckpoint>) - Static method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- CheckpointStateOutputStream() - Constructor for class org.apache.flink.runtime.state.CheckpointStreamFactory.CheckpointStateOutputStream
-
- CheckpointStatisticDetailsHandler - Class in org.apache.flink.runtime.rest.handler.job.checkpoints
-
REST handler which returns the details for a checkpoint.
- CheckpointStatisticDetailsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, CheckpointStatistics, CheckpointMessageParameters>, ExecutionGraphCache, Executor, CheckpointStatsCache) - Constructor for class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointStatisticDetailsHandler
-
- CheckpointStatisticDetailsHeaders - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
- CheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Statistics for a checkpoint.
- CheckpointStatistics.CompletedCheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Statistics for a completed checkpoint.
- CheckpointStatistics.FailedCheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Statistics for a failed checkpoint.
- CheckpointStatistics.PendingCheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Statistics for a pending checkpoint.
- CheckpointStatsCache - Class in org.apache.flink.runtime.rest.handler.job.checkpoints
-
A size-based cache of accessed checkpoints for completed and failed
checkpoints.
- CheckpointStatsCache(int) - Constructor for class org.apache.flink.runtime.rest.handler.job.checkpoints.CheckpointStatsCache
-
- CheckpointStatsCounts - Class in org.apache.flink.runtime.checkpoint
-
Counts of checkpoints.
- 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>, CheckpointCoordinatorConfiguration, MetricGroup) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
-
Creates a new checkpoint stats tracker.
- CheckpointStorage - Interface in org.apache.flink.runtime.state
-
Implementations of this interface should implement methods acting as an administration role for checkpoint storage,
which defined in
CheckpointStorageCoordinatorView
.
- CheckpointStorageCoordinatorView - Interface in org.apache.flink.runtime.state
-
- CheckpointStorageLocation - Interface in org.apache.flink.runtime.state
-
A storage location for one particular checkpoint, offering data persistent, metadata persistence,
and lifecycle/cleanup methods.
- CheckpointStorageLocationReference - Class in org.apache.flink.runtime.state
-
A reference to a storage location.
- CheckpointStorageLocationReference(byte[]) - Constructor for class org.apache.flink.runtime.state.CheckpointStorageLocationReference
-
Creates a new location reference.
- CheckpointStorageWorkerView - Interface in org.apache.flink.runtime.state
-
This interface implements the durable storage of checkpoint data and metadata streams.
- CheckpointStreamFactory - Interface in org.apache.flink.runtime.state
-
A factory for checkpoint output streams, which are used to persist data for checkpoints.
- CheckpointStreamFactory.CheckpointStateOutputStream - Class in org.apache.flink.runtime.state
-
- CheckpointStreamWithResultProvider - Interface in org.apache.flink.runtime.state
-
Interface that provides access to a CheckpointStateOutputStream and a method to provide the
SnapshotResult
.
- CheckpointStreamWithResultProvider.PrimaryAndSecondaryStream - Class in org.apache.flink.runtime.state
-
- CheckpointStreamWithResultProvider.PrimaryStreamOnly - Class in org.apache.flink.runtime.state
-
- CheckpointType - Enum in org.apache.flink.runtime.checkpoint
-
The type of checkpoint to perform.
- checkStateMetaInfo(StateDescriptor<?, ?>) - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
-
- childFirst(URL[], ClassLoader, String[]) - Static method in class org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders
-
- CircularElement() - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.CircularElement
-
- CircularElement(int, InMemorySorter<E>, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.CircularElement
-
- CircularQueues() - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.CircularQueues
-
- CircularQueues(int) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.CircularQueues
-
- ClassLoaderUtil - Class in org.apache.flink.runtime.util
-
Utilities for information with respect to class loaders, specifically class loaders for
the dynamic loading of user defined classes.
- ClassloadingProps - Class in org.apache.flink.runtime.jobmaster.message
-
The response of classloading props request to JobManager.
- ClassloadingProps(int, Collection<PermanentBlobKey>, Collection<URL>) - Constructor for class org.apache.flink.runtime.jobmaster.message.ClassloadingProps
-
Constructor of ClassloadingProps.
- cleanup() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.CrossDriver
-
- cleanup() - Method in interface org.apache.flink.runtime.operators.Driver
-
This method is invoked in any case (clean termination and exception) at the end of the tasks operation.
- cleanup() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.JoinDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.MapDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.NoOpDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.ReduceDriver
-
- cleanup() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
-
- cleanup() - Method in class org.apache.flink.runtime.rest.handler.legacy.ExecutionGraphCache
-
Perform the cleanup of out dated ExecutionGraphEntry
.
- cleanup() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
-
Calling this method will attempt delete the underlying snapshot directory recursively, if the state is
"ongoing".
- cleanupJob(JobID, boolean) - Method in class org.apache.flink.runtime.blob.BlobServer
-
Removes all BLOBs from local and HA store belonging to the given job ID.
- cleanUpOperatorStatsCache() - Method in interface org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTracker
-
Cleans up the operator stats cache if it contains timed out entries.
- cleanUpOperatorStatsCache() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTrackerImpl
-
Cleans up the operator stats cache if it contains timed out entries.
- cleanupProvidedResources() - Method in class org.apache.flink.runtime.state.AsyncSnapshotCallable
-
This method implements the cleanup of resources that have been passed in (from the sync part).
- clear() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- clear() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
-
- clear() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
-
- clear() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- clear() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyLinkedMap
-
- clear() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Clears the internal state of the view.
- clear() - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
Clears the internal state.
- clear() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
-
Removes all entries from the PriorityQueue.
- clear() - Method in class org.apache.flink.runtime.operators.util.BitSet
-
Clear the bit set.
- clear() - Method in class org.apache.flink.runtime.query.KvStateEntry
-
- clear() - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
Stop and clear the currently registered job leader id listeners.
- clear() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
-
Clears the queue.
- clear() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
- clear() - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueSet
-
- clear() - Method in class org.apache.flink.runtime.state.HeapBroadcastState
-
- clear() - Method in class org.apache.flink.runtime.state.PartitionableListState
-
- clear() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
Removes all tasks from this task slot.
- clear() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
-
- clear() - Method in class org.apache.flink.runtime.util.IntArrayList
-
- clear() - Method in class org.apache.flink.runtime.util.LongArrayList
-
- clearAll() - Method in class org.apache.flink.runtime.io.network.TaskEventDispatcher
-
Removes all registered event handlers.
- clearAllBroadcastVariables() - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
-
- clearAllMemory(List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- clearAllMemory(List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
releases all of the partition's segments (pages and overflow buckets)
- clearAllMemory(List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.ReOpenableHashPartition
-
- clearBroadcastVariable(String) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
-
- clearBuffers() - Method in interface org.apache.flink.runtime.io.network.api.reader.MutableReader
-
- clearBuffers() - Method in class org.apache.flink.runtime.io.network.api.reader.MutableRecordReader
-
- clearBuffers() - Method in interface org.apache.flink.runtime.io.network.api.reader.Reader
-
- clearBuffers() - Method in class org.apache.flink.runtime.io.network.api.reader.RecordReader
-
- clearBuffers() - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
- clearJob(JobID) - Method in class org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
-
- clearJob(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
-
- clearJob(JobID) - Method in interface org.apache.flink.runtime.highavailability.RunningJobsRegistry
-
Clear job state form the registry, usually called after job finish.
- clearJob(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperRunningJobsRegistry
-
- clearPartitions() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
This method clears all partitions currently residing (partially) in memory.
- clearPendingSlotRequest() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
- clearReaders(MutableReader<?>[]) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
- clearStateAsync() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
This method can be overridden to add a (non-blocking) state clearing routine to the
ResourceManager that will be called when leadership is revoked.
- clearTaskAssignment() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
-
- clearWriters(List<RecordWriter<?>>) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
- ClientUtils - Enum in org.apache.flink.runtime.client
-
Contains utility methods for clients.
- Clock - Class in org.apache.flink.runtime.util.clock
-
A clock that gives access to time.
- Clock() - Constructor for class org.apache.flink.runtime.util.clock.Clock
-
- clone() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
-
- cloneConfiguration(Configuration) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Clones the given configuration and resets instance specific config options.
- close() - Method in class org.apache.flink.runtime.blob.AbstractBlobCache
-
- close() - Method in class org.apache.flink.runtime.blob.BlobCacheService
-
- close() - Method in class org.apache.flink.runtime.blob.BlobClient
-
- close() - Method in class org.apache.flink.runtime.blob.BlobServer
-
Shuts down the BLOB server.
- close() - Method in class org.apache.flink.runtime.blob.FileSystemBlobStore
-
- close() - Method in class org.apache.flink.runtime.blob.VoidBlobStore
-
- close(Collection<MasterTriggerRestoreHook<?>>, Logger) - Static method in class org.apache.flink.runtime.checkpoint.hooks.MasterHooks
-
Closes the master hooks.
- close() - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
-
Tear-down method for the hook.
- close() - Method in class org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
-
- close() - Method in class org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
-
- close() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Closes the high availability services, releasing all resources.
- close() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
-
- close() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
-
- close() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- close() - Method in class org.apache.flink.runtime.io.disk.FileChannelInputView
-
- close() - Method in class org.apache.flink.runtime.io.disk.FileChannelManagerImpl
-
Remove all the temp directories.
- close() - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
-
Closes this output, writing pending data and releasing the memory.
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractChannelReaderInputView
-
Closes this InputView, closing the underlying reader and returning all memory segments.
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
-
Closes this OutputView, closing the underlying writer
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
-
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
Closes the channel and waits until all pending asynchronous requests are processed.
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
Closes this InputView, closing the underlying reader and returning all memory segments.
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
Closes this OutputView, closing the underlying writer and returning all memory segments.
- close() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
-
Closes the channel.
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Removes all temporary files.
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
Close method.
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.RequestQueue
-
Closes this request queue.
- close() - Method in class org.apache.flink.runtime.io.disk.iomanager.SynchronousFileIOChannel
-
- close() - Method in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
-
- close() - Method in class org.apache.flink.runtime.io.disk.SpillingBuffer
-
- close() - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
Closes the writer.
- close() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
-
- close(RemoteInputChannel) - Method in class org.apache.flink.runtime.io.network.netty.NettyPartitionRequestClient
-
- close() - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
Tries to shut down all network I/O components.
- close() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- close() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
-
- close() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- close(RemoteInputChannel) - Method in interface org.apache.flink.runtime.io.network.PartitionRequestClient
-
Cancels the partition request for the given remote input channel and removes
this client from factory if it is not referenced by any other input channels.
- close() - Method in class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
-
- close() - Method in class org.apache.flink.runtime.iterative.io.SolutionSetFastUpdateOutputCollector
-
- close() - Method in class org.apache.flink.runtime.iterative.io.SolutionSetObjectsUpdateOutputCollector
-
- close() - Method in class org.apache.flink.runtime.iterative.io.SolutionSetUpdateOutputCollector
-
- close() - Method in class org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
-
- close() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
- close() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
-
- close() - Method in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricDumpSerializer
-
- close() - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- close() - Method in class org.apache.flink.runtime.metrics.groups.ComponentMetricGroup
-
Closes the component group by removing and closing all metrics and subgroups
(inherited from
AbstractMetricGroup
), plus closing and removing all dedicated
component subgroups.
- close() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- close() - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
-
- close() - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
-
- close() - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
-
- close() - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
-
- close() - Method in class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
-
- close() - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
-
- close() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
-
- close() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
Closes the hash table.
- close() - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
-
Closes the hash table.
- close() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
- close() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Closes the hash table.
- close() - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
-
- close() - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
-
- close() - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
-
- close() - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
-
- close() - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
-
- close() - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
-
- close() - Method in class org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
-
- close() - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
-
- close() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
-
- close() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
-
- close() - Method in class org.apache.flink.runtime.operators.shipping.OutputCollector
-
- close() - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- close() - Method in class org.apache.flink.runtime.operators.sort.LargeRecordHandler
-
Closes all structures and deletes all temporary files.
- close() - Method in class org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
-
- close() - Method in class org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
-
- close() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
Shuts down all the threads initiated by this sort/merger.
- close() - Method in class org.apache.flink.runtime.operators.TempBarrier
-
- close() - Method in interface org.apache.flink.runtime.operators.util.CoGroupTaskIterator
-
General-purpose close method.
- close() - Method in interface org.apache.flink.runtime.operators.util.JoinTaskIterator
-
General-purpose close method.
- close() - Method in class org.apache.flink.runtime.operators.util.metrics.CountingCollector
-
- close() - Method in class org.apache.flink.runtime.operators.util.SimpleCloseableInputProvider
-
- close() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
Close connection.
- close() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
Closes the slot manager.
- close() - Method in class org.apache.flink.runtime.rest.handler.FileUploads
-
- close() - Method in class org.apache.flink.runtime.rest.handler.legacy.ExecutionGraphCache
-
- close() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- close() - Method in class org.apache.flink.runtime.state.BoundedInputStream
-
- close() - Method in class org.apache.flink.runtime.state.CheckpointMetadataOutputStream
-
This method should close the stream, if has not been closed before.
- close() - Method in class org.apache.flink.runtime.state.CheckpointStreamFactory.CheckpointStateOutputStream
-
This method should close the stream, if has not been closed before.
- close() - Method in interface org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
-
- close() - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- close() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
-
- close() - Method in class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
-
- close() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
-
- close() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
-
If the stream is only closed, we remove the produced file (cleanup through the auto close
feature, for example).
- close() - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
-
- close() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
-
- close() - Method in class org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
-
- close() - Method in class org.apache.flink.runtime.state.RetrievableStreamStateHandle
-
- close() - Method in class org.apache.flink.runtime.state.SharedStateRegistry
-
- close() - Method in class org.apache.flink.runtime.taskmanager.ConsumableNotifyingResultPartitionWriterDecorator
-
- close() - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
-
- close() - Method in class org.apache.flink.runtime.util.ForwardingInputStream
-
- close() - Method in class org.apache.flink.runtime.util.ForwardingOutputStream
-
- close() - Method in class org.apache.flink.runtime.util.NonClosingInputStreamDecorator
-
- close() - Method in class org.apache.flink.runtime.util.NonClosingOutpusStreamDecorator
-
- close() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
-
- close() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
-
- close(boolean) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
-
Closes the ZooKeeperUtilityFactory.
- CloseableInputProvider<E> - Interface in org.apache.flink.runtime.operators.util
-
Utility interface for a provider of an input that can be closed.
- closeAndCleanupAllData() - Method in interface org.apache.flink.runtime.blob.BlobStoreService
-
Closes and cleans up the store.
- closeAndCleanupAllData() - Method in class org.apache.flink.runtime.blob.FileSystemBlobStore
-
- closeAndCleanupAllData() - Method in class org.apache.flink.runtime.blob.VoidBlobStore
-
- closeAndCleanupAllData() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Closes the high availability services (releasing all resources) and deletes
all data stored by these services in external stores.
- closeAndCleanupAllData() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
-
- closeAndCleanupAllData() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- closeAndDelete() - Method in class org.apache.flink.runtime.io.disk.FileChannelInputView
-
- closeAndDelete() - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
-
Closes this output, writing pending data and releasing the memory.
- closeAndDelete() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
-
- closeAndDelete() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
This method waits for all pending asynchronous requests to return.
- closeAndDelete() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
-
Closes the channel and deletes the underlying file.
- closeAndDelete() - Method in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
-
- closeAndFinalizeCheckpoint() - Method in class org.apache.flink.runtime.state.CheckpointMetadataOutputStream
-
Closes the stream after all metadata was written and finalizes the checkpoint location.
- closeAndFinalizeCheckpoint() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
-
- closeAndFinalizeCheckpointStreamResult() - Method in interface org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
-
Closes the stream ans returns a snapshot result with the stream handle(s).
- closeAndFinalizeCheckpointStreamResult() - Method in class org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryAndSecondaryStream
-
- closeAndFinalizeCheckpointStreamResult() - Method in class org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryStreamOnly
-
- closeAndGetBytes() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
-
Closes the stream and returns the byte array containing the stream's data.
- closeAndGetHandle() - Method in class org.apache.flink.runtime.state.CheckpointStreamFactory.CheckpointStateOutputStream
-
Closes the stream and gets a state handle that can create an input stream
producing the data written to this stream.
- closeAndGetHandle() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
-
- closeAndGetHandle() - Method in class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
-
- closeAndGetHandle() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
-
- closeAndGetHandle() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
-
- closeAndGetPrimaryHandle() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
-
- closeAndGetSecondaryHandle() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
-
- closeAsync() - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- closeAsync() - Method in class org.apache.flink.runtime.entrypoint.component.DispatcherResourceManagerComponent
-
- closeAsync() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
-
- closeAsync() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
Shuts down the mini cluster, failing all currently executing jobs.
- closeAsync() - Method in class org.apache.flink.runtime.rest.handler.AbstractHandler
-
- closeAsync() - Method in class org.apache.flink.runtime.rest.RestClient
-
- closeAsync() - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
-
- closeAsync() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Triggers the shut down of the rpc endpoint.
- closeAsync() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
-
- closeAsync() - Method in enum org.apache.flink.runtime.webmonitor.WebMonitorExtension.EmptyWebMonitorExtension
-
- closeChainedTasks(List<ChainedDriver<?, ?>>, AbstractInvokable) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Closes all chained tasks, in the order as they are stored in the array.
- closed - Variable in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
Flag marking this channel as closed
- closed - Variable in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
Flag to mark the table as open / closed.
- closed - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Flag indicating that the closing logic has been invoked.
- closed - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
Flag indicating that the sorter was closed.
- closeExceptionally() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
-
- closeHandlerAsync() - Method in class org.apache.flink.runtime.rest.handler.AbstractHandler
-
- closeHandlerAsync() - Method in class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.StatusHandler
-
- closeJobManagerConnection(JobID, Exception) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
This method should be called by the framework once it detects that a currently registered
job manager has failed.
- closeLocalStrategiesAndCaches() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- closeLocalStrategiesAndCaches() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- closeLock - Variable in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
The lock that is used during closing to synchronize the thread that waits for all
requests to be handled with the asynchronous I/O thread.
- closeOpenChannelConnections(ConnectionID) - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
-
Closes opened ChannelConnections in case of a resource release.
- closeOpenChannelConnections(ConnectionID) - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
-
- closeOpenChannelConnections(ConnectionID) - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
-
- closeTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
-
- closeTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- closeTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
-
- closeTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
-
- closeTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
-
- closeTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
-
- closeTask() - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
-
- closeTask() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
-
- closeTask() - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
-
- closeTaskManagerConnection(ResourceID, Exception) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
This method should be called by the framework once it detects that a currently registered
task executor has failed.
- closeUserCode(Function) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Closes the given stub using its RichFunction.close()
method.
- CLUSTER_CONFIG_REST_PATH - Static variable in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
-
- ClusterConfigHandler - Class in org.apache.flink.runtime.rest.handler.cluster
-
Handler which serves the cluster's configuration.
- ClusterConfigHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, ClusterConfigurationInfo, EmptyMessageParameters>, Configuration) - Constructor for class org.apache.flink.runtime.rest.handler.cluster.ClusterConfigHandler
-
- ClusterConfiguration - Class in org.apache.flink.runtime.entrypoint
-
Configuration class which contains the parsed command line arguments for
the
ClusterEntrypoint
.
- ClusterConfiguration(String, Properties, String[]) - Constructor for class org.apache.flink.runtime.entrypoint.ClusterConfiguration
-
- clusterConfiguration - Variable in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
-
- ClusterConfigurationInfo - Class in org.apache.flink.runtime.rest.messages
-
Response of the
ClusterConfigHandler
, represented as a list
of key-value pairs of the cluster
Configuration
.
- ClusterConfigurationInfo() - Constructor for class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfo
-
- ClusterConfigurationInfo(int) - Constructor for class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfo
-
- ClusterConfigurationInfoEntry - Class in org.apache.flink.runtime.rest.messages
-
- ClusterConfigurationInfoEntry(String, String) - Constructor for class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoEntry
-
- ClusterConfigurationInfoHeaders - Class in org.apache.flink.runtime.rest.messages
-
- ClusterConfigurationParserFactory - Class in org.apache.flink.runtime.entrypoint
-
Parser factory which generates a
ClusterConfiguration
from the given
list of command line arguments.
- ClusterConfigurationParserFactory() - Constructor for class org.apache.flink.runtime.entrypoint.ClusterConfigurationParserFactory
-
- ClusterEntrypoint - Class in org.apache.flink.runtime.entrypoint
-
Base class for the Flink cluster entry points.
- ClusterEntrypoint(Configuration) - Constructor for class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- ClusterEntrypoint.ExecutionMode - Enum in org.apache.flink.runtime.entrypoint
-
- ClusterEntrypointException - Exception in org.apache.flink.runtime.entrypoint
-
- ClusterEntrypointException(String) - Constructor for exception org.apache.flink.runtime.entrypoint.ClusterEntrypointException
-
- ClusterEntrypointException(Throwable) - Constructor for exception org.apache.flink.runtime.entrypoint.ClusterEntrypointException
-
- ClusterEntrypointException(String, Throwable) - Constructor for exception org.apache.flink.runtime.entrypoint.ClusterEntrypointException
-
- ClusterInformation - Class in org.apache.flink.runtime.entrypoint
-
Information about the cluster which is shared with the cluster components.
- ClusterInformation(String, int) - Constructor for class org.apache.flink.runtime.entrypoint.ClusterInformation
-
- ClusterOverview - Class in org.apache.flink.runtime.messages.webmonitor
-
- ClusterOverview(int, int, int, int, int, int, int) - Constructor for class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
-
- ClusterOverview(int, int, int, JobsOverview, JobsOverview) - Constructor for class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
-
- ClusterOverview(ResourceOverview, JobsOverview) - Constructor for class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
-
- ClusterOverviewHandler - Class in org.apache.flink.runtime.rest.handler.cluster
-
Handler which returns the cluster overview information with version.
- ClusterOverviewHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, ClusterOverviewWithVersion, EmptyMessageParameters>) - Constructor for class org.apache.flink.runtime.rest.handler.cluster.ClusterOverviewHandler
-
- ClusterOverviewHeaders - Class in org.apache.flink.runtime.rest.messages
-
- ClusterOverviewWithVersion - Class in org.apache.flink.runtime.rest.handler.legacy.messages
-
Cluster overview message including the current Flink version and commit id.
- ClusterOverviewWithVersion(int, int, int, int, int, int, int, String, String) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
-
- ClusterOverviewWithVersion(int, int, int, JobsOverview, JobsOverview, String, String) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
-
- CoGroupDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
-
CoGroup task which is executed by a Task Manager.
- CoGroupDriver() - Constructor for class org.apache.flink.runtime.operators.CoGroupDriver
-
- CoGroupRawDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
-
- CoGroupRawDriver() - Constructor for class org.apache.flink.runtime.operators.CoGroupRawDriver
-
- CoGroupRawDriver.SimpleIterable<IN> - Class in org.apache.flink.runtime.operators
-
- CoGroupRawDriver.SimpleIterable.SimpleIterator<IN> - Class in org.apache.flink.runtime.operators
-
- CoGroupTaskIterator<T1,T2> - Interface in org.apache.flink.runtime.operators.util
-
Interface describing the methods that have to be implemented by local strategies for the CoGroup Pact.
- CoGroupWithSolutionSetFirstDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
-
- CoGroupWithSolutionSetFirstDriver() - Constructor for class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- CoGroupWithSolutionSetSecondDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
-
- CoGroupWithSolutionSetSecondDriver() - Constructor for class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- collect(T) - Method in class org.apache.flink.runtime.iterative.io.SolutionSetFastUpdateOutputCollector
-
- collect(T) - Method in class org.apache.flink.runtime.iterative.io.SolutionSetObjectsUpdateOutputCollector
-
- collect(T) - Method in class org.apache.flink.runtime.iterative.io.SolutionSetUpdateOutputCollector
-
- collect(T) - Method in class org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
-
- collect(IT) - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
-
- collect(IT) - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- collect(IT) - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
-
- collect(IT) - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
-
- collect(T) - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
-
- collect(IT) - Method in class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
-
- collect(IN) - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
-
- collect(IN) - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
-
- collect(IT) - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
-
- collect(T) - Method in class org.apache.flink.runtime.operators.shipping.OutputCollector
-
Collects a record and emits it to all writers.
- collect(OUT) - Method in class org.apache.flink.runtime.operators.util.metrics.CountingCollector
-
- collectStackTraces(int, ExecutionAttemptID, List<StackTraceElement[]>) - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator
-
Collects stack traces of a task.
- CoLocationConstraint - Class in org.apache.flink.runtime.jobmanager.scheduler
-
A CoLocationConstraint manages the location of a set of tasks
(Execution Vertices).
- CoLocationGroup - Class in org.apache.flink.runtime.jobmanager.scheduler
-
A Co-location group is a group of JobVertices, where the i-th subtask of one vertex
has to be executed on the same TaskManager as the i-th subtask of all
other JobVertices in the same group.
- CoLocationGroup() - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
-
- CoLocationGroup(JobVertex...) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
-
- combine(JobsOverview) - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
-
Combines the given jobs overview with this.
- combineAll(Collection<? extends CompletableFuture<? extends T>>) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Creates a future that is complete once multiple other futures completed.
- CombiningSpillingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable, MemoryManager, IOManager, TypeSerializer<E>, TypeComparator<E>, List<MemorySegment>, List<MemorySegment>, int, boolean) - Constructor for class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger.CombiningSpillingThread
-
- CombiningUnilateralSortMerger<E> - Class in org.apache.flink.runtime.operators.sort
-
The CombiningUnilateralSortMerger is part of a merge-sort implementation.
- CombiningUnilateralSortMerger(GroupCombineFunction<E, E>, MemoryManager, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, double, int, float, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger
-
Creates a new sorter that reads the data from a given reader and provides an iterator returning that
data in a sorted manner.
- CombiningUnilateralSortMerger(GroupCombineFunction<E, E>, MemoryManager, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, double, int, int, float, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger
-
Creates a new sorter that reads the data from a given reader and provides an iterator returning that
data in a sorted manner.
- CombiningUnilateralSortMerger.CombiningSpillingThread - Class in org.apache.flink.runtime.operators.sort
-
- CommandLineOptions - Class in org.apache.flink.runtime.entrypoint.parser
-
Container class for command line options.
- CommandLineParser<T> - Class in org.apache.flink.runtime.entrypoint.parser
-
Command line parser which produces a result from the given
command line arguments.
- CommandLineParser(ParserResultFactory<T>) - Constructor for class org.apache.flink.runtime.entrypoint.parser.CommandLineParser
-
- commit() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
Make the change visible to the readers.
- commitDate - Variable in class org.apache.flink.runtime.util.EnvironmentInformation.RevisionInformation
-
The git commit date
- commitId - Variable in class org.apache.flink.runtime.util.EnvironmentInformation.RevisionInformation
-
The git commit id (hash)
- CompactingHashTable<T> - Class in org.apache.flink.runtime.operators.hash
-
A hash table that uses Flink's managed memory and supports replacement of records or
updates to records.
- CompactingHashTable(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.hash.CompactingHashTable
-
- CompactingHashTable(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.operators.hash.CompactingHashTable
-
- CompactingHashTable.EntryIterator - Class in org.apache.flink.runtime.operators.hash
-
Iterator that traverses the whole hash table once
If entries are inserted during iteration they may be overlooked by the iterator
- CompactingHashTable.HashTableProber<PT> - Class in org.apache.flink.runtime.operators.hash
-
- comparator - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
-
- compare(int, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- compare(int, int, int, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- compare(int, int) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
-
- compare(int, int, 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
-
- compare(int, int, int, int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- compare(String, String) - Method in class org.apache.flink.runtime.rest.RestServerEndpoint.RestHandlerUrlComparator.CaseInsensitiveOrderComparator
-
- compare(Tuple2<RestHandlerSpecification, ChannelInboundHandler>, Tuple2<RestHandlerSpecification, ChannelInboundHandler>) - Method in class org.apache.flink.runtime.rest.RestServerEndpoint.RestHandlerUrlComparator
-
- compare(RestAPIVersion, RestAPIVersion) - Method in class org.apache.flink.runtime.rest.versioning.RestAPIVersion.RestAPIVersionComparator
-
- comparePriority(T, T) - Method in interface org.apache.flink.runtime.state.PriorityComparator
-
Compares two objects for priority.
- comparePriorityTo(T) - Method in interface org.apache.flink.runtime.state.PriorityComparable
-
- compareTo(BlobKey) - Method in class org.apache.flink.runtime.blob.BlobKey
-
- compareTo(ResourceProfile) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
- compareTo(Delayed) - Method in class org.apache.flink.runtime.concurrent.ScheduledFutureAdapter
-
- compareTo(TaskManagerLocation) - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
- complete() - Static method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationInfo
-
- completeAll(Collection<? extends CompletableFuture<?>>) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
- completeAllocation(AllocationID, JobID) - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
- completed(V) - Static method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationResult
-
- completed() - Static method in class org.apache.flink.runtime.rest.messages.queue.QueueStatus
-
- CompletedCheckpoint - Class in org.apache.flink.runtime.checkpoint
-
A CompletedCheckpoint describes a checkpoint after all required tasks acknowledged it (with their state)
and that is considered successful.
- CompletedCheckpoint(JobID, long, long, long, Map<OperatorID, OperatorState>, Collection<MasterState>, CheckpointProperties, CompletedCheckpointStorageLocation) - Constructor for class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- CompletedCheckpointStatistics(long, CheckpointStatsStatus, boolean, long, long, long, long, long, int, int, Map<JobVertexID, TaskCheckpointStatistics>, String, boolean) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.CompletedCheckpointStatistics
-
- CompletedCheckpointStats - Class in org.apache.flink.runtime.checkpoint
-
Statistics for a successfully completed checkpoint.
- CompletedCheckpointStatsSummary - Class in org.apache.flink.runtime.checkpoint
-
Summary over all completed checkpoints.
- CompletedCheckpointStorageLocation - Interface in org.apache.flink.runtime.state
-
The CompletedCheckpointStorageLocation describes the storage aspect of a completed checkpoint.
- CompletedCheckpointStore - Interface in org.apache.flink.runtime.checkpoint
-
- completedExceptionally(Throwable) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
- CompletedSubtaskCheckpointStatistics(int, long, long, long, SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration, SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
-
- completeExceptional(SerializedThrowable) - Static method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationInfo
-
- completeSnapshotAndGetHandle() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
-
Calling this method completes the snapshot for this snapshot directory, if possible, and creates a corresponding
DirectoryStateHandle
that points to the snapshot directory.
- ComponentMainThreadExecutor - Interface in org.apache.flink.runtime.concurrent
-
Interface for an executor that runs tasks in the main thread of an
RpcEndpoint
.
- ComponentMainThreadExecutor.DummyComponentMainThreadExecutor - Class in org.apache.flink.runtime.concurrent
-
Dummy implementation of ComponentMainThreadExecutor.
- ComponentMetricGroup<P extends AbstractMetricGroup<?>> - Class in org.apache.flink.runtime.metrics.groups
-
Abstract MetricGroup
for system components (e.g.,
TaskManager, Job, Task, Operator).
- ComponentMetricGroup(MetricRegistry, String[], P) - Constructor for class org.apache.flink.runtime.metrics.groups.ComponentMetricGroup
-
Creates a new ComponentMetricGroup.
- composeAfterwards(CompletableFuture<?>, Supplier<CompletableFuture<?>>) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Run the given asynchronous action after the completion of the given future.
- CompositeContainerOverlay - Class in org.apache.flink.runtime.clusterframework.overlays
-
A composite overlay that delegates to a set of inner overlays.
- CompositeContainerOverlay(ContainerOverlay...) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.CompositeContainerOverlay
-
- CompositeContainerOverlay(List<ContainerOverlay>) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.CompositeContainerOverlay
-
- compositeHeapBuffer() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
-
- compositeHeapBuffer(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
-
- CompositeStateHandle - Interface in org.apache.flink.runtime.state
-
Base of all snapshots that are taken by
StateBackend
s and some other
components in tasks.
- computeDefaultMaxParallelism(int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
-
Computes a default maximum parallelism from the operator parallelism.
- computedResult - Variable in class org.apache.flink.runtime.state.KeyGroupPartitioner
-
Cached result.
- 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.
- computePipelinedRegions(FailoverTopology) - Static method in class org.apache.flink.runtime.executiongraph.failover.flip1.PipelinedRegionComputeUtil
-
- computeSlotResourceProfile(int, long) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- 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.operators.BatchTask
-
The task configuration with the setup parameters.
- config - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- config - Variable in class org.apache.flink.runtime.operators.util.TaskConfig
-
- CONFIG_DIR_OPTION - Static variable in class org.apache.flink.runtime.entrypoint.parser.CommandLineOptions
-
- ConfigurableStateBackend - Interface in org.apache.flink.runtime.state
-
An interface for state backends that pick up additional parameters from a configuration.
- ConfigurationParserUtils - Class in org.apache.flink.runtime.util
-
Utility class to extract related parameters from Configuration
and to
sanity check them.
- ConfigurationParserUtils() - Constructor for class org.apache.flink.runtime.util.ConfigurationParserUtils
-
- configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.CompositeContainerOverlay
-
- configure(ContainerSpecification) - Method in interface org.apache.flink.runtime.clusterframework.overlays.ContainerOverlay
-
Configure the given container specification.
- configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay
-
- configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.HadoopConfOverlay
-
- configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.HadoopUserOverlay
-
- configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay
-
- configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay
-
- configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay
-
- configure(Configuration, ClassLoader) - Method in interface org.apache.flink.runtime.state.ConfigurableStateBackend
-
Creates a variant of the state backend that applies additional configuration parameters.
- configure(Configuration, ClassLoader) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Creates a copy of this state backend that uses the values defined in the configuration
for fields where that were not specified in this state backend.
- configure(Configuration, ClassLoader) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
-
Creates a copy of this state backend that uses the values defined in the configuration
for fields where that were not specified in this state backend.
- confirmCheckpoint(long) - Method in class org.apache.flink.runtime.state.NoOpTaskLocalStateStoreImpl
-
- confirmCheckpoint(long) - Method in interface org.apache.flink.runtime.state.TaskLocalStateStore
-
Notifies that the checkpoint with the given id was confirmed as complete.
- confirmCheckpoint(long) - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
- confirmCheckpoint(ExecutionAttemptID, long, long) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- confirmCheckpoint(ExecutionAttemptID, long, long) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Confirm a checkpoint for the given task.
- confirmLeaderSessionID(UUID) - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
-
- confirmLeaderSessionID(UUID) - Method in interface org.apache.flink.runtime.leaderelection.LeaderElectionService
-
Confirms that the new leader session ID has been successfully received by the new leader.
- confirmLeaderSessionID(UUID) - Method in class org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
-
- confirmLeaderSessionID(UUID) - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
-
- ConjunctFuture() - Constructor for class org.apache.flink.runtime.concurrent.FutureUtils.ConjunctFuture
-
- connecDataSet(IntermediateDataSet) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
- connect(String, Class<C>) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- connect(String, F, Class<C>) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- connect(String, Class<C>) - Method in interface org.apache.flink.runtime.rpc.RpcService
-
Connect to a remote rpc server under the provided address.
- connect(String, F, Class<C>) - Method in interface org.apache.flink.runtime.rpc.RpcService
-
Connect to a remote fenced rpc server under the provided address.
- connectDataSetAsInput(IntermediateDataSet, DistributionPattern) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- connectIdInput(IntermediateDataSetID, DistributionPattern) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- ConnectionClosedException - Exception in org.apache.flink.runtime.rest
-
Exception which is thrown if the
RestClient
detects that a connection
was closed.
- ConnectionClosedException(String) - Constructor for exception org.apache.flink.runtime.rest.ConnectionClosedException
-
- ConnectionClosedException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rest.ConnectionClosedException
-
- ConnectionClosedException(Throwable) - Constructor for exception org.apache.flink.runtime.rest.ConnectionClosedException
-
- ConnectionException - Exception in org.apache.flink.runtime.rest
-
Base class for all connection related exception thrown by the
RestClient
.
- ConnectionException(String) - Constructor for exception org.apache.flink.runtime.rest.ConnectionException
-
- ConnectionException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rest.ConnectionException
-
- ConnectionException(Throwable) - Constructor for exception org.apache.flink.runtime.rest.ConnectionException
-
- ConnectionID - Class in org.apache.flink.runtime.io.network
-
A
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
-
- ConnectionIdleException - Exception in org.apache.flink.runtime.rest
-
Exception which is thrown by the
RestClient
if a connection
becomes idle.
- ConnectionIdleException(String) - Constructor for exception org.apache.flink.runtime.rest.ConnectionIdleException
-
- ConnectionIdleException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rest.ConnectionIdleException
-
- ConnectionIdleException(Throwable) - Constructor for exception org.apache.flink.runtime.rest.ConnectionIdleException
-
- ConnectionManager - 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
-
- connectNewDataSetAsInput(JobVertex, DistributionPattern, ResultPartitionType) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- connectSource(int, IntermediateResult, JobEdge, int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- connectToPredecessors(Map<IntermediateDataSetID, IntermediateResult>) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- connectToResourceManager(ResourceManagerGateway) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Connects the SlotPool to the given ResourceManager.
- connectToResourceManager(ResourceManagerGateway) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
-
- CONSERVATIVE_PAGE_SIZE_MULTIPLE - Static variable in class org.apache.flink.runtime.io.network.partition.PageSizeUtil
-
A conservative fallback value (64 KiBytes) that should be a multiple of the page size even
in some uncommon cases of servers installations with larger-than-usual page sizes.
- ConstantTextHandler - Class in org.apache.flink.runtime.rest.handler.legacy
-
Responder that returns a constant String.
- ConstantTextHandler(String) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.ConstantTextHandler
-
- constructLogString(String, String, AbstractInvokable) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Utility function that composes a string for logging purposes.
- ConsumableNotifyingResultPartitionWriterDecorator - Class in org.apache.flink.runtime.taskmanager
-
A wrapper of result partition writer for handling the logic of consumable notification.
- ConsumableNotifyingResultPartitionWriterDecorator(TaskActions, JobID, ResultPartitionWriter, ResultPartitionConsumableNotifier) - Constructor for class org.apache.flink.runtime.taskmanager.ConsumableNotifyingResultPartitionWriterDecorator
-
- consume(T, int) - Method in interface org.apache.flink.runtime.state.KeyGroupPartitioner.KeyGroupElementsConsumer
-
- consumeAndCacheRemainingData() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
-
- ContaineredTaskManagerParameters - Class in org.apache.flink.runtime.clusterframework
-
This class describes the basic parameters for launching a TaskManager process.
- ContaineredTaskManagerParameters(long, long, long, int, HashMap<String, String>) - Constructor for class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
-
- ContainerOverlay - Interface in org.apache.flink.runtime.clusterframework.overlays
-
A container overlay to produce a container specification.
- ContainerSpecification - Class in org.apache.flink.runtime.clusterframework
-
Encapsulates a container specification, including artifacts, environment variables,
system properties, and Flink configuration settings.
- ContainerSpecification() - Constructor for class org.apache.flink.runtime.clusterframework.ContainerSpecification
-
- ContainerSpecification.Artifact - Class in org.apache.flink.runtime.clusterframework
-
An artifact to be copied into the container.
- ContainerSpecification.Artifact.Builder - Class in org.apache.flink.runtime.clusterframework
-
- contains(Object) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- contains(ExecutionVertexID) - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.partitionrelease.PipelinedRegion
-
- contains(Object) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- contains(SlotRequestId) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager
-
- contains(AbstractID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.MultiTaskSlot
-
Checks whether this slot or any of its children contains the given groupId.
- contains(AbstractID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.TaskSlot
-
Check whether the task slot contains the given groupId.
- contains(K) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
-
- contains(int) - Method in class org.apache.flink.runtime.state.KeyGroupRange
-
Checks whether or not a single key-group is contained in the range.
- contains(int) - Method in interface org.apache.flink.runtime.state.KeyGroupsList
-
Returns true, if the given key group id is contained in the list, otherwise false.
- contains(JobID) - Method in class org.apache.flink.runtime.taskexecutor.JobManagerTable
-
- containsAll(Collection<?>) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- containsAll(Collection<?>) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- containsCoLocationConstraints() - Method in class org.apache.flink.runtime.executiongraph.failover.adapter.DefaultFailoverTopology
-
- containsCoLocationConstraints() - Method in interface org.apache.flink.runtime.executiongraph.failover.flip1.FailoverTopology
-
Returns whether the topology contains co-location constraints.
- containsJob(JobID) - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
Check whether the given job is being monitored or not.
- containsJob(JobID) - Method in class org.apache.flink.runtime.taskexecutor.JobLeaderService
-
Check whether the service monitors the given job.
- containsKey(K, N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
- containsKey(K, N) - Method in class org.apache.flink.runtime.state.heap.NestedStateMap
-
- containsKey(K, N) - Method in class org.apache.flink.runtime.state.heap.StateMap
-
Returns whether this map contains the specified key/namespace composite key.
- containsKey(N) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Returns whether this table contains a mapping for the composite of active key and given namespace.
- containsKeyA(A) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyLinkedMap
-
- containsKeyB(B) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyLinkedMap
-
- containsSlot(SlotID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
-
- CONTENT_TYPE_BINARY - Static variable in enum org.apache.flink.runtime.rest.util.RestConstants
-
- CONTENT_TYPE_JAR - Static variable in enum org.apache.flink.runtime.rest.util.RestConstants
-
- ControlMessages - Enum in org.apache.flink.runtime.rpc.akka
-
Control messages for the AkkaRpcActor
.
- ConversionException - Exception in org.apache.flink.runtime.rest.messages
-
Exception which is thrown if an input cannot be converted into the requested type.
- ConversionException(String) - Constructor for exception org.apache.flink.runtime.rest.messages.ConversionException
-
- ConversionException(Throwable) - Constructor for exception org.apache.flink.runtime.rest.messages.ConversionException
-
- ConversionException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rest.messages.ConversionException
-
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointIdPathParameter
-
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskAttemptPathParameter
-
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.JobIDPathParameter
-
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.JobVertexIdPathParameter
-
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Converts the given string to a valid value of this parameter.
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.MessageQueryParameter
-
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.SubtaskIndexPathParameter
-
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerIdPathParameter
-
- convertFromString(String) - Method in class org.apache.flink.runtime.rest.messages.TriggerIdPathParameter
-
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.AccumulatorsIncludeSerializedValueQueryParameter
-
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobsFilterQueryParameter
-
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter
-
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricsFilterParameter
-
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtasksFilterQueryParameter
-
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagersFilterQueryParameter
-
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.MessageQueryParameter
-
Converts the given string to a valid value of this parameter.
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.RescalingParallelismQueryParameter
-
- convertStringToValue(String) - Method in class org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter
-
Deprecated.
- convertToOperatorStateSavepointV2(Map<JobVertexID, ExecutionJobVertex>, Savepoint) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
-
- convertToString(Long) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointIdPathParameter
-
- convertToString(Integer) - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskAttemptPathParameter
-
- convertToString(JobID) - Method in class org.apache.flink.runtime.rest.messages.JobIDPathParameter
-
- convertToString(JobVertexID) - Method in class org.apache.flink.runtime.rest.messages.JobVertexIdPathParameter
-
- convertToString(X) - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Converts the given value to its string representation.
- convertToString(List<X>) - Method in class org.apache.flink.runtime.rest.messages.MessageQueryParameter
-
- convertToString(Integer) - Method in class org.apache.flink.runtime.rest.messages.SubtaskIndexPathParameter
-
- convertToString(ResourceID) - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerIdPathParameter
-
- convertToString(TriggerId) - Method in class org.apache.flink.runtime.rest.messages.TriggerIdPathParameter
-
- convertValueToString(Boolean) - Method in class org.apache.flink.runtime.rest.messages.AccumulatorsIncludeSerializedValueQueryParameter
-
- convertValueToString(JobID) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobsFilterQueryParameter
-
- convertValueToString(MetricsAggregationParameter.AggregationMode) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter
-
- convertValueToString(String) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricsFilterParameter
-
- convertValueToString(String) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtasksFilterQueryParameter
-
- convertValueToString(ResourceID) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagersFilterQueryParameter
-
- convertValueToString(X) - Method in class org.apache.flink.runtime.rest.messages.MessageQueryParameter
-
Converts the given value to its string representation.
- convertValueToString(Integer) - Method in class org.apache.flink.runtime.rest.messages.RescalingParallelismQueryParameter
-
- convertValueToString(TerminationModeQueryParameter.TerminationMode) - Method in class org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter
-
Deprecated.
- copy() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
-
Returns a retained copy with separate indexes.
- copy(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
-
Create a copy of this QueryScopeInfo and append the given scope.
- copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobManagerQueryScopeInfo
-
- copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobQueryScopeInfo
-
- copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
-
- copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskManagerQueryScopeInfo
-
- copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
-
- copy(ArrayList<T>) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- copy(ArrayList<T>, ArrayList<T>) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- copy(VoidNamespace) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- copy(VoidNamespace, VoidNamespace) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- copy1 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- copy2 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- CopyOnWriteStateMap<K,N,S> - Class in org.apache.flink.runtime.state.heap
-
Implementation of Flink's in-memory state maps with copy-on-write support.
- CopyOnWriteStateMap.StateMapEntry<K,N,S> - Class in org.apache.flink.runtime.state.heap
-
- CopyOnWriteStateMapSnapshot<K,N,S> - Class in org.apache.flink.runtime.state.heap
-
- CopyOnWriteStateTable<K,N,S> - Class in org.apache.flink.runtime.state.heap
-
- CopyOnWriteStateTableSnapshot<K,N,S> - Class in org.apache.flink.runtime.state.heap
-
This class represents the snapshot of a
CopyOnWriteStateTable
and has a role in operator state checkpointing.
- copyTemplate() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- copyToBufferBuilder(BufferBuilder) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
-
Copies the intermediate data serialization buffer to the given target buffer.
- copyToBufferBuilder(BufferBuilder) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
-
Copies an intermediate data serialization buffer into the target BufferBuilder.
- CorruptConfigurationException - Exception in org.apache.flink.runtime.operators.util
-
Exception indicating that the parsed configuration was corrupt.
- CorruptConfigurationException(String) - Constructor for exception org.apache.flink.runtime.operators.util.CorruptConfigurationException
-
Creates a new exception with the given error message.
- CorruptConfigurationException(String, Throwable) - Constructor for exception org.apache.flink.runtime.operators.util.CorruptConfigurationException
-
- count - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.CounterDump
-
- countBuffers() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- counter(int) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- counter(String) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- counter(int, C) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- counter(String, C) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- counter(int) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- counter(String) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- counter(int, C) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- counter(String, C) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- CounterDump(QueryScopeInfo, String, long) - Constructor for class org.apache.flink.runtime.metrics.dump.MetricDump.CounterDump
-
- counterHistogram - Variable in class org.apache.flink.runtime.state.KeyGroupPartitioner
-
This bookkeeping array is used to count the elements in each key-group.
- CountingCollector<OUT> - Class in org.apache.flink.runtime.operators.util.metrics
-
- CountingCollector(Collector<OUT>, Counter) - Constructor for class org.apache.flink.runtime.operators.util.metrics.CountingCollector
-
- CountingIterable<IN> - Class in org.apache.flink.runtime.operators.util.metrics
-
- CountingIterable(Iterable<IN>, Counter) - Constructor for class org.apache.flink.runtime.operators.util.metrics.CountingIterable
-
- CountingIterator<IN> - Class in org.apache.flink.runtime.operators.util.metrics
-
- CountingIterator(Iterator<IN>, Counter) - Constructor for class org.apache.flink.runtime.operators.util.metrics.CountingIterator
-
- CountingMutableObjectIterator<IN> - Class in org.apache.flink.runtime.operators.util.metrics
-
- CountingMutableObjectIterator(MutableObjectIterator<IN>, Counter) - Constructor for class org.apache.flink.runtime.operators.util.metrics.CountingMutableObjectIterator
-
- Counts(long, long, int, long, long) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
-
- create() - Method in class org.apache.flink.runtime.akka.StoppingSupervisorWithoutLoggingActorKilledExceptionStrategy
-
- create() - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook.Factory
-
Instantiates the MasterTriggerRestoreHook
.
- create(Configuration, long, int) - Static method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
-
Computes the parameters to be used to start a TaskManager Java process.
- create(Configuration, RpcService, HighAvailabilityServices, BlobServer, HeartbeatServices, MetricRegistry, ArchivedExecutionGraphStore, MetricQueryServiceRetriever, FatalErrorHandler) - Method in class org.apache.flink.runtime.entrypoint.component.AbstractDispatcherResourceManagerComponentFactory
-
- create(Configuration, RpcService, HighAvailabilityServices, BlobServer, HeartbeatServices, MetricRegistry, ArchivedExecutionGraphStore, MetricQueryServiceRetriever, FatalErrorHandler) - Method in interface org.apache.flink.runtime.entrypoint.component.DispatcherResourceManagerComponentFactory
-
- create(FlinkUserCodeClassLoaders.ResolveOrder, URL[], ClassLoader, String[]) - Static method in class org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders
-
- create(ExecutionGraph) - Method in class org.apache.flink.runtime.executiongraph.failover.AdaptedRestartPipelinedRegionStrategyNG.Factory
-
- create(ExecutionGraph) - Method in interface org.apache.flink.runtime.executiongraph.failover.FailoverStrategy.Factory
-
Instantiates the FailoverStrategy
.
- create(FailoverTopology) - Method in interface org.apache.flink.runtime.executiongraph.failover.flip1.FailoverStrategy.Factory
-
- create() - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.FailureRateRestartBackoffTimeStrategy.FailureRateRestartBackoffTimeStrategyFactory
-
- create() - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.FixedDelayRestartBackoffTimeStrategy.FixedDelayRestartBackoffTimeStrategyFactory
-
- create() - Method in interface org.apache.flink.runtime.executiongraph.failover.flip1.RestartBackoffTimeStrategy.Factory
-
- create(ExecutionGraph) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy.Factory
-
- create(ExecutionGraph) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy.Factory
-
- create(ExecutionGraph) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy.Factory
-
- create(int, ResultPartition, File, int) - Method in enum org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionType
-
Creates BoundedBlockingSubpartition of this type.
- create(String, InputGateDeploymentDescriptor, PartitionProducerStateProvider, InputChannelMetrics) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGateFactory
-
Creates an input gate and all of its input channels.
- create(PartitionTrackerFactory.TaskExecutorGatewayLookup) - Method in interface org.apache.flink.runtime.io.network.partition.PartitionTrackerFactory
-
Creates a new PartitionTracker.
- create(String, ResultPartitionDeploymentDescriptor) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionFactory
-
- create(String, ResultPartitionID, ResultPartitionType, int, int, FunctionWithException<BufferPoolOwner, BufferPool, IOException>) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionFactory
-
- create(JobGraph) - Method in class org.apache.flink.runtime.jobmaster.factories.DefaultJobManagerJobMetricGroupFactory
-
- create(JobGraph) - Method in interface org.apache.flink.runtime.jobmaster.factories.JobManagerJobMetricGroupFactory
-
- create(JobGraph) - Method in enum org.apache.flink.runtime.jobmaster.factories.UnregisteredJobManagerJobMetricGroupFactory
-
- create(Collection<JobStatus>) - Static method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
-
- create(List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.sort.DefaultInMemorySorterFactory
-
- create(List<MemorySegment>) - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorterFactory
-
- create(AccessExecution, MutableIOMetrics) - Static method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- create(TaskManagerLocation, ExecutionAttemptID) - Static method in class org.apache.flink.runtime.shuffle.ProducerDescriptor
-
- create(String, TypeSerializer<T>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- create(String, TypeSerializer<T>) - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueSetFactory
-
- create(int, int, KeyExtractorFunction<T>, PriorityComparator<T>) - Method in interface org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue.PartitionQueueSetFactory
-
Creates a new queue for a given key-group partition.
- create(String, TypeSerializer<T>) - Method in interface org.apache.flink.runtime.state.PriorityQueueSetFactory
-
- create(Executor) - Method in interface org.apache.flink.runtime.state.SharedStateRegistryFactory
-
- createActivatorDeactivator() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- createActiveResourceManager(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, FatalErrorHandler, ClusterInformation, String, JobManagerMetricGroup) - Method in class org.apache.flink.runtime.resourcemanager.ActiveResourceManagerFactory
-
- createActiveResourceManagerConfiguration(Configuration) - Static method in class org.apache.flink.runtime.resourcemanager.ActiveResourceManagerFactory
-
- createAllocatedSlotReport(ResourceID) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Create report about the allocated slots belonging to the specified task manager.
- createAllocatedSlotReport(ResourceID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
-
- createAndAddResultDataSet(ResultPartitionType) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- createAndAddResultDataSet(IntermediateDataSetID, ResultPartitionType) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- createAvailableOrEmbeddedServices(Configuration, Executor) - Static method in class org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
-
- createBlobStore() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Creates the BLOB store in which BLOBs are stored in a highly-available fashion.
- createBlobStore() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
-
- createBlobStore() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- createBlobStoreFromConfig(Configuration) - Static method in class org.apache.flink.runtime.blob.BlobUtils
-
Creates a BlobStore based on the parameters set in the configuration.
- createBlockChannelReader(FileIOChannel.ID) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Creates a block channel reader that reads blocks from the given channel.
- createBlockChannelReader(FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Creates a block channel reader that reads blocks from the given channel.
- createBlockChannelReader(FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
Creates a block channel reader that reads blocks from the given channel.
- createBlockChannelWriter(FileIOChannel.ID) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Creates a block channel writer that writes to the given channel.
- createBlockChannelWriter(FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Creates a block channel writer that writes to the given channel.
- createBlockChannelWriter(FileIOChannel.ID, RequestDoneCallback<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Creates a block channel writer that writes to the given channel.
- createBlockChannelWriter(FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
- createBlockChannelWriter(FileIOChannel.ID, RequestDoneCallback<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
- createBufferConsumer() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
- createBufferFileReader(FileIOChannel.ID, RequestDoneCallback<Buffer>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
- createBufferFileReader(FileIOChannel.ID, RequestDoneCallback<Buffer>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
- createBufferFileSegmentReader(FileIOChannel.ID, RequestDoneCallback<FileSegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
- createBufferFileSegmentReader(FileIOChannel.ID, RequestDoneCallback<FileSegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
- createBufferFileWriter(FileIOChannel.ID) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
- createBufferFileWriter(FileIOChannel.ID) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
- createBufferPool(int, int) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPoolFactory
-
Tries to create a buffer pool, which is guaranteed to provide at least the number of required
buffers.
- createBufferPool(int, int, Optional<BufferPoolOwner>) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPoolFactory
-
Tries to create a buffer pool with an optional owner, which is guaranteed to provide at least the
number of required buffers.
- createBufferPool(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- createBufferPool(int, int, Optional<BufferPoolOwner>) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- createBulkBlockChannelReader(FileIOChannel.ID, List<MemorySegment>, int) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Creates a block channel reader that reads all blocks from the given channel directly in one bulk.
- createBulkBlockChannelReader(FileIOChannel.ID, List<MemorySegment>, int) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
Creates a block channel reader that reads all blocks from the given channel directly in one bulk.
- createChannel() - Method in interface org.apache.flink.runtime.io.disk.FileChannelManager
-
Creates an ID identifying an underlying file channel and returns it.
- createChannel() - Method in class org.apache.flink.runtime.io.disk.FileChannelManagerImpl
-
- createChannel() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
- createChannelEnumerator() - Method in interface org.apache.flink.runtime.io.disk.FileChannelManager
-
Creates an enumerator for channels that logically belong together and returns it.
- createChannelEnumerator() - Method in class org.apache.flink.runtime.io.disk.FileChannelManagerImpl
-
- createChannelEnumerator() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
-
Creates a new
FileIOChannel.Enumerator
, spreading the channels in a round-robin fashion
across the temporary file directories.
- createCheckpointDataSerializer() - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
-
Creates a the serializer to (de)serializes the data stored by this hook.
- createCheckpointDirectory(Path, long) - Static method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
-
Creates the directory path for the data exclusive to a specific checkpoint.
- 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(CheckpointedStateScope) - Method in interface org.apache.flink.runtime.state.CheckpointStreamFactory
-
- createCheckpointStateOutputStream(CheckpointedStateScope) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
-
- createCheckpointStateOutputStream(CheckpointedStateScope) - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory
-
- createCheckpointStorage(JobID) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
- createCheckpointStorage(JobID) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
-
- createCheckpointStorage(JobID) - Method in interface org.apache.flink.runtime.state.StateBackend
-
Creates a storage for checkpoints for the given job.
- createCheckpointStore(JobID, int, ClassLoader) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
-
- createCheckpointStore(JobID, int, ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
-
- createCheckpointStore(JobID, int, ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
-
- createChildGroup(String, AbstractMetricGroup.ChildType) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- createChildGroup(String, AbstractMetricGroup.ChildType) - Method in class org.apache.flink.runtime.metrics.groups.GenericKeyMetricGroup
-
- createClient() - Method in class org.apache.flink.runtime.blob.BlobServer
-
- createClientSSLEngineFactory() - 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
-
- created(JobResult) - Static method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
-
- createDeploymentDescriptor(AllocationID, int, JobManagerTaskRestore, Collection<ResultPartitionDeploymentDescriptor>) - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory
-
- createDetailsForJob(AccessExecutionGraph) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
-
- createDispatcher(Configuration, RpcService, HighAvailabilityServices, GatewayRetriever<ResourceManagerGateway>, BlobServer, HeartbeatServices, JobManagerMetricGroup, String, ArchivedExecutionGraphStore, FatalErrorHandler, HistoryServerArchivist) - Method in interface org.apache.flink.runtime.dispatcher.DispatcherFactory
-
- createDispatcher(Configuration, RpcService, HighAvailabilityServices, GatewayRetriever<ResourceManagerGateway>, BlobServer, HeartbeatServices, JobManagerMetricGroup, String, ArchivedExecutionGraphStore, FatalErrorHandler, HistoryServerArchivist) - Method in class org.apache.flink.runtime.dispatcher.JobDispatcherFactory
-
- createDispatcher(Configuration, RpcService, HighAvailabilityServices, GatewayRetriever<ResourceManagerGateway>, BlobServer, HeartbeatServices, JobManagerMetricGroup, String, ArchivedExecutionGraphStore, FatalErrorHandler, HistoryServerArchivist) - Method in enum org.apache.flink.runtime.dispatcher.SessionDispatcherFactory
-
- createDispatcherResourceManagerComponent(T, ResourceManager<?>, LeaderRetrievalService, LeaderRetrievalService, WebMonitorEndpoint<?>, JobManagerMetricGroup) - Method in class org.apache.flink.runtime.entrypoint.component.AbstractDispatcherResourceManagerComponentFactory
-
- createDispatcherResourceManagerComponent(MiniDispatcher, ResourceManager<?>, LeaderRetrievalService, LeaderRetrievalService, WebMonitorEndpoint<?>, JobManagerMetricGroup) - Method in class org.apache.flink.runtime.entrypoint.component.JobDispatcherResourceManagerComponentFactory
-
- createDispatcherResourceManagerComponent(Dispatcher, ResourceManager<?>, LeaderRetrievalService, LeaderRetrievalService, WebMonitorEndpoint<?>, JobManagerMetricGroup) - Method in class org.apache.flink.runtime.entrypoint.component.SessionDispatcherResourceManagerComponentFactory
-
- createDispatcherResourceManagerComponentFactory(Configuration) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- createDispatcherResourceManagerComponentFactory(Configuration) - Method in class org.apache.flink.runtime.entrypoint.StandaloneSessionClusterEntrypoint
-
- createDispatcherResourceManagerComponents(Configuration, MiniCluster.RpcServiceFactory, HighAvailabilityServices, BlobServer, HeartbeatServices, MetricRegistry, MetricQueryServiceRetriever, FatalErrorHandler) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- createDuplicatingStream(long, CheckpointedStateScope, CheckpointStreamFactory, LocalRecoveryDirectoryProvider) - Static method in interface org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
-
- createExecutorService(int, int, String) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
-
- createFactory(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.failover.flip1.FailureRateRestartBackoffTimeStrategy
-
- createFactory(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.failover.flip1.FixedDelayRestartBackoffTimeStrategy
-
- 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 NoRestartStrategyFactory instance.
- createFailoverRegion(ExecutionGraph, List<ExecutionVertex>) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
-
- createFileSystemStateStorage(Configuration, String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- createForDeserializedState() - Method in interface org.apache.flink.runtime.state.StateSnapshotTransformer.StateSnapshotTransformFactory
-
- createForDeserializedState() - Method in class org.apache.flink.runtime.state.StateSnapshotTransformers.ListStateSnapshotTransformFactory
-
- createForDeserializedState() - Method in class org.apache.flink.runtime.state.StateSnapshotTransformers.MapStateSnapshotTransformFactory
-
- createForDeserializedState() - Method in class org.apache.flink.runtime.state.StateSnapshotTransformers.StateSnapshotTransformFactoryWrapAdaptor
-
- createForSerializedState() - Method in interface org.apache.flink.runtime.state.StateSnapshotTransformer.StateSnapshotTransformFactory
-
- createForSerializedState() - Method in class org.apache.flink.runtime.state.StateSnapshotTransformers.StateSnapshotTransformFactoryWrapAdaptor
-
- createFrom(Configuration) - Static method in class org.apache.flink.runtime.entrypoint.component.FileJobGraphRetriever
-
- createFrom(ExecutionGraph) - Static method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- createFrom(AccessExecutionGraph) - Static method in class org.apache.flink.runtime.jobmaster.JobResult
-
- createFromConfig(Configuration, ClassLoader) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackendFactory
-
- createFromConfig(Configuration, ClassLoader) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackendFactory
-
- createFromConfig(Configuration, ClassLoader) - Method in interface org.apache.flink.runtime.state.StateBackendFactory
-
Creates the state backend, optionally using the given configuration.
- createGateway(CompletableFuture<Tuple2<String, UUID>>) - Method in class org.apache.flink.runtime.webmonitor.retriever.impl.RpcGatewayRetriever
-
- createGateway(CompletableFuture<Tuple2<String, UUID>>) - Method in class org.apache.flink.runtime.webmonitor.retriever.LeaderGatewayRetriever
-
- createHaServices(Configuration, Executor) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- createHAServices(Configuration, Executor) - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServicesFactory
-
- createHeartbeatManager(ResourceID, HeartbeatListener<I, O>, ScheduledExecutor, Logger) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatServices
-
Creates a heartbeat manager which does not actively send heartbeats.
- createHeartbeatManagerSender(ResourceID, HeartbeatListener<I, O>, ScheduledExecutor, Logger) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatServices
-
Creates a heartbeat manager which actively sends heartbeats to monitoring targets.
- createHeartbeatMonitor(ResourceID, HeartbeatTarget<O>, ScheduledExecutor, HeartbeatListener<?, O>, long) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatMonitor.Factory
-
Create heartbeat monitor heartbeat monitor.
- createHeartbeatServices(Configuration) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- createHighAvailabilityServices(Configuration, Executor, HighAvailabilityServicesUtils.AddressResolution) - Static method in class org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
-
- createHighAvailabilityServices(Configuration, Executor) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- createHistoryServerArchivist(Configuration, JsonArchivist) - Static method in interface org.apache.flink.runtime.dispatcher.HistoryServerArchivist
-
- createInputGates(ShuffleIOOwnerContext, PartitionProducerStateProvider, Collection<InputGateDeploymentDescriptor>) - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
- createInputGates(ShuffleIOOwnerContext, PartitionProducerStateProvider, Collection<InputGateDeploymentDescriptor>) - Method in interface org.apache.flink.runtime.shuffle.ShuffleEnvironment
-
Factory method for the
InputGates
to consume result partitions.
- createInputIterator(MutableReader<?>, TypeSerializerFactory<?>) - Method in class org.apache.flink.runtime.operators.BatchTask
-
- createInstance(SchedulingTopology, FailoverTopology) - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.partitionrelease.NotReleasingPartitionReleaseStrategy.Factory
-
- createInstance(SchedulingTopology, FailoverTopology) - Method in interface org.apache.flink.runtime.executiongraph.failover.flip1.partitionrelease.PartitionReleaseStrategy.Factory
-
- createInstance(SchedulingTopology, FailoverTopology) - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.partitionrelease.RegionPartitionReleaseStrategy.Factory
-
- createInstance(Logger, JobGraph, BackPressureStatsTracker, Executor, Configuration, SlotProvider, ScheduledExecutorService, ClassLoader, CheckpointRecoveryFactory, Time, BlobWriter, JobManagerJobMetricGroup, Time, ShuffleMaster<?>, PartitionTracker) - Method in class org.apache.flink.runtime.scheduler.DefaultSchedulerFactory
-
- createInstance(Logger, JobGraph, BackPressureStatsTracker, Executor, Configuration, SlotProvider, ScheduledExecutorService, ClassLoader, CheckpointRecoveryFactory, Time, BlobWriter, JobManagerJobMetricGroup, Time, ShuffleMaster<?>, PartitionTracker) - Method in class org.apache.flink.runtime.scheduler.LegacySchedulerFactory
-
- createInstance(Logger, JobGraph, BackPressureStatsTracker, Executor, Configuration, SlotProvider, ScheduledExecutorService, ClassLoader, CheckpointRecoveryFactory, Time, BlobWriter, JobManagerJobMetricGroup, Time, ShuffleMaster<?>, PartitionTracker) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNGFactory
-
- createInstance(SchedulerOperations, SchedulingTopology, JobGraph) - Method in class org.apache.flink.runtime.scheduler.strategy.EagerSchedulingStrategy.Factory
-
- createInstance(SchedulerOperations, SchedulingTopology, JobGraph) - Method in class org.apache.flink.runtime.scheduler.strategy.LazyFromSourcesSchedulingStrategy.Factory
-
- createInstance(SchedulerOperations, SchedulingTopology, JobGraph) - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingStrategyFactory
-
- createInstance() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- createInstance(Object...) - Method in class org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
-
- createInstance() - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- createInternalClientSSLEngineFactory(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
Creates a SSLEngineFactory to be used by internal communication client endpoints.
- createInternalServerSSLEngineFactory(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
Creates a SSLEngineFactory to be used by internal communication server endpoints.
- createInternalState(TypeSerializer<N>, StateDescriptor<S, SV>, StateSnapshotTransformer.StateSnapshotTransformFactory<SEV>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- createInternalState(TypeSerializer<N>, StateDescriptor<S, SV>) - Method in interface org.apache.flink.runtime.state.KeyedStateFactory
-
- createInternalState(TypeSerializer<N>, StateDescriptor<S, SV>, StateSnapshotTransformer.StateSnapshotTransformFactory<SEV>) - Method in interface org.apache.flink.runtime.state.KeyedStateFactory
-
- createJobManagerRunner(JobGraph, Configuration, RpcService, HighAvailabilityServices, HeartbeatServices, JobManagerSharedServices, JobManagerJobMetricGroupFactory, FatalErrorHandler) - Method in enum org.apache.flink.runtime.dispatcher.DefaultJobManagerRunnerFactory
-
- createJobManagerRunner(JobGraph, Configuration, RpcService, HighAvailabilityServices, HeartbeatServices, JobManagerSharedServices, JobManagerJobMetricGroupFactory, FatalErrorHandler) - Method in interface org.apache.flink.runtime.dispatcher.JobManagerRunnerFactory
-
- createJobMasterService(JobGraph, OnCompletionActions, ClassLoader) - Method in class org.apache.flink.runtime.jobmaster.factories.DefaultJobMasterServiceFactory
-
- createJobMasterService(JobGraph, OnCompletionActions, ClassLoader) - Method in interface org.apache.flink.runtime.jobmaster.factories.JobMasterServiceFactory
-
- createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry, TtlTimeProvider, MetricGroup, Collection<KeyedStateHandle>, CloseableRegistry) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
-
- createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry, TtlTimeProvider, MetricGroup, Collection<KeyedStateHandle>, CloseableRegistry) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
- createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry, TtlTimeProvider, MetricGroup, Collection<KeyedStateHandle>, CloseableRegistry) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
-
- createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry, TtlTimeProvider, MetricGroup, Collection<KeyedStateHandle>, CloseableRegistry) - Method in interface org.apache.flink.runtime.state.StateBackend
-
- createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - Method in class org.apache.flink.runtime.operators.sort.NonReusingMergeInnerJoinIterator
-
- createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - Method in class org.apache.flink.runtime.operators.sort.NonReusingMergeOuterJoinIterator
-
- createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - Method in class org.apache.flink.runtime.operators.sort.ReusingMergeInnerJoinIterator
-
- createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - Method in class org.apache.flink.runtime.operators.sort.ReusingMergeOuterJoinIterator
-
- createKeyGroupPartitionReader(KeyGroupPartitioner.ElementReaderFunction<T>, KeyGroupPartitioner.KeyGroupElementsConsumer<T>) - Static method in class org.apache.flink.runtime.state.KeyGroupPartitioner
-
- createKeyGroupPartitions(int, int) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
-
Groups the available set of key groups into key group partitions.
- createKvStateClientProxy(InetAddress, Iterator<Integer>, int, int, KvStateRequestStats) - Static method in class org.apache.flink.runtime.query.QueryableStateUtils
-
Initializes the
client proxy
responsible for
receiving requests from the external (to the cluster) client and forwarding them internally.
- createKvStateServer(InetAddress, Iterator<Integer>, int, int, KvStateRegistry, KvStateRequestStats) - Static method in class org.apache.flink.runtime.query.QueryableStateUtils
-
Initializes the
server
responsible for sending the
requested internal state to the
client proxy
.
- createKvStateTaskRegistry(JobID, JobVertexID) - Method in class org.apache.flink.runtime.taskexecutor.KvStateService
-
- createLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
-
- createLeaderElectionService(CuratorFramework, Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- createLeaderElectionService(CuratorFramework, Configuration, String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- createLeaderRetrievalService() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
-
- createLeaderRetrievalService() - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
-
- createLeaderRetrievalService(Configuration) - Static method in class org.apache.flink.runtime.util.StandaloneUtils
-
- createLeaderRetrievalService(Configuration, boolean, String) - Static method in class org.apache.flink.runtime.util.StandaloneUtils
-
- createLeaderRetrievalService(CuratorFramework, Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- createLeaderRetrievalService(CuratorFramework, Configuration, String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- createLocalRecoveryConfig() - Method in interface org.apache.flink.runtime.state.TaskStateManager
-
Returns the configuration for local recovery, i.e.
- createLocalRecoveryConfig() - Method in class org.apache.flink.runtime.state.TaskStateManagerImpl
-
- createLogicalScope(CharacterFilter, char) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- createLogicalScope(CharacterFilter, char) - Method in class org.apache.flink.runtime.metrics.groups.GenericValueMetricGroup
-
- createMetadataOutputStream() - Method in interface org.apache.flink.runtime.state.CheckpointStorageLocation
-
Creates the output stream to persist the checkpoint metadata to.
- createMetadataOutputStream() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
-
- createMetadataOutputStream() - Method in class org.apache.flink.runtime.state.memory.NonPersistentMetadataCheckpointStorageLocation
-
- createMetadataOutputStream() - Method in class org.apache.flink.runtime.state.memory.PersistentMetadataCheckpointStorageLocation
-
- createMetricQueryService(RpcService, ResourceID, long) - Static method in class org.apache.flink.runtime.metrics.dump.MetricQueryService
-
Starts the MetricQueryService actor in the given actor system.
- createMetricRegistry(Configuration) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- createMetricRegistry(Configuration) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
Factory method to create the metric registry for the mini cluster.
- createModule(SecurityConfiguration) - Method in class org.apache.flink.runtime.security.modules.HadoopModuleFactory
-
- createModule(SecurityConfiguration) - Method in class org.apache.flink.runtime.security.modules.JaasModuleFactory
-
- createModule(SecurityConfiguration) - Method in interface org.apache.flink.runtime.security.modules.SecurityModuleFactory
-
- createModule(SecurityConfiguration) - Method in class org.apache.flink.runtime.security.modules.ZookeeperModuleFactory
-
- createNettySSLHandler(ByteBufAllocator) - Method in class org.apache.flink.runtime.io.network.netty.SSLHandlerFactory
-
- createNettySSLHandler(ByteBufAllocator, String, int) - Method in class org.apache.flink.runtime.io.network.netty.SSLHandlerFactory
-
- createNoTransform() - Static method in interface org.apache.flink.runtime.state.StateSnapshotTransformer.StateSnapshotTransformFactory
-
- createOperationKey(HandlerRequest<B, M>) - Method in class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.TriggerHandler
-
Create the operation key under which the result future of the asynchronous operation will
be stored.
- createOperationKey(HandlerRequest<EmptyRequestBody, RescalingTriggerMessageParameters>) - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingTriggerHandler
-
- createOperationKey(HandlerRequest<SavepointDisposalRequest, EmptyMessageParameters>) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalTriggerHandler
-
- createOperatorStateBackend(Environment, String, Collection<OperatorStateHandle>, CloseableRegistry) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
-
- createOperatorStateBackend(Environment, String, Collection<OperatorStateHandle>, CloseableRegistry) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
- createOperatorStateBackend(Environment, String, Collection<OperatorStateHandle>, CloseableRegistry) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
-
- createOperatorStateBackend(Environment, String, Collection<OperatorStateHandle>, CloseableRegistry) - Method in interface org.apache.flink.runtime.state.StateBackend
-
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.runtime.state.ArrayListSerializerSnapshot
-
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializerSnapshot
-
- 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
-
- createRandomName(String) - Static method in class org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
-
Creates a random name of the form prefix_X, where X is an increasing number.
- createReadView(BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
- createResourceManager(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, FatalErrorHandler, ClusterInformation, String, JobManagerMetricGroup) - Method in class org.apache.flink.runtime.resourcemanager.ActiveResourceManagerFactory
-
- createResourceManager(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, FatalErrorHandler, ClusterInformation, String, JobManagerMetricGroup) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerFactory
-
- createResourceManager(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, FatalErrorHandler, ClusterInformation, String, JobManagerMetricGroup) - Method in enum org.apache.flink.runtime.resourcemanager.StandaloneResourceManagerFactory
-
- 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.NoOrFixedIfCheckpointingEnabledRestartStrategyFactory
-
- createRestartStrategy() - Method in class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy.NoRestartStrategyFactory
-
- createRestartStrategy() - Method in class org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
-
Factory method to create a restart strategy.
- createRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - Static method in class org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
-
Creates a
RestartStrategy
instance from the given
RestartStrategies.RestartStrategyConfiguration
.
- createRestartStrategy() - Method in class org.apache.flink.runtime.executiongraph.restart.ThrowingRestartStrategy.ThrowingRestartStrategyFactory
-
- createRestartStrategyFactory(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
-
- createRestClientSSLEngineFactory(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
- createRestEndpoint(Configuration, LeaderGatewayRetriever<DispatcherGateway>, LeaderGatewayRetriever<ResourceManagerGateway>, TransientBlobService, ExecutorService, MetricFetcher, LeaderElectionService, FatalErrorHandler) - Method in enum org.apache.flink.runtime.rest.JobRestEndpointFactory
-
- createRestEndpoint(Configuration, LeaderGatewayRetriever<DispatcherGateway>, LeaderGatewayRetriever<ResourceManagerGateway>, TransientBlobService, ExecutorService, MetricFetcher, LeaderElectionService, FatalErrorHandler) - Method in interface org.apache.flink.runtime.rest.RestEndpointFactory
-
- createRestEndpoint(Configuration, LeaderGatewayRetriever<DispatcherGateway>, LeaderGatewayRetriever<ResourceManagerGateway>, TransientBlobService, ExecutorService, MetricFetcher, LeaderElectionService, FatalErrorHandler) - Method in enum org.apache.flink.runtime.rest.SessionRestEndpointFactory
-
- createRestNettySSLContext(Configuration, boolean, ClientAuth, SslProvider) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
Creates an SSL context for the external REST SSL.
- createRestServerSSLEngineFactory(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
- createRestSSLContext(Configuration, boolean) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
Creates an SSL context for clients against the external REST endpoint.
- createResult(CommandLine) - Method in class org.apache.flink.runtime.entrypoint.ClusterConfigurationParserFactory
-
- createResult(CommandLine) - Method in class org.apache.flink.runtime.entrypoint.EntrypointClusterConfigurationParserFactory
-
- createResult(CommandLine) - Method in interface org.apache.flink.runtime.entrypoint.parser.ParserResultFactory
-
Create the result of the command line argument parsing.
- createResultPartitionWriters(ShuffleIOOwnerContext, Collection<ResultPartitionDeploymentDescriptor>) - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
- createResultPartitionWriters(ShuffleIOOwnerContext, Collection<ResultPartitionDeploymentDescriptor>) - Method in interface org.apache.flink.runtime.shuffle.ShuffleEnvironment
-
- createRpcService() - Method in class org.apache.flink.runtime.minicluster.MiniCluster.CommonRpcServiceFactory
-
- createRpcService(AkkaRpcServiceConfiguration, boolean, String) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
Factory method to instantiate the RPC service.
- createRpcService() - Method in class org.apache.flink.runtime.minicluster.MiniCluster.DedicatedRpcServiceFactory
-
- createRpcService() - Method in interface org.apache.flink.runtime.minicluster.MiniCluster.RpcServiceFactory
-
- createRpcService(String, String, Configuration) - Static method in class org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
-
Utility method to create RPC service from configuration and hostname, port.
- createRpcService(String, int, Configuration) - Static method in class org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
-
Utility method to create RPC service from configuration and hostname, port.
- createRpcService(String, String, Configuration, String, BootstrapTools.ActorSystemExecutorConfiguration) - Static method in class org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
-
Utility method to create RPC service from configuration and hostname, port.
- createRpcService(Configuration, HighAvailabilityServices) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
-
Create a RPC service for the task manager.
- createRuntimeContext(MetricGroup) - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- createRuntimeContext(MetricGroup) - Method in class org.apache.flink.runtime.operators.BatchTask
-
- createRuntimeContext() - Method in class org.apache.flink.runtime.operators.DataSinkTask
-
- createRuntimeContext() - Method in class org.apache.flink.runtime.operators.DataSourceTask
-
- createSavepointLocation(FileSystem, Path) - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
-
- createSavepointLocation(FileSystem, Path) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
-
- createSavepointLocation(FileSystem, Path) - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
-
- createScheduler(SlotPool) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultSchedulerFactory
-
- createScheduler(SlotPool) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SchedulerFactory
-
Creates a new scheduler instance that uses the given
SlotPool
to allocate slots.
- createSerializableExecutionGraphStore(Configuration, ScheduledExecutor) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- createSerializableExecutionGraphStore(Configuration, ScheduledExecutor) - Method in class org.apache.flink.runtime.entrypoint.JobClusterEntrypoint
-
- createSerializableExecutionGraphStore(Configuration, ScheduledExecutor) - Method in class org.apache.flink.runtime.entrypoint.SessionClusterEntrypoint
-
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-
- createSerializerInstance(CompositeSerializer.PrecomputedParameters, TypeSerializer<?>...) - Method in class org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
-
- createServerSSLEngineFactory() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- createSharedCount(String, int) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
-
- createSharedStateRegistryKeyFromFileName(StateHandleID) - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
-
Create a unique key to register one of our shared state handles.
- createSharedValue(String, byte[]) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
-
- createShuffleEnvironment(ShuffleEnvironmentContext) - Method in class org.apache.flink.runtime.io.network.NettyShuffleServiceFactory
-
- createShuffleEnvironment(ShuffleEnvironmentContext) - Method in interface org.apache.flink.runtime.shuffle.ShuffleServiceFactory
-
- createShuffleIOOwnerContext(String, ExecutionAttemptID, MetricGroup) - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
- createShuffleIOOwnerContext(String, ExecutionAttemptID, MetricGroup) - Method in interface org.apache.flink.runtime.shuffle.ShuffleEnvironment
-
Create a context of the shuffle input/output owner used to create partitions or gates belonging to the owner.
- createShuffleIOOwnerMetricGroup(MetricGroup) - Static method in class org.apache.flink.runtime.io.network.metrics.NettyShuffleMetricFactory
-
- createShuffleMaster(Configuration) - Method in class org.apache.flink.runtime.io.network.NettyShuffleServiceFactory
-
- createShuffleMaster(Configuration) - Method in interface org.apache.flink.runtime.shuffle.ShuffleServiceFactory
-
Factory method to create a specific
ShuffleMaster
implementation.
- createSimpleStream(CheckpointedStateScope, CheckpointStreamFactory) - Static method in interface org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
-
- createSlotPool(JobID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DefaultSlotPoolFactory
-
- createSlotPool(JobID) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPoolFactory
-
- createSlotReport(ResourceID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
- createSnapshot() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
-
Creates a new snapshot of the available stats.
- createSnapshot() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
- createSolutionSetUpdateOutputCollector(Collector<OT>) - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
Creates a new solution set update output collector.
- createSSLClientSocketFactory(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
Creates a factory for SSL Client Sockets from the given configuration.
- createSSLServerSocketFactory(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
Creates a factory for SSL Server Sockets from the given configuration.
- createStateAndWrapWithTtlIfEnabled(TypeSerializer<N>, StateDescriptor<S, SV>, KeyedStateBackend<K>, TtlTimeProvider) - Static method in class org.apache.flink.runtime.state.ttl.TtlStateFactory
-
- createStateMap() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
-
- createStateMap() - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
-
- createStateMap() - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- createSubmittedJobGraphs(CuratorFramework, Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- createSubpartitionView(int, BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.ReleaseOnConsumptionResultPartition
-
- createSubpartitionView(int, BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Returns the requested subpartition.
- createSubpartitionView(ResultPartitionID, int, BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
-
- createSubpartitionView(ResultPartitionID, int, BufferAvailabilityListener) - Method in interface org.apache.flink.runtime.io.network.partition.ResultPartitionProvider
-
Returns the requested intermediate result partition input view.
- createTaskOwnedStateStream() - Method in interface org.apache.flink.runtime.state.CheckpointStorageWorkerView
-
Opens a stream to persist checkpoint state data that is owned strictly by tasks and
not attached to the life cycle of a specific checkpoint.
- createTaskOwnedStateStream() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
-
- createTaskOwnedStateStream() - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
-
- createTaskRegistry(JobID, JobVertexID) - Method in class org.apache.flink.runtime.query.KvStateRegistry
-
- createTerminationFutureOverAllConnectedVertexes() - Method in class org.apache.flink.runtime.executiongraph.failover.FailoverRegion
-
- createTmpFile(String, DistributedCache.DistributedCacheEntry, JobID, ExecutionAttemptID) - Method in class org.apache.flink.runtime.filecache.FileCache
-
If the file doesn't exists locally, retrieve the file from the blob-service.
- createUnregisteredJobManagerJobMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
-
- createUnregisteredJobManagerMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
-
- createUnregisteredOperatorMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
-
- createUnregisteredTaskManagerJobMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
-
- createUnregisteredTaskManagerMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
-
- createUnregisteredTaskMetricGroup() - Static method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups
-
- createWorkerSlotProfiles(Configuration) - Static method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- 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(CuratorFramework, String, RetrievableStateStorageHelper<T>) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- createZooKeeperStateHandleStore(String, RetrievableStateStorageHelper<T>) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
-
- CreditBasedInputBuffersUsageGauge - Class in org.apache.flink.runtime.io.network.metrics
-
Gauge metric measuring the input buffers usage for
SingleInputGate
s under credit based mode.
- CreditBasedInputBuffersUsageGauge(FloatingBuffersUsageGauge, ExclusiveBuffersUsageGauge, SingleInputGate[]) - Constructor for class org.apache.flink.runtime.io.network.metrics.CreditBasedInputBuffersUsageGauge
-
- CrossDriver<T1,T2,OT> - Class in org.apache.flink.runtime.operators
-
Cross task which is executed by a Task Manager.
- CrossDriver() - Constructor for class org.apache.flink.runtime.operators.CrossDriver
-
- crossMatchingGroup(Iterator<T1>, Iterator<T2>, FlatJoinFunction<T1, T2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- CURRENT_JOB_IDS_REST_PATH - Static variable in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
-
- CURRENT_STATE_META_INFO_SNAPSHOT_VERSION - Static variable in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshotReadersWriters
-
- 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
-
- 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.
- currentSchemaSerializer() - Method in class org.apache.flink.runtime.state.StateSerializerProvider
-
Gets the serializer that recognizes the current serialization schema of the state.
- currentTimestamp() - Method in interface org.apache.flink.runtime.state.ttl.TtlTimeProvider
-
- GarbageCollectorInfo(String, long, long) - Constructor for class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMetricsInfo.GarbageCollectorInfo
-
- garbageCollectorNames - Variable in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.TaskManagerMetricStore
-
- GatewayRetriever<T extends RpcGateway> - Interface in org.apache.flink.runtime.webmonitor.retriever
-
- gauge(int, G) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- gauge(String, G) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- gauge(int, G) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- gauge(String, G) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- GaugeDump(QueryScopeInfo, String, String) - Constructor for class org.apache.flink.runtime.metrics.dump.MetricDump.GaugeDump
-
- generate() - Static method in class org.apache.flink.runtime.clusterframework.types.ResourceID
-
Generate a random resource id.
- generate() - Static method in class org.apache.flink.runtime.dispatcher.DispatcherId
-
Generates a new random DispatcherId.
- generate() - Static method in class org.apache.flink.runtime.jobmaster.JobMasterId
-
Generates a new random JobMasterId.
- generate() - Static method in class org.apache.flink.runtime.resourcemanager.ResourceManagerId
-
Generates a new random ResourceManagerId.
- generate() - Static method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerSlotId
-
- generateCheckpointStatistics(AbstractCheckpointStats, boolean) - Static method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- generateEndpointIdWithUUID() - Method in interface org.apache.flink.runtime.dispatcher.DispatcherFactory
-
- generateEndpointIdWithUUID() - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerFactory
-
- generatePlan(JobGraph) - Static method in class org.apache.flink.runtime.jobgraph.jsonplan.JsonPlanGenerator
-
- generateRegistration() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
This method generate a specific Registration, for example TaskExecutor Registration at the ResourceManager.
- generateRegistration() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorToResourceManagerConnection
-
- generateSlotOffer() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
Generate the slot offer from this TaskSlot.
- generateTaskManagerConfiguration(Configuration, String, int, int, FiniteDuration) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Generate a task manager configuration.
- generateZookeeperPath(String, String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- GenericKeyMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
- GenericMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
A simple named MetricGroup
that is used to hold
subgroups of metrics.
- GenericMetricGroup(MetricRegistry, AbstractMetricGroup, String) - Constructor for class org.apache.flink.runtime.metrics.groups.GenericMetricGroup
-
- GenericValueMetricGroup - Class in org.apache.flink.runtime.metrics.groups
-
- get(JobID, BlobKey, File) - Method in interface org.apache.flink.runtime.blob.BlobView
-
Copies a blob to a local file.
- get(JobID, BlobKey, File) - Method in class org.apache.flink.runtime.blob.FileSystemBlobStore
-
- get(JobID, BlobKey, File) - Method in class org.apache.flink.runtime.blob.VoidBlobStore
-
- get() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
-
Atomically gets the current checkpoint ID.
- get() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
-
- get() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
-
- get() - Method in class org.apache.flink.runtime.concurrent.ScheduledFutureAdapter
-
- get(long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.ScheduledFutureAdapter
-
- get(JobID) - Method in interface org.apache.flink.runtime.dispatcher.ArchivedExecutionGraphStore
-
- get(JobID) - Method in class org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
-
- get(JobID) - Method in class org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
-
- get(String) - Method in class org.apache.flink.runtime.iterative.concurrent.Broker
-
Blocking retrieval and removal of the object to share.
- get() - Static method in class org.apache.flink.runtime.messages.Acknowledge
-
Gets the singleton instance.
- get(int) - Method in class org.apache.flink.runtime.operators.util.BitSet
-
Returns true if the bit is set in the specified index.
- get(int) - Method in class org.apache.flink.runtime.state.ChainedStateHandle
-
Get the state handle for a single operator in the operator chain by it's index.
- get() - Method in class org.apache.flink.runtime.state.DoneFuture
-
- get(long, TimeUnit) - Method in class org.apache.flink.runtime.state.DoneFuture
-
- get(K, N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
- get(K, N) - Method in class org.apache.flink.runtime.state.heap.NestedStateMap
-
- get(K, N) - Method in class org.apache.flink.runtime.state.heap.StateMap
-
Returns the state for the composite of active key and given namespace.
- get(N) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Returns the state of the mapping for the composite of active key and given namespace.
- get(K, N) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Returns the state for the composite of active key and given namespace.
- get(K) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
-
- get() - Method in class org.apache.flink.runtime.state.PartitionableListState
-
- get() - Static method in class org.apache.flink.runtime.state.VoidNamespace
-
Getter for the singleton instance
- get(JobID) - Method in class org.apache.flink.runtime.taskexecutor.JobManagerTable
-
- get() - Method in class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
-
- get() - Static method in class org.apache.flink.runtime.util.EmptyIterator
-
Gets a singleton instance of the empty iterator.
- get() - Static method in class org.apache.flink.runtime.util.EmptyMutableObjectIterator
-
Gets a singleton instance of the empty iterator.
- get(int) - Method in class org.apache.flink.runtime.util.EvictingBoundedList
-
- getAccumulatorRegistry() - Method in interface org.apache.flink.runtime.execution.Environment
-
Return the registry for accumulators which are periodically sent to the job manager.
- getAccumulatorRegistry() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getAccumulatorRegistry() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getAccumulatorResults() - Method in class org.apache.flink.runtime.jobmaster.JobResult
-
- getAccumulatorResultsStringified() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the aggregated user-defined accumulators as strings.
- getAccumulatorResultsStringified() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getAccumulatorResultsStringified() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Returns the a stringified version of the user-defined accumulators.
- getAccumulators() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
Gets flink and user-defined accumulators in serialized form.
- getAccumulatorSnapshots() - Method in class org.apache.flink.runtime.taskexecutor.AccumulatorReport
-
- getAccumulatorsSerialized() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns a map containing the serialized values of user-defined accumulators.
- getAccumulatorsSerialized() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getAccumulatorsSerialized() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Gets a serialized accumulator map.
- getAckTimestamp() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
-
Returns the timestamp when the acknowledgement of this subtask was
received at the coordinator.
- getAckTimestamp() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
-
- getAckTimestampStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
-
Returns the summary stats for the ACK timestamps.
- getAclForPath(String) - Method in class org.apache.flink.runtime.util.ZooKeeperUtils.SecureAclProvider
-
- getActiveSlots(JobID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Return an iterator of active slots (their application ids) for the given job id.
- getActorSystem() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- getActual() - Method in exception org.apache.flink.runtime.highavailability.LeaderIdMismatchException
-
- getAddress() - Method in class org.apache.flink.runtime.io.network.ConnectionID
-
- getAddress() - Method in exception org.apache.flink.runtime.io.network.netty.exception.TransportException
-
- getAddress() - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Return the address of the task manager with which the gateway is associated.
- getAddress() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
-
- getAddress() - Method in interface org.apache.flink.runtime.jobmaster.JobMasterService
-
Get the address of the JobMaster service under which it is reachable.
- getAddress() - Method in class org.apache.flink.runtime.jobmaster.ResourceManagerAddress
-
- getAddress() - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
-
- getAddress() - Method in interface org.apache.flink.runtime.leaderelection.LeaderContender
-
Returns the address of the
LeaderContender
under which other instances can connect
to it.
- getAddress() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
-
- getAddress() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- getAddress() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Gets the address of the underlying RPC endpoint.
- getAddress() - Method in interface org.apache.flink.runtime.rpc.RpcGateway
-
Returns the fully qualified address under which the associated rpc endpoint is reachable.
- getAddress() - Method in interface org.apache.flink.runtime.rpc.RpcService
-
Return the hostname or host address under which the rpc service can be reached.
- getAddress() - Method in class org.apache.flink.runtime.shuffle.ProducerDescriptor
-
- getAddress() - Method in class org.apache.flink.runtime.util.LeaderConnectionInfo
-
- getAddress() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
-
- getAggregatedUserAccumulatorsStringified() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
Returns the aggregated user-defined accumulators as strings.
- getAggregatedUserAccumulatorsStringified() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
-
- getAggregatedUserAccumulatorsStringified() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getAggregateJobVertexState(int[], int) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
A utility function that computes an "aggregated" state for the vertex.
- getAggregates() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
-
- getAggregates(ClassLoader) - Method in class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
-
- getAggregateState() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
- getAggregateState() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
-
- getAggregateState() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
-
- getAggregator(String) - Method in class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
-
- getAggregatorNames() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
-
- getAggregatorNames() - Method in class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
-
- getAkkaConfig() - Method in interface org.apache.flink.runtime.clusterframework.BootstrapTools.ActorSystemExecutorConfiguration
-
Create the executor Config
for the respective executor.
- getAkkaConfig() - Method in class org.apache.flink.runtime.clusterframework.BootstrapTools.FixedThreadPoolExecutorConfiguration
-
- getAkkaConfig() - Method in class org.apache.flink.runtime.clusterframework.BootstrapTools.ForkJoinExecutorConfiguration
-
- getAlignment() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
-
- getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the total buffered bytes during alignment over all subtasks.
- getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
-
- getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
-
- getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
-
- getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
-
Returns the number of bytes buffered during stream alignment (for
exactly-once only).
- getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
-
Returns the total buffered bytes during alignment over all subtasks.
- getAlignmentBuffered() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
-
- getAlignmentBuffered() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- getAlignmentBuffered() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
-
- getAlignmentBuffered() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- getAlignmentBufferedStats() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummary
-
Returns the summary stats for the bytes buffered during alignment.
- getAlignmentBufferedStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
-
Returns the summary stats for the buffered bytes during alignments.
- getAlignmentDuration() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
-
Returns the duration of the stream alignment (for exactly-once only).
- getAlignmentDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment
-
- getAlignmentDurationNanos() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- getAlignmentDurationStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
-
Returns the summary stats for the alignment duration.
- getAllAggregators() - Method in class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
-
- getAllAndLock() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Gets all available state handles from ZooKeeper and locks the respective state nodes.
- getAllCheckpoints() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
- getAllCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
-
- getAllCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
-
- getAllExecutionVertexIDs() - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.FailoverRegion
-
Returns IDs of all vertices in this region.
- getAllExecutionVertices() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns an iterable containing all execution vertices for this execution graph.
- getAllExecutionVertices() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getAllExecutionVertices() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getAllExecutionVertices() - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.FailoverRegion
-
Returns all vertices in this region.
- getAllInputEdges() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getAllInputGates() - Method in interface org.apache.flink.runtime.execution.Environment
-
- getAllInputGates() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getAllIntermediateResults() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getAllocatedSlotFuture() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl.PendingRequest
-
- getAllocatedSlotInfos() - Method in class org.apache.flink.runtime.jobmaster.AllocatedSlotReport
-
- getAllocatedSlots(JobID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Return an iterator of allocated slots for the given job id.
- getAllocationId() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
- getAllocationId() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
- getAllocationId() - Method in class org.apache.flink.runtime.instance.SharedSlot
-
- getAllocationId() - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
- getAllocationId() - Method in class org.apache.flink.runtime.instance.SimpleSlotContext
-
- getAllocationId() - Method in class org.apache.flink.runtime.jobmaster.AllocatedSlotInfo
-
- getAllocationId() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Gets the allocation id of this slot.
- getAllocationId() - Method in interface org.apache.flink.runtime.jobmaster.SlotInfo
-
Gets the id under which the slot has been allocated on the TaskManager.
- getAllocationId() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- getAllocationId() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
-
- getAllocationId() - Method in class org.apache.flink.runtime.resourcemanager.SlotRequest
-
Get the unique identification of this request
- getAllocationId() - Method in exception org.apache.flink.runtime.taskexecutor.exceptions.SlotOccupiedException
-
- getAllocationId() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotOffer
-
- getAllocationId() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
- getAllocationID() - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
-
Get the allocation id of this slot.
- getAllocationId() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getAllocationIdsPerJob(JobID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
- getAllocationTimeout() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getAllowQueuedScheduling() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- getAllPartitions() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getAllPaths() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Return a list of all valid paths for state handles.
- getAllSubtaskMetricStores() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.TaskMetricStore
-
- getAllTaskStateStats() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns all task state stats instances.
- getAllVariables() - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- getAllVariables() - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- getAllVertices() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns a map containing all job vertices for this execution graph.
- getAllVertices() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getAllVertices() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getAllWriters() - Method in interface org.apache.flink.runtime.execution.Environment
-
- getAllWriters() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getAlwaysParentFirstLoaderPatterns() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getAndIncrement() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
-
Atomically increments the current checkpoint ID.
- getAndIncrement() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
-
- getAndIncrement() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
-
- getAndLock(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
- getAndRemove(String) - Method in class org.apache.flink.runtime.iterative.concurrent.Broker
-
Blocking retrieval and removal of the object to share.
- getAndResetUnannouncedCredit() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
Gets the unannounced credit and resets it to 0 atomically.
- getAppConfigurationEntry(String) - Method in class org.apache.flink.runtime.security.DynamicConfiguration
-
Retrieve the AppConfigurationEntries for the specified name
from this Configuration.
- getApplicationStatus() - Method in class org.apache.flink.runtime.jobmaster.JobResult
-
- getArchivedExecutionConfig() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the ArchivedExecutionConfig
for this execution graph.
- getArchivedExecutionConfig() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getArchivedExecutionConfig() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Returns the serializable ArchivedExecutionConfig
.
- getArchivedJsons(Path) - Static method in class org.apache.flink.runtime.history.FsJobArchivist
-
- getArgs() - Method in class org.apache.flink.runtime.entrypoint.ClusterConfiguration
-
- getArgs() - Method in class org.apache.flink.runtime.rpc.messages.LocalRpcInvocation
-
- getArgs() - Method in class org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation
-
- getArgs() - Method in interface org.apache.flink.runtime.rpc.messages.RpcInvocation
-
Returns the arguments of the remote procedure call
- getArity() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-
- getArtifacts() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
-
Get the container artifacts.
- getAssignedAllocationID() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
-
- getAssignedAllocationID() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getAssignedPendingSlotRequest() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingTaskManagerSlot
-
- getAssignedPendingTaskManagerSlot() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
-
- 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
-
- getAssignedSlotRequest() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
- getAssignmentMode() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
-
- getAssignmentMode() - Method in class org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
-
- getAsyncCheckpointDuration() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
-
Returns the duration of the asynchronous part of the checkpoint.
- getAsyncCheckpointDurationStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
-
Returns the summary stats for the async checkpoint duration.
- getAsyncDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
-
- getAsyncDurationMillis() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- getAsyncExecutor() - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerServices
-
Gets the async executor which executes outside of the main thread of the ResourceManager
- getAsynchronousDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
-
- getAsyncOperationDescription() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationTriggerMessageHeaders
-
Returns the description for this async operation header.
- getAsyncOperationDescription() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
-
- getAsyncOperationDescription() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
-
- getAsyncOperationDescription() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
-
- getAsyncOperationDescription() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointTriggerHeaders
-
- getAttempt() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- getAttempt() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
-
- 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
-
- getAvailableJobDetails() - Method in interface org.apache.flink.runtime.dispatcher.ArchivedExecutionGraphStore
-
Return the collection of
JobDetails
of all currently stored jobs.
- getAvailableJobDetails(JobID) - Method in interface org.apache.flink.runtime.dispatcher.ArchivedExecutionGraphStore
-
- getAvailableJobDetails() - Method in class org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
-
- getAvailableJobDetails(JobID) - Method in class org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
-
- getAvailableJobDetails() - Method in class org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
-
- getAvailableJobDetails(JobID) - Method in class org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
-
- getAvailableSlotsInformation() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Returns a list of
SlotInfo
objects about all slots that are currently available in the slot
pool.
- getAvailableSlotsInformation() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
-
- getAverage() - Method in class org.apache.flink.runtime.checkpoint.MinMaxAvgStats
-
Calculates the average over all seen values.
- getAverage() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
-
- getAvg() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
-
- getBackendIdentifier() - Method in interface org.apache.flink.runtime.state.IncrementalKeyedStateHandle
-
Returns the identifier of the state backend from which this handle was created.
- getBackendIdentifier() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
-
- getBackendIdentifier() - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
-
- getBackendStateType() - Method in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
-
- getBackoffTime() - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.FailureRateRestartBackoffTimeStrategy
-
- getBackoffTime() - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.FixedDelayRestartBackoffTimeStrategy
-
- getBackoffTime() - Method in interface org.apache.flink.runtime.executiongraph.failover.flip1.RestartBackoffTimeStrategy
-
Returns the delay to do the restarting.
- getBackpressureLevel() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
-
- getBackpressureLevel() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
-
- getBackPressureRatio(int) - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
-
Returns the ratio of stack traces indicating back pressure to total
number of sampled stack traces.
- getBackPressureStatsTracker() - Method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
-
- getBasePath() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
- getBlobManagerPort() - Method in class org.apache.flink.runtime.jobmaster.message.ClassloadingProps
-
- getBlobServerHostname() - Method in class org.apache.flink.runtime.entrypoint.ClusterInformation
-
- getBlobServerPort(Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- getBlobServerPort(Time) - Method in interface org.apache.flink.runtime.dispatcher.DispatcherGateway
-
Returns the port of the blob server.
- getBlobServerPort() - Method in class org.apache.flink.runtime.entrypoint.ClusterInformation
-
- getBlobWriter() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getBlobWriter() - Method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
-
- getBlockCount() - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
-
Gets the number of blocks written by this output view.
- getBlockCount() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
-
Gets the number of blocks used by this view.
- getBlockCount() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
Gets the number of blocks used by this view.
- getBlockCount() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
- getBlockCount() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ChannelWithBlockCount
-
- getBlockingSubpartitionType() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
-
- getBroadcastGroupSize(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getBroadcastInputName(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getBroadcastInputSerializer(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getBroadcastState(MapStateDescriptor<K, V>) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- getBroadcastStateMetaInfoSnapshots() - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
-
- getBroadcastVariable(String) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
-
- getBroadcastVariableManager() - Method in interface org.apache.flink.runtime.execution.Environment
-
- getBroadcastVariableManager() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- getBroadcastVariableManager() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getBroadcastVariableWithInitializer(String, BroadcastVariableInitializer<T, C>) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
-
- getBuffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
-
- getBufferBuilder() - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
- getBufferBuilder() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getBufferBuilder() - Method in class org.apache.flink.runtime.taskmanager.ConsumableNotifyingResultPartitionWriterDecorator
-
- getBufferedData() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
-
- getBufferPool() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- getBufferPool() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getBufferProvider() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
- getBuildSideBlockCount() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- getBuildSideChannel() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- getBuildSideComparator() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
- getBuildSideIterator() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
- getBuildSideRecordCount() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- getBuildSideSerializer() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
- getBytes(int, ByteBuf, int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getBytes(int, byte[], int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getBytes(int, ByteBuffer) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getBytes(int, OutputStream, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getBytes(int, GatheringByteChannel, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getBytes(int, FileChannel, long, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getBytesBufferedInAlignment() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- getBytesInLatestSegment() - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
-
Gets the number of bytes written in the latest memory segment.
- getBytesMemoryUsed() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
Gets the number of bytes used by this output view, including written bytes and header bytes.
- getBytesRead() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
-
- getBytesWritten() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
-
Gets the number of pay-load bytes already written.
- getBytesWritten() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
-
- getCacheSize() - Method in class org.apache.flink.runtime.query.KvStateEntry
-
- getCallable() - Method in class org.apache.flink.runtime.rpc.messages.CallAsync
-
- getCapacity() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
Gets the total capacity of this hash table, in bytes.
- getCapacity() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- getCapacity() - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Gets the total capacity of this sorter, in bytes.
- getCapacity() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.MetricDump.CounterDump
-
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.MetricDump.GaugeDump
-
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.MetricDump
-
Returns the category for this MetricDump.
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
-
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.MetricDump.MeterDump
-
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
-
Returns the category for this QueryScopeInfo.
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobManagerQueryScopeInfo
-
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobQueryScopeInfo
-
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
-
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskManagerQueryScopeInfo
-
- getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
-
- getChainedStubConfig(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getChainedTask(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getChainedTaskName(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getChainLength() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getChannel() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractChannelReaderInputView
-
Get the underlying channel.
- getChannel() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
-
Get the underlying channel.
- getChannel() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
- getChannel() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ChannelWithBlockCount
-
- getChannelID() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
-
- getChannelID() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
-
Gets the channel ID of this I/O channel.
- getChannelIndex() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
-
- getCheckpointAlignment() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
-
- getCheckpointById(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
-
- getCheckpointCoordinator() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getCheckpointCoordinatorConfiguration() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
- getCheckpointCoordinatorConfiguration() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getCheckpointCoordinatorConfiguration() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getCheckpointCoordinatorConfiguration() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
-
- getCheckpointDirectory() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
-
- getCheckpointDirectoryForJob(Path, JobID) - Static method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
-
Builds directory into which a specific job checkpoints, meaning the directory inside which
it creates the checkpoint-specific subdirectories.
- getCheckpointDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
-
- getCheckpointDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
-
- getCheckpointFailureReason() - Method in exception org.apache.flink.runtime.checkpoint.CheckpointException
-
- getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the ID of this checkpoint.
- getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetaData
-
- getCheckpointID() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
-
Returns the ID of this checkpoint.
- getCheckpointId() - Method in interface org.apache.flink.runtime.checkpoint.savepoint.Savepoint
-
Returns the checkpoint ID of the savepoint.
- getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
-
- getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
-
- getCheckpointId() - Method in class org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
-
- getCheckpointId() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
-
- getCheckpointId() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- getCheckpointId() - Method in interface org.apache.flink.runtime.state.IncrementalKeyedStateHandle
-
Returns the ID of the checkpoint for which the handle was created.
- getCheckpointId() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
-
- getCheckpointId() - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
-
- getCheckpointId() - Method in interface org.apache.flink.runtime.state.ManagedSnapshotContext
-
Returns the ID of the checkpoint for which the snapshot is taken.
- getCheckpointId() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
-
- getCheckpointIdCounter() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- getCheckpointingSettings() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Gets the settings for asynchronous snapshots.
- getCheckpointInterval() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
-
- getCheckpointMetrics() - Method in class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
-
- getCheckpointOptions() - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
-
- getCheckpointOptions() - Method in class org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
-
- getCheckpointOutputStream() - Method in interface org.apache.flink.runtime.state.CheckpointStreamWithResultProvider
-
Returns the encapsulated output stream.
- getCheckpointOutputStream() - Method in class org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryAndSecondaryStream
-
- getCheckpointOutputStream() - Method in class org.apache.flink.runtime.state.CheckpointStreamWithResultProvider.PrimaryStreamOnly
-
- getCheckpointPath() - Method in class org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
-
Gets the checkpoint base directory.
- getCheckpointPath() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Gets the base directory where all the checkpoints are stored.
- getCheckpointRecoveryFactory() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the checkpoint recovery factory for the job manager
- getCheckpointRecoveryFactory() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
-
- getCheckpointRecoveryFactory() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getCheckpointResponder() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
-
- getCheckpointRetentionPolicy() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
-
- getCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
-
- getCheckpointsDirectory() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
-
- getCheckpointStatisticsPerTask() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- getCheckpointStatsSnapshot() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns a snapshot of the checkpoint statistics or null
if
checkpointing is disabled.
- getCheckpointStatsSnapshot() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getCheckpointStatsSnapshot() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getCheckpointStatus() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics
-
- getCheckpointStatus() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- getCheckpointStorage() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- getCheckpointStore() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- getCheckpointTimeout() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- getCheckpointTimeout() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
-
- getCheckpointTimestamp() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- getCheckpointTimestamp() - Method in interface org.apache.flink.runtime.state.ManagedSnapshotContext
-
Returns timestamp (wall clock time) when the master node triggered the checkpoint for which
the state snapshot is taken.
- getCheckpointTimestamp() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
-
- getCheckpointType() - Method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
-
Returns the type of checkpoint to perform.
- getCheckpointType() - Method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
-
Gets the type of the checkpoint (checkpoint / savepoint).
- getClassLoader(JobID) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
-
- getClassLoader(JobID) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
-
Returns the user code class loader associated with id.
- getClassLoaderResolveOrder() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getClasspaths() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- getCleanUpInterval() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTrackerImpl
-
Cleanup interval for completed stats cache.
- getClientChannelHandlers() - Method in class org.apache.flink.runtime.io.network.netty.NettyProtocol
-
Returns the client channel handlers.
- getClientConnectTimeoutSeconds() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getClientNumThreads() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getCloseFuture() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- getClusterInformation() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- getClusterInformation() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
-
Gets the cluster information.
- getCoLocationConstraint() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- getCoLocationConstraint() - Method in class org.apache.flink.runtime.scheduler.ExecutionVertexSchedulingRequirements
-
- getCoLocationGroup() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getCoLocationGroup() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getCommitId() - Method in class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
-
- getComparatorWithCurrentReference() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator
-
- getComparatorWithCurrentReference() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator
-
- getCompatibleVersions() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
-
- getCompatibleVersions() - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
-
- getCompletedCheckpointStatistics() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
-
- getCompletionFuture() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
Returns the completion future.
- getComponentMetricStore(HandlerRequest<EmptyRequestBody, M>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.AbstractMetricsHandler
-
Returns the MetricStore.ComponentMetricStore
that should be queried for metrics.
- getComponentMetricStore(HandlerRequest<EmptyRequestBody, JobManagerMetricsMessageParameters>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.JobManagerMetricsHandler
-
- getComponentMetricStore(HandlerRequest<EmptyRequestBody, JobMetricsMessageParameters>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.JobMetricsHandler
-
- getComponentMetricStore(HandlerRequest<EmptyRequestBody, JobVertexMetricsMessageParameters>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.JobVertexMetricsHandler
-
Deprecated.
- getComponentMetricStore(HandlerRequest<EmptyRequestBody, SubtaskMetricsMessageParameters>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.SubtaskMetricsHandler
-
- getComponentMetricStore(HandlerRequest<EmptyRequestBody, TaskManagerMetricsMessageParameters>, MetricStore) - Method in class org.apache.flink.runtime.rest.handler.job.metrics.TaskManagerMetricsHandler
-
- getCompressionDecorator(ExecutionConfig) - Static method in class org.apache.flink.runtime.state.AbstractStateBackend
-
- getConfig() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getConfigDir() - Method in class org.apache.flink.runtime.entrypoint.ClusterConfiguration
-
- getConfigDir() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- getConfigDir() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerCliOptions
-
- getConfiguration() - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
- getConfiguration() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns the vertex's configuration object which can be used to pass custom settings to the task at runtime.
- getConfiguration() - Method in class org.apache.flink.runtime.jobmaster.JobMasterConfiguration
-
- getConfiguration() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
-
- getConfiguration() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
Gets the configuration that holds the actual values encoded.
- getConfiguration() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcServiceConfiguration
-
- getConfiguration() - Method in class org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
-
- getConfiguration() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getConfiguration() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- getConfiguration() - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
-
Gets the configuration that the TaskManager was started with.
- getConnectionId() - Method in class org.apache.flink.runtime.shuffle.NettyShuffleDescriptor
-
- getConnectionId() - Method in enum org.apache.flink.runtime.shuffle.NettyShuffleDescriptor.LocalExecutionPartitionConnectionInfo
-
- getConnectionId() - Method in class org.apache.flink.runtime.shuffle.NettyShuffleDescriptor.NetworkPartitionConnectionInfo
-
- getConnectionId() - Method in interface org.apache.flink.runtime.shuffle.NettyShuffleDescriptor.PartitionConnectionInfo
-
- 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.NettyShuffleEnvironment
-
- getConnectionTimeout() - Method in class org.apache.flink.runtime.rest.RestClientConfiguration
-
RestOptions.CONNECTION_TIMEOUT
.
- getConsumedPartitionShuffleDescriptor(ExecutionEdge, boolean) - Static method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptorFactory
-
- getConsumedPartitionType() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
-
Returns the type of this input channel's consumed result partition.
- getConsumedPartitionType() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
Returns the type of this input channel's consumed result partition.
- getConsumedResultId() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
-
- getConsumedResultID() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGateID
-
- getConsumedResultId() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- getConsumedResultPartitions() - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingExecutionVertex
-
Get all consumed result partitions.
- getConsumedResultPartitionsProducers(ExecutionVertexID) - Method in class org.apache.flink.runtime.scheduler.ExecutionGraphToInputsLocationsRetrieverAdapter
-
- getConsumedResultPartitionsProducers(ExecutionVertexID) - Method in interface org.apache.flink.runtime.scheduler.InputsLocationsRetriever
-
Get the producers of the result partitions consumed by an execution.
- getConsumedSubpartitionIndex() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
-
- getConsumerExecutionState() - Method in interface org.apache.flink.runtime.io.network.partition.PartitionProducerStateProvider.ResponseHandle
-
- getConsumerID() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGateID
-
- getConsumers() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
-
- getConsumers() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
-
- getConsumers() - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingResultPartition
-
Gets the consumers of this result partition.
- getContainingTask() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getContainingTask() - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getContentType() - Method in class org.apache.flink.runtime.rest.FileUpload
-
- getConvergenceCriterion(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getConvergenceCriterionAggregatorName() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getCount() - Method in class org.apache.flink.runtime.checkpoint.MinMaxAvgStats
-
Returns the count of all seen values.
- getCount() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogram
-
- getCounts() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
-
Returns the snapshotted checkpoint counts.
- getCounts() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
-
- getCpuCores() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the cpu cores needed.
- getCpuIdle() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
-
- getCpuIrq() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
-
- getCpuLoad1() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
-
- getCpuLoad15() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
-
- getCpuLoad5() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
-
- getCpuNice() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
-
- getCpuSoftIrq() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
-
- getCpuSys() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
-
- getCpuUsage() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
-
- getCpuUsagePerProcessor(int) - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
-
- getCpuUser() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
-
- getCreationTimestamp() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
-
- getCurrent() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.ProbeIterator
-
- getCurrent() - Method in interface org.apache.flink.runtime.util.KeyGroupedIterator
-
- getCurrent() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator
-
- getCurrent() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator
-
- getCurrentAllocation(int) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Get the current allocation for the task slot with the given index.
- getCurrentAssignedResource() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getCurrentAssignedResourceLocation() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
- getCurrentAssignedResourceLocation() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
-
- getCurrentAssignedResourceLocation() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getCurrentBackoff() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Returns the current backoff in ms.
- getCurrentBuffer() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
-
- getCurrentBuffer() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
-
- getCurrentConfiguration() - Method in class org.apache.flink.runtime.security.modules.JaasModule
-
- getCurrentExecutionAttempt() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
Returns the current execution for this execution vertex.
- getCurrentExecutionAttempt() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
-
- getCurrentExecutionAttempt() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getCurrentKey() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- getCurrentKey() - Method in interface org.apache.flink.runtime.state.heap.InternalKeyContext
-
Used by states to access the current key.
- getCurrentKey() - Method in class org.apache.flink.runtime.state.heap.InternalKeyContextImpl
-
- getCurrentKey() - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
-
- getCurrentKeyGroup() - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
-
Returns the key group that is currently being written.
- getCurrentKeyGroupIndex() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- getCurrentKeyGroupIndex() - Method in interface org.apache.flink.runtime.state.heap.InternalKeyContext
-
Returns the key-group to which the current key belongs.
- getCurrentKeyGroupIndex() - Method in class org.apache.flink.runtime.state.heap.InternalKeyContextImpl
-
- getCurrentNumberOfSubtasks() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the current number of subtasks the respective task is split into.
- getCurrentOffset() - Method in class org.apache.flink.runtime.io.disk.SimpleCollectingOutputView
-
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.runtime.state.ArrayListSerializerSnapshot
-
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializerSnapshot
-
- getCurrentPositionInSegment() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Gets the position from which the next byte will be read.
- getCurrentPositionInSegment() - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
Gets the current write position (the position where the next bytes will be written)
in the current memory segment.
- getCurrentProbeRecord() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
- getCurrentRestartAttempt() - Method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
-
- getCurrentSegment() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Gets the memory segment that will be used to read the next bytes from.
- getCurrentSegment() - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
Gets the segment that the view currently writes to.
- getCurrentSegmentLimit() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Gets the current limit in the memory segment.
- getCurrentTaskManagerLocationFuture() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getData() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
-
- getDataPort() - Method in class org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
-
- getDataPort() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
-
- getDataPort() - Method in class org.apache.flink.runtime.shuffle.ProducerDescriptor
-
- getDefault() - Static method in class org.apache.flink.runtime.state.CheckpointStorageLocationReference
-
- getDefaultAcl() - Method in class org.apache.flink.runtime.util.ZooKeeperUtils.SecureAclProvider
-
- getDefaultElement() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
-
- getDefaultMimeType() - Static method in class org.apache.flink.runtime.rest.handler.util.MimeTypes
-
Gets the default MIME type, which is "application/octet-stream"
.
- getDefaultSavepointDirectory() - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
-
Gets the default directory for savepoints.
- getDefaultStateBackend() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
-
- getDefaultValue() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
- getDelay(TimeUnit) - Method in class org.apache.flink.runtime.concurrent.ScheduledFutureAdapter
-
- getDelegateStateHandle() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
-
- getDelegateStateHandle() - Method in interface org.apache.flink.runtime.state.OperatorStateHandle
-
Returns the underlying stream state handle that points to the state data.
- getDelegateStateHandle() - Method in class org.apache.flink.runtime.state.OperatorStreamStateHandle
-
- getDelimiter() - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
-
Returns the global delimiter.
- getDelimiter(int) - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
-
Returns the configured delimiter for the reporter with the given index.
- getDelimiter() - Method in class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
-
- getDelimiter() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
- getDelimiter(int) - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
- getDelimiter() - Method in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
-
- getDelimiter(int) - Method in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
-
- getDelimiter() - Method in class org.apache.flink.runtime.metrics.ReporterSetup
-
- getDeploymentOption() - Method in class org.apache.flink.runtime.scheduler.ExecutionVertexDeploymentOption
-
- getDescription() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationTriggerMessageHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.AccumulatorsIncludeSerializedValueQueryParameter
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointIdPathParameter
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedJobMetricsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedSubtaskMetricsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedTaskManagerMetricsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobsFilterQueryParameter
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexMetricsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricsFilterParameter
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtasksFilterQueryParameter
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagersFilterQueryParameter
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskAttemptPathParameter
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobCancellationHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobIDPathParameter
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobVertexIdPathParameter
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
-
- getDescription() - Method in interface org.apache.flink.runtime.rest.messages.MessageHeaders
-
Returns the description for this header.
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Returns a description for REST API HTML documentation.
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.RescalingParallelismQueryParameter
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.SubtaskIndexPathParameter
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerIdPathParameter
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
-
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter
-
Deprecated.
- getDescription() - Method in class org.apache.flink.runtime.rest.messages.TriggerIdPathParameter
-
- getDirectMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the direct memory needed in MB.
- getDirectMemoryStatsAsString(BufferPoolMXBean) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
-
Returns a String with the direct memory footprint.
- getDirectory() - Method in class org.apache.flink.runtime.state.DirectoryStateHandle
-
- getDirectory() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
-
- getDirectoryStateHandle() - Method in class org.apache.flink.runtime.state.DirectoryKeyedStateHandle
-
- getDispatcher() - Method in class org.apache.flink.runtime.entrypoint.component.DispatcherResourceManagerComponent
-
- getDispatcherGatewayFuture() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- getDispatcherLeaderElectionService() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the leader election service for the cluster's dispatcher.
- getDispatcherLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
-
- getDispatcherLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
- getDispatcherLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getDispatcherLeaderRetriever() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the leader retriever for the dispatcher.
- getDispatcherLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
-
- getDispatcherLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
- getDispatcherLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getDispatcherResourceManagerComponents() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- getDistributedCacheEntries() - Method in interface org.apache.flink.runtime.execution.Environment
-
- getDistributedCacheEntries() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getDistributionMode() - Method in class org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
-
- getDistributionPattern() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Returns the distribution pattern used for this edge.
- getDriver() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getDriverClass() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
-
- getDriverComparator(int) - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getDriverComparator(int) - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getDriverComparator(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getDriverStrategy() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getDuration() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getDuration() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
-
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
-
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment
-
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
-
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- getDynamicConfiguration() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
-
Get the dynamic configuration.
- getDynamicProperties() - Method in class org.apache.flink.runtime.entrypoint.ClusterConfiguration
-
- getElementsCollectedAndReset() - Method in class org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
-
- getElementSerializer() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- getElementSerializer() - Method in class org.apache.flink.runtime.state.RegisteredPriorityQueueStateBackendMetaInfo
-
- getEndKeyGroup() - Method in class org.apache.flink.runtime.state.KeyGroupRange
-
- getEndOffsetExclusive() - Method in class org.apache.flink.runtime.state.BoundedInputStream
-
- getEndpointId() - Method in interface org.apache.flink.runtime.dispatcher.DispatcherFactory
-
- getEndpointId() - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerFactory
-
- getEndpointId() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Returns the rpc endpoint's identifier.
- getEndTime() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getEndTime() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSample
-
Returns the time stamp, when all stack traces were collected at the
JobManager.
- getEndTime() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- getEndTime() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- getEndTime() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- getEndTimestamp() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
-
Returns the time stamp, when all stack traces were collected at the
JobManager.
- getEndTimestamp() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
-
- getEndToEndDuration() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the duration of this checkpoint calculated as the time since
triggering until the latest acknowledged subtask or -1
if
no subtask was acknowledged yet.
- getEndToEndDuration() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
-
Returns the end to end duration until the checkpoint failure.
- getEndToEndDuration(long) - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
-
Computes the duration since the given trigger timestamp.
- getEndToEndDuration(long) - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
-
Returns the duration of this checkpoint at the task/operator calculated
as the time since triggering until the latest acknowledged subtask
or -1
if no subtask was acknowledged yet.
- getEndToEndDurationStats() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummary
-
Returns the summary stats for the duration of completed checkpoints.
- getEntryIterator() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
- getEntryIterator() - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
-
- getEntryIterator() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
Returns an iterator that can be used to iterate over all the elements in the table.
- getEnvironment() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the environment of this task.
- getEnvironmentVariables() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
-
Get the environment variables.
- getError() - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.FailureHandlingResult
-
Returns reason why the restarting cannot be conducted.
- getError(ClassLoader) - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
Gets the attached exception, which is in serialized form.
- getErrorDelayMillis() - Method in class org.apache.flink.runtime.registration.RetryingRegistrationConfiguration
-
- getEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
-
- getEventPublisher() - Method in class org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
-
- getException() - Method in class org.apache.flink.runtime.executiongraph.ErrorInfo
-
Returns the serialized form of the original exception.
- getExceptionAsString() - Method in class org.apache.flink.runtime.executiongraph.ErrorInfo
-
Returns the contained exception as a string.
- getExecutingThread() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
If the invokable implementation executes user code in a thread other than,
Task.getExecutingThread()
, this method returns that executing thread.
- 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
-
- getExecutionAttemptID() - Method in class org.apache.flink.runtime.shuffle.ShuffleIOOwnerContext
-
- getExecutionConfig() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the job specific ExecutionConfig
.
- getExecutionConfig() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the global ExecutionConfig.
- getExecutionConfig() - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getExecutionConfig() - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- getExecutionConfig() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getExecutionConfigInfo() - Method in class org.apache.flink.runtime.rest.messages.JobConfigInfo
-
- getExecutionGraph() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getExecutionGraph(JobID) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- getExecutionGraph(JobID, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.legacy.ExecutionGraphCache
-
- 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.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- getExecutionState() - Method in class org.apache.flink.runtime.taskmanager.Task
-
Returns the current execution state of the task.
- getExecutionState() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
Returns the new execution state of the task.
- getExecutionVertexID() - Method in interface org.apache.flink.runtime.executiongraph.failover.flip1.FailoverVertex
-
Returns the ID of this vertex.
- getExecutionVertexId() - Method in class org.apache.flink.runtime.scheduler.ExecutionVertexDeploymentOption
-
- getExecutionVertexId() - Method in class org.apache.flink.runtime.scheduler.ExecutionVertexSchedulingRequirements
-
- getExecutionVertexId() - Method in class org.apache.flink.runtime.scheduler.ExecutionVertexVersion
-
- getExecutionVertexId() - Method in class org.apache.flink.runtime.scheduler.SlotExecutionVertexAssignment
-
- getExecutionVertexIds() - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.partitionrelease.PipelinedRegion
-
- getExecutionVertexName() - Method in interface org.apache.flink.runtime.executiongraph.failover.flip1.FailoverVertex
-
Returns the name of this vertex.
- getExecutor() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- getExecutor() - Method in interface org.apache.flink.runtime.rpc.RpcService
-
Gets the executor, provided by this RPC service.
- getExpected() - Method in exception org.apache.flink.runtime.highavailability.LeaderIdMismatchException
-
- getExtendedResources() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the extended resources.
- getExternalPath() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
-
Returns the external pointer of this checkpoint.
- getExternalPath() - Method in class org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
-
Returns the external path if this checkpoint was persisted externally.
- getExternalPath() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
-
- getExternalPath() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.CompletedCheckpointStatistics
-
- getExternalPointer() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getExternalPointer() - Method in interface org.apache.flink.runtime.state.CompletedCheckpointStorageLocation
-
Gets the external pointer to the checkpoint.
- getExternalPointer() - Method in class org.apache.flink.runtime.state.filesystem.FsCompletedCheckpointStorageLocation
-
- getFailedCheckpointStatistics() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
-
- getFailoverRegion(ExecutionVertexID) - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy
-
Returns the failover region that contains the given execution vertex.
- getFailoverRegion(ExecutionVertex) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
-
Finds the failover region that contains the given execution vertex.
- getFailoverStrategy() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Gets the failover strategy used by the execution graph to recover from failures of tasks.
- getFailoverVertices() - Method in class org.apache.flink.runtime.executiongraph.failover.adapter.DefaultFailoverTopology
-
- getFailoverVertices() - Method in interface org.apache.flink.runtime.executiongraph.failover.flip1.FailoverTopology
-
Returns an iterable over all vertices, topologically sorted.
- getFailureCause() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getFailureCause() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getFailureCause() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getFailureCause() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
- getFailureCause() - Method in class org.apache.flink.runtime.io.network.partition.NoOpResultSubpartitionView
-
- getFailureCause() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getFailureCause() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
-
- getFailureCause() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationInfo
-
- getFailureCause() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointInfo
-
- getFailureCause() - Method in class org.apache.flink.runtime.taskmanager.Task
-
If the task has failed, this method gets the exception that caused this task to fail.
- getFailureCauseAsString() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
Returns the exception that caused the job to fail.
- getFailureCauseAsString() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
Returns the exception that caused the job to fail.
- getFailureCauseAsString() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
-
- getFailureCauseAsString() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
-
- getFailureCauseAsString() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getFailureCauseAsString() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getFailureHandlingResult(ExecutionVertexID, Throwable) - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.ExecutionFailureHandler
-
Return result of failure handling.
- getFailureInfo() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the exception that caused the job to fail.
- getFailureInfo() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getFailureInfo() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getFailureMessage() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
-
Returns the failure message or null
if no cause was provided.
- getFailureMessage() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.FailedCheckpointStatistics
-
- getFailureTimestamp() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
-
Returns the timestamp when this checkpoint failed.
- getFailureTimestamp() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.FailedCheckpointStatistics
-
- getFencingToken() - Method in class org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
-
- getFencingToken() - Method in class org.apache.flink.runtime.rpc.FencedRpcEndpoint
-
- getFencingToken() - Method in interface org.apache.flink.runtime.rpc.FencedRpcGateway
-
Get the current fencing token.
- getFencingToken() - Method in interface org.apache.flink.runtime.rpc.messages.FencedMessage
-
- getFencingToken() - Method in class org.apache.flink.runtime.rpc.messages.LocalFencedMessage
-
- getFencingToken() - Method in class org.apache.flink.runtime.rpc.messages.RemoteFencedMessage
-
- getField(TtlValue<T>, int) - Method in class org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
-
- getFile(TransientBlobKey) - Method in class org.apache.flink.runtime.blob.BlobServer
-
Retrieves the local path of a (job-unrelated) file associated with a job and a blob key.
- getFile(JobID, TransientBlobKey) - Method in class org.apache.flink.runtime.blob.BlobServer
-
Retrieves the local path of a file associated with a job and a blob key.
- getFile(JobID, PermanentBlobKey) - Method in class org.apache.flink.runtime.blob.BlobServer
-
Returns the path to a local copy of the file associated with the provided job ID and blob
key.
- getFile(JobID, PermanentBlobKey) - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
-
Returns the path to a local copy of the file associated with the provided job ID and blob
key.
- getFile(JobID, PermanentBlobKey) - Method in interface org.apache.flink.runtime.blob.PermanentBlobService
-
Returns the path to a local copy of the file associated with the provided job ID and blob
key.
- getFile(TransientBlobKey) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
-
- getFile(JobID, TransientBlobKey) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
-
- getFile(TransientBlobKey) - Method in interface org.apache.flink.runtime.blob.TransientBlobService
-
Returns the path to a local copy of the (job-unrelated) file associated with the provided
blob key.
- getFile(JobID, TransientBlobKey) - Method in interface org.apache.flink.runtime.blob.TransientBlobService
-
Returns the path to a local copy of the file associated with the provided job ID and blob
key.
- getFile() - Method in class org.apache.flink.runtime.rest.FileUpload
-
- getFileChannel() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileSegment
-
- getFilehandlesDriver() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getFilehandlesInput(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getFileInternal(JobID, BlobKey) - Method in class org.apache.flink.runtime.blob.AbstractBlobCache
-
Returns local copy of the file for the BLOB with the given key.
- getFileInternal(JobID, BlobKey) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
-
- getFilePath() - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
-
Gets the path where this handle's state is stored.
- getFileSystem() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
-
- getFilterStrategy() - Method in interface org.apache.flink.runtime.state.StateSnapshotTransformer.CollectionStateSnapshotTransformer
-
- getFlinkConfig() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
-
- getFlinkRevision() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
-
- getFlinkVersion() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
-
- getFoldingState(FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
-
- getForForwardExchange(ExecutionMode) - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
-
- getFormatDescription(OperatorID) - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatVertex
-
- 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
-
- getFullSegments() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBulkBlockReader
-
- getFullSegments() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BulkBlockChannelReader
-
- getFuture() - Method in class org.apache.flink.runtime.registration.RetryingRegistration
-
- getFuture() - Method in interface org.apache.flink.runtime.webmonitor.retriever.GatewayRetriever
-
Get future of object to retrieve.
- getFuture() - Method in class org.apache.flink.runtime.webmonitor.retriever.LeaderGatewayRetriever
-
- getFutureExecutor() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Returns the ExecutionContext associated with this ExecutionGraph.
- getGarbageCollectorStatsAsString(List<GarbageCollectorMXBean>) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
-
Gets the garbage collection statistics from the JVM.
- getGateway() - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- getGateway() - Method in interface org.apache.flink.runtime.jobmaster.JobMasterService
-
- getGlobalAggregateManager() - Method in interface org.apache.flink.runtime.execution.Environment
-
- getGlobalAggregateManager() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
-
- getGlobalAggregateManager() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getGlobalModVersion() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Gets the global modification version of the execution graph when this execution was created.
- getGlobalModVersion() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Gets the current global modification version of the ExecutionGraph.
- getGraph() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getGroupID() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the ID that identifies the logical group to which this slot belongs:
If the slot does not belong to any group in particular, this field is null.
If this slot was allocated as a sub-slot of a
SlotSharingGroupAssignment
,
then this ID will be the JobVertexID of the vertex whose task the slot
holds in its shared slot.
In case that the slot represents the shared slot of a co-location constraint, this ID will be the
ID of the co-location constraint.
- getGroupId() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
-
Gets the ID that identifies the co-location group.
- getGroupId() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.TaskSlot
-
- getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Returns the name for this group, meaning what kind of entity it represents, for example "taskmanager".
- getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.GenericMetricGroup
-
- getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
-
- getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.JobMetricGroup
-
- getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
-
- getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
-
- getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- getGroupRangeOffsets() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
-
- getGroupSize(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getHadoopUser() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Gets the name of the user that is running the JVM.
- getHadoopVersionString() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
- getHandleName() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
-
- getHandlers() - Method in enum org.apache.flink.runtime.webmonitor.WebMonitorExtension.EmptyWebMonitorExtension
-
- getHandlers() - Method in interface org.apache.flink.runtime.webmonitor.WebMonitorExtension
-
- getHardwareDescription() - Method in class org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
-
- getHardwareDescription() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
-
- getHash() - Method in class org.apache.flink.runtime.blob.BlobKey
-
Returns the hash component of this key.
- getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - Method in class org.apache.flink.runtime.operators.hash.HashJoinIteratorBase
-
- getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstReOpenableHashJoinIterator
-
- getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondReOpenableHashJoinIterator
-
- getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstReOpenableHashJoinIterator
-
- getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondReOpenableHashJoinIterator
-
- getHeadElementIndex() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
-
Returns the start index of the queue elements in the array.
- getHeadElementIndex() - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueue
-
- getHeaderLength() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- getHeaderLength() - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
- getHeapMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the heap memory needed in MB.
- getHeartbeatTarget() - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatMonitor
-
Gets heartbeat target.
- getHeartbeatTarget() - Method in class org.apache.flink.runtime.heartbeat.HeartbeatMonitorImpl
-
- getHeartbeatTargetId() - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatMonitor
-
Gets heartbeat target id.
- getHeartbeatTargetId() - Method in class org.apache.flink.runtime.heartbeat.HeartbeatMonitorImpl
-
- getHighAvailabilityServices() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- getHistory() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
-
Returns the snapshotted checkpoint history.
- getHistory() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
-
- getHistoryServerURL(Configuration) - Static method in enum org.apache.flink.runtime.webmonitor.history.HistoryServerUtils
-
- getHost() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- getHost() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- getHostAddress() - Method in class org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
-
- getHostname(RpcService) - Method in class org.apache.flink.runtime.entrypoint.component.AbstractDispatcherResourceManagerComponentFactory
-
- getHostname() - Method in class org.apache.flink.runtime.entrypoint.EntrypointClusterConfiguration
-
- getHostname() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Gets the hostname of the underlying RPC endpoint.
- getHostname() - Method in interface org.apache.flink.runtime.rpc.RpcGateway
-
Returns the fully qualified hostname under which the associated rpc endpoint is reachable.
- getHostname() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
Gets the hostname of the TaskManager.
- getHostName(InetAddress) - Static method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
-
Gets the hostname of the TaskManager based on the network address.
- getHostname() - Method in class org.apache.flink.runtime.util.LeaderConnectionInfo
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.handler.legacy.files.LogFileHandlerSpecification
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.handler.legacy.files.StdoutFileHandlerSpecification
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.handler.legacy.files.WebContentHandlerSpecification
-
- getHttpMethod() - Method in interface org.apache.flink.runtime.rest.handler.RestHandlerSpecification
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointTriggerHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobCancellationHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerStdoutFileHeaders
-
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.YarnCancelJobTerminationHeaders
-
Deprecated.
- getHttpMethod() - Method in class org.apache.flink.runtime.rest.messages.YarnStopJobTerminationHeaders
-
Deprecated.
- getHttpResponseStatus() - Method in exception org.apache.flink.runtime.rest.handler.RestHandlerException
-
- getHttpResponseStatus() - Method in exception org.apache.flink.runtime.rest.util.RestClientException
-
- getID() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getId() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- getId() - Method in class org.apache.flink.runtime.instance.Instance
-
- getId() - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
-
- getId() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
-
- getID() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns the ID of this job vertex.
- getId() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
-
Gets the ID that identifies this co-location group.
- getId() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
-
- getId() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- getId() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
-
- getId() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.Metric
-
- getId() - Method in class org.apache.flink.runtime.rest.messages.queue.QueueStatus
-
- getId() - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingExecutionVertex
-
Gets id of the execution vertex.
- getId() - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingResultPartition
-
Gets id of the result partition.
- getID() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
Returns the ID of the task this result belongs to
- getIdAlternatives() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns a list of all alternative IDs of this job vertex.
- getIdentifier() - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
-
Gets the identifier of this hook.
- getIdlenessTimeout() - Method in class org.apache.flink.runtime.rest.RestClientConfiguration
-
RestOptions.IDLENESS_TIMEOUT
.
- getIdleSince() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
-
- getImplicitConvergenceCriterion(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getImplicitConvergenceCriterionAggregatorName() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getIndex() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics
-
- getIndex() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
- getIndexInSubtaskGroup() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the index of this subtask in the subtask group.
- getInfoForCurrentThread() - Method in class org.apache.flink.runtime.query.KvStateEntry
-
- getInitialCredit() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
- getInitialRegistrationPause() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getInitialRegistrationTimeoutMillis() - Method in class org.apache.flink.runtime.registration.RetryingRegistrationConfiguration
-
- getInitialTableSize(int, int, int, int) - Static method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
- getInput(int) - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getInput(int) - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getInputChannelId() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
- getInputChannels() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- getInputComparator(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getInputDependencyConstraint() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getInputDependencyConstraint() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getInputDependencyConstraint() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getInputDependencyConstraint() - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingExecutionVertex
-
Get InputDependencyConstraint
.
- getInputEdges(int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getInputEdges() - Method in interface org.apache.flink.runtime.executiongraph.failover.flip1.FailoverVertex
-
Returns all input edges of this vertex.
- getInputFormats() - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer.FormatUserCodeTable
-
- getInputFormats() - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
-
- getInputGate(int) - Method in interface org.apache.flink.runtime.execution.Environment
-
- getInputGate(InputGateID) - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
- getInputGate(int) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getInputGates() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
- getInputGroup() - Method in class org.apache.flink.runtime.shuffle.ShuffleIOOwnerContext
-
- getInputLocalStrategy(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getInputNum() - Method in class org.apache.flink.runtime.executiongraph.ExecutionEdge
-
- getInputs() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getInputs() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getInputSerializer(int) - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getInputSerializer(int) - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getInputSerializer(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getInputSplitData() - Method in class org.apache.flink.runtime.jobmaster.SerializedInputSplit
-
- getInputSplitProvider() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the input split provider assigned to this environment.
- getInputSplitProvider() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getInputSplitSource() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getInstalledContext() - Static method in class org.apache.flink.runtime.security.SecurityUtils
-
- getInstalledModules() - Static method in class org.apache.flink.runtime.security.SecurityUtils
-
- getInstance() - Static method in class org.apache.flink.runtime.blob.VoidBlobWriter
-
- getInstance() - 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
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.LogFileHandlerSpecification
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.StdoutFileHandlerSpecification
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.WebContentHandlerSpecification
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.EmptyMessageParameters
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.EmptyRequestBody
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.EmptyResponseBody
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedJobMetricsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedSubtaskMetricsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedTaskManagerMetricsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexMetricsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointTriggerHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobCancellationHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerStdoutFileHeaders
-
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.YarnCancelJobTerminationHeaders
-
Deprecated.
- getInstance() - Static method in class org.apache.flink.runtime.rest.messages.YarnStopJobTerminationHeaders
-
Deprecated.
- getInstance() - Static method in class org.apache.flink.runtime.util.clock.SystemClock
-
- getInstanceId() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
- getInstanceID() - Method in class org.apache.flink.runtime.resourcemanager.registration.TaskExecutorConnection
-
- getInstanceId() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
-
- getIntermediateDataSetID() - Method in class org.apache.flink.runtime.executiongraph.PartitionInfo
-
- getIntermediateResult() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
-
- getInternal() - Method in interface org.apache.flink.runtime.state.internal.InternalAppendingState
-
Get internally stored value.
- getInternalIndex() - Method in interface org.apache.flink.runtime.state.heap.HeapPriorityQueueElement
-
- getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.DirectoryKeyedStateHandle
-
- getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
-
- getIntersection(KeyGroupRange) - Method in interface org.apache.flink.runtime.state.KeyedStateHandle
-
Returns a state over a range that is the intersection between this
handle's key-group range and the provided key-group range.
- getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.KeyGroupRange
-
Create a range that represent the intersection between this range and the given range.
- getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
-
Returns a key-group range with offsets which is the intersection of the internal key-group range with the given
key-group range.
- getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
-
- getIntervalSettings() - Method in class org.apache.flink.runtime.metrics.ReporterSetup
-
- getInvokableClass(ClassLoader) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns the invokable class which represents the task of this vertex
- getInvokableClassName() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
-
- getInvokableClassName() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns the name of the invokable class which represents the task of this vertex.
- 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.taskexecutor.TaskManagerServices
-
- getIOManager() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getIOMetricGroup() - Method in class org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
-
Returns the OperatorIOMetricGroup for this operator.
- getIOMetricGroup() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
Returns the TaskIOMetricGroup for this task.
- getIOMetrics() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
- getIOMetrics() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
-
- getIOMetrics() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getIOMetrics() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- getIOMetrics() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
- getIoMetricsInfo() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- getIOWait() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
-
- getIsSolutionSetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getIsSolutionSetUpdateWithoutReprobe() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getIsWorksetIteration() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getIsWorksetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getIterationAggregators() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- getIterationAggregators(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getIterationHeadFinalOutputConfig() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getIterationHeadIndexOfSyncOutput() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getIterationHeadPartialSolutionOrWorksetInputIndex() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getIterationHeadSolutionSetInputIndex() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getIterationId() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getIterator() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
Gets an iterator over all records in this buffer in their logical order.
- getIterator() - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Gets an iterator over all records in this buffer in their logical order.
- getIterator() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
Gets an iterator over all records in this buffer in their logical order.
- getIterator() - Method in interface org.apache.flink.runtime.operators.sort.Sorter
-
- getIterator() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
- getIterator() - Method in class org.apache.flink.runtime.operators.TempBarrier
-
This method resets the input!
- getIterator() - Method in interface org.apache.flink.runtime.operators.util.CloseableInputProvider
-
Gets the iterator over this input.
- getIterator() - Method in class org.apache.flink.runtime.operators.util.SimpleCloseableInputProvider
-
- getJob() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
-
- getJobAccumulators() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
-
- getJobCheckpointingConfiguration() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
-
Returns the job's checkpointing configuration which is derived from the
CheckpointConfig.
- getJobConfiguration() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the job-wide configuration object that was attached to the JobGraph.
- getJobConfiguration() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getJobConfiguration() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
-
- getJobConfiguration() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns the configuration object for this job.
- getJobConfiguration() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the job configuration object which was attached to the original
JobGraph
.
- getJobConfiguration() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getJobConfiguration() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getJobExecutionResult() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
-
- getJobGraph() - Method in class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
-
- getJobGraph() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
-
- getJobID() - Method in class org.apache.flink.runtime.accumulators.AccumulatorSnapshot
-
- getJobId() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getJobId() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- getJobID() - Method in exception org.apache.flink.runtime.client.JobExecutionException
-
- getJobId() - Method in class org.apache.flink.runtime.client.JobStatusMessage
-
- getJobId() - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
-
- getJobId() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
- getJobId() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Returns the task's job ID.
- getJobID() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the ID of the job that the task belongs to.
- getJobID() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the JobID
for this execution graph.
- getJobID() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getJobID() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getJobId() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getJobId() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getJobId() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
-
- getJobID() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns the ID of the job.
- getJobId() - Method in class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
-
Returns the
JobID
of the submitted
JobGraph
.
- getJobId() - Method in class org.apache.flink.runtime.jobmaster.AllocatedSlotReport
-
- getJobId() - Method in class org.apache.flink.runtime.jobmaster.JobResult
-
- getJobId() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getJobId() - Method in class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview.JobIdWithStatus
-
- getJobId() - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Returns the JobID the KvState instances belong to.
- getJobId() - Method in class org.apache.flink.runtime.query.KvStateMessage.LookupKvStateLocation
-
Returns the JobID the KvState instance belongs to.
- getJobId() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
-
Returns the JobID the KvState instance belongs to.
- getJobId() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
-
Returns the JobID the KvState instance belongs to.
- getJobID() - Method in class org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
-
- getJobId() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
-
- getJobId() - Method in class org.apache.flink.runtime.resourcemanager.SlotRequest
-
Get the JobID of the slot requested for.
- getJobId() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- getJobId() - Method in class org.apache.flink.runtime.rest.messages.JobConfigInfo
-
- getJobId() - Method in exception org.apache.flink.runtime.taskexecutor.exceptions.SlotOccupiedException
-
- getJobID() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
-
- getJobId() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
- getJobID() - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
-
Get the job id of the slot allocated for.
- getJobID() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getJobID() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getJobID() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
-
The ID of the job the task belongs to
- getJobIds() - Method in class org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
-
- getJobIds() - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
-
- getJobIds() - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
-
Get all job ids of submitted job graphs to the submitted job graph store.
- getJobIds() - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
-
- getJobInformationOrBlobKey() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getJobLeaderIdService() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
-
- getJobLeaderService() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- getJobManager() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
- getJobManagerAddress(Configuration) - Static method in class org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
-
Returns the JobManager's hostname and port extracted from the given
Configuration
.
- getJobManagerBindAddress() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
-
- getJobManagerFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
-
- getJobManagerGateway() - Method in class org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
-
- getJobManagerGateway() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
-
- getJobManagerJobFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
-
- getJobManagerLeaderElectionService(JobID) - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the leader election service for the given job.
- getJobManagerLeaderElectionService(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
-
- getJobManagerLeaderElectionService(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
- getJobManagerLeaderElectionService(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getJobManagerLeaderRetriever(JobID) - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
- getJobManagerLeaderRetriever(JobID, String) - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the leader retriever for the job JobMaster which is responsible for the given job
- getJobManagerLeaderRetriever(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
-
- getJobManagerLeaderRetriever(JobID, String) - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
-
- getJobManagerLeaderRetriever(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
- getJobManagerLeaderRetriever(JobID, String) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
- getJobManagerLeaderRetriever(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getJobManagerLeaderRetriever(JobID, String) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getJobManagerManagedKeyedState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns the managed keyed state from the job manager, which represents the ground truth about what this state
should represent.
- getJobManagerManagedOperatorState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns the managed operator state from the job manager, which represents the ground truth about what this state
should represent.
- getJobManagerMetricStore() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
- getJobManagerMode() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- getJobManagerOwnedSnapshot() - Method in class org.apache.flink.runtime.state.SnapshotResult
-
- getJobManagerRawKeyedState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns the raw keyed state from the job manager, which represents the ground truth about what this state
should represent.
- getJobManagerRawOperatorState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns the raw operator state from the job manager, which represents the ground truth about what this state
should represent.
- getJobManagerResourceID() - Method in class org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
-
- getJobManagerTable() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- getJobMasterId() - Method in class org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
-
- getJobMasterId() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
-
- getJobMasterMainThreadExecutor() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getJobMetricStore(String) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
- getJobName() - Method in class org.apache.flink.runtime.client.JobStatusMessage
-
- getJobName() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the job name for the execution graph.
- getJobName() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getJobName() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getJobName() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
-
- getJobName() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getJobName() - Method in class org.apache.flink.runtime.rest.messages.JobConfigInfo
-
- getJobs() - Method in class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
-
- getJobs() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
- getJobSchedulingStatus(JobID) - Method in class org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
-
- getJobSchedulingStatus(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
-
- getJobSchedulingStatus(JobID) - Method in interface org.apache.flink.runtime.highavailability.RunningJobsRegistry
-
Gets the scheduling status of a job.
- getJobSchedulingStatus(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperRunningJobsRegistry
-
- getJobState() - Method in class org.apache.flink.runtime.client.JobStatusMessage
-
- getJobStatus() - Method in class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview.JobIdWithStatus
-
- getJobStatus(JobID) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- getJobStatus() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- getJobsWithStatus() - Method in class org.apache.flink.runtime.messages.webmonitor.JobIdsWithStatusOverview
-
- getJobTerminationFuture() - Method in class org.apache.flink.runtime.dispatcher.MiniDispatcher
-
- getJobTimeout() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
-
- getJobVertex(JobVertexID) - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
- getJobVertex(JobVertexID) - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getJobVertex(JobVertexID) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getJobVertex() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getJobVertex() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getJobVertexID() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getJobVertexId() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
-
Returns the ID of the operator the statistics belong to.
- getJobVertexId() - Method in interface org.apache.flink.runtime.execution.Environment
-
Gets the ID of the JobVertex for which this task executes a parallel subtask.
- getJobVertexId() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
- getJobVertexId() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
-
- getJobVertexId() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getJobvertexId() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getJobVertexId() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
-
- getJobVertexId() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- getJobVertexId() - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Returns the JobVertexID the KvState instances belong to.
- getJobVertexId() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
-
Returns the JobVertexID the KvState instance belongs to.
- getJobVertexId() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
-
Returns the JobVertexID the KvState instance belongs to.
- getJobVertexID() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- getJobVertexId() - Method in class org.apache.flink.runtime.scheduler.strategy.ExecutionVertexID
-
- getJobVertexId() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getJobVertexId() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getJobVertexIds() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
-
- getJobVertexInfos() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- getJobVertexMetrics() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- getJobVerticesPerState() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- getJson() - Method in class org.apache.flink.runtime.webmonitor.history.ArchivedJson
-
- getJsonPlan() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the job plan as a JSON string.
- getJsonPlan() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getJsonPlan() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getJsonPlan() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- getJsonPlan() - Method in class org.apache.flink.runtime.rest.messages.JobPlanInfo
-
- getJvmStartupOptions() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Gets the system parameters and environment parameters that were passed to the JVM on startup.
- getJvmStartupOptionsArray() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Gets the system parameters and environment parameters that were passed to the JVM on startup.
- getJvmVersion() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Gets the version of the JVM in the form "VM_Name - Vendor - Spec/Version".
- getKey() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoEntry
-
- getKey() - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Returns the key of this parameter, e.g.
- getKey() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap.StateMapEntry
-
- getKey() - Method in interface org.apache.flink.runtime.state.Keyed
-
Returns the key attribute.
- getKey() - Method in interface org.apache.flink.runtime.state.StateEntry
-
Returns the key of this entry.
- getKey() - Method in class org.apache.flink.runtime.state.StateEntry.SimpleStateEntry
-
- getKeyA(A) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyLinkedMap
-
- getKeyB(B) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyLinkedMap
-
- getKeyedStateHandles(Collection<? extends KeyedStateHandle>, KeyGroupRange) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
-
- getKeyedStateStore() - Method in interface org.apache.flink.runtime.state.ManagedInitializationContext
-
Returns an interface that allows for registering keyed state with the backend.
- getKeyedStateStore() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
-
- getKeyedStateStreamFuture() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
-
- getKeyGroupCompressionDecorator() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- getKeyGroupId(int) - Method in class org.apache.flink.runtime.state.KeyGroupRange
-
- getKeyGroupId(int) - Method in interface org.apache.flink.runtime.state.KeyGroupsList
-
- getKeyGroupId() - Method in class org.apache.flink.runtime.state.KeyGroupStatePartitionStreamProvider
-
Returns the key group that corresponds to the data in the provided stream.
- getKeyGroupList() - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
-
Returns a list of all key-groups which can be written to this stream.
- getKeyGroupOffset() - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- getKeyGroupOffset(int) - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
-
Returns the offset for the given key-group.
- getKeyGroupRange() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
-
Returns the key group index the KvState instance belongs to.
- getKeyGroupRange() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
-
Returns the key group index the KvState instance belongs to.
- getKeyGroupRange() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- getKeyGroupRange() - Method in class org.apache.flink.runtime.state.DirectoryKeyedStateHandle
-
- getKeyGroupRange() - Method in interface org.apache.flink.runtime.state.heap.InternalKeyContext
-
Returns the key groups for this backend.
- getKeyGroupRange() - Method in class org.apache.flink.runtime.state.heap.InternalKeyContextImpl
-
- getKeyGroupRange() - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
-
- getKeyGroupRange() - Method in interface org.apache.flink.runtime.state.KeyedStateHandle
-
Returns the range of the key groups contained in the state.
- getKeyGroupRange() - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
-
- getKeyGroupRange() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
-
- getKeyGroupWriter() - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueStateSnapshot
-
- getKeyGroupWriter() - Method in interface org.apache.flink.runtime.state.StateSnapshot
-
- getKeys(N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
- getKeys(String, N) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- getKeys(N) - Method in class org.apache.flink.runtime.state.heap.NestedStateMap
-
- getKeys(N) - Method in class org.apache.flink.runtime.state.heap.StateMap
-
- getKeys(N) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- getKeys(String, N) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
-
- getKeySerializer() - Method in class org.apache.flink.runtime.query.KvStateInfo
-
- getKeySerializer() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- getKeySerializer() - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- getKeySerializer() - Method in interface org.apache.flink.runtime.state.internal.InternalKvState
-
Returns the TypeSerializer
for the type of key this state is associated to.
- getKeySerializer() - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
-
- getKeySerializer() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
-
- getKeySerializerSnapshot() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
-
- getKeytab() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
-
- getKrb5LoginModuleName() - Static method in class org.apache.flink.runtime.security.KerberosUtils
-
- getKvState(KvStateID) - Method in class org.apache.flink.runtime.query.KvStateRegistry
-
Returns the
KvStateEntry
containing the requested instance as identified by the
given KvStateID, along with its
KvStateInfo
or
null
if none is registered.
- getKvStateClientProxy() - Method in class org.apache.flink.runtime.taskexecutor.KvStateService
-
- getKvStateID(int) - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Returns the registered KvStateID for the key group index or
null
if none is registered yet.
- getKvStateId() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
-
Returns the ID of the registered KvState instance.
- getKvStateLocation(String) - Method in class org.apache.flink.runtime.query.KvStateLocationRegistry
-
Returns the
KvStateLocation
for the registered KvState instance
or
null
if no location information is available.
- getKvStateLocationOracle(JobID) - Method in interface org.apache.flink.runtime.query.KvStateClientProxy
-
Retrieves a future containing the currently leading key-value state location oracle.
- getKvStateLocationRegistry() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getKvStateRegistry() - Method in class org.apache.flink.runtime.taskexecutor.KvStateService
-
- getKvStateServer() - Method in class org.apache.flink.runtime.taskexecutor.KvStateService
-
- getKvStateServerAddress(int) - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Returns the registered server address for the key group index or
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.
- getKvStateService() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- getLast() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
-
Returns the last checkpoint ID (current - 1).
- getLastAccessTimestamp() - Method in class org.apache.flink.runtime.state.ttl.TtlValue
-
- getLastHeartbeat() - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatMonitor
-
Gets the last heartbeat.
- getLastHeartbeat() - Method in class org.apache.flink.runtime.heartbeat.HeartbeatMonitorImpl
-
- getLastHeartBeat() - Method in class org.apache.flink.runtime.instance.Instance
-
Gets the timestamp of the last heartbeat.
- getLastHeartbeat() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
-
- getLastHeartbeatFrom(ResourceID) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatManager
-
Returns the last received heartbeat from the given target.
- getLastHeartbeatFrom(ResourceID) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
-
- getLastOutputCollector() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getLastTasksConfig() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getLastUpdateTime() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the latest acknowledged subtask stats or null
if
none was acknowledged yet.
- getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
-
- getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
-
- getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
-
- getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
-
Returns the latest acknowledged subtask stats or null
if none was acknowledged yet.
- getLatestAckTimestamp() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the ack timestamp of the latest acknowledged subtask or
-1
if none was acknowledged yet.
- getLatestAckTimestamp() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
-
Returns the ack timestamp of the latest acknowledged subtask or
-1
if none was acknowledged yet.
- getLatestAckTimestamp() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- getLatestAckTimestamp() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- getLatestCheckpoint(boolean) - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
- getLatestCheckpoints() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
-
- getLatestCompletedCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
-
- getLatestFailedCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
-
- getLatestPriorAllocation() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getLatestPriorExecution() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getLatestPriorLocation() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
Gets the location where the latest completed/canceled/failed execution of the vertex's
task happened.
- getLatestRestoredCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
-
Returns the latest restored checkpoint.
- getLatestSavepoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
-
- getLatestVersion(Collection<RestAPIVersion>) - Static method in enum org.apache.flink.runtime.rest.versioning.RestAPIVersion
-
Returns the latest version from the given collection.
- getLeaderConnectionInfoFuture() - Method in class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderConnectionInfoListener
-
- getLeaderFuture() - Method in class org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
-
Returns the current JobManagerGateway future.
- getLeaderGatewayFuture() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
-
- getLeaderId(JobID) - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
- getLeaderID() - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerServices
-
Gets the current leader id assigned at the ResourceManager.
- getLeaderNow() - Method in class org.apache.flink.runtime.webmonitor.retriever.LeaderRetriever
-
Returns the current leader information if available.
- getLeaderSessionID() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
-
Returns the current leader session ID or null, if the contender is not the leader.
- getLeaderSessionID() - Method in class org.apache.flink.runtime.util.LeaderConnectionInfo
-
- getLength() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileSegment
-
- getLength() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- getLength() - Method in class org.apache.flink.runtime.state.ChainedStateHandle
-
Returns the length of the operator chain.
- getLength() - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- getLibraryCacheManager() - Method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
-
- getLibraryCacheManager() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
-
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.FileChannelInputView
-
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.HeaderlessChannelReaderInputView
-
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.RandomAccessInputView
-
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
-
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Gets the limit for reading bytes from the given memory segment.
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- getListState(ListStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
-
- getListState(ListStateDescriptor<S>) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- getLocality() - Method in class org.apache.flink.runtime.instance.SharedSlot
-
- getLocality() - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
Gets the locality information attached to this slot.
- getLocality() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Gets the locality of this slot.
- getLocality() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- getLocality() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotAndLocality
-
- getLocality() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSelectionStrategy.SlotInfoAndLocality
-
- getLocalRecoveryConfig() - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- getLocalRecoveryConfig() - Method in class org.apache.flink.runtime.state.NoOpTaskLocalStateStoreImpl
-
- getLocalRecoveryConfig() - Method in interface org.apache.flink.runtime.state.TaskLocalStateStore
-
- getLocalRecoveryConfig() - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
- getLocalStateDirectoryProvider() - Method in class org.apache.flink.runtime.state.LocalRecoveryConfig
-
- getLocation() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
-
Gets the location assigned to this slot.
- getLocation() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointInfo
-
- getLocationConstraint() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getLocationConstraint(int) - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
-
- getLocationReference() - Method in interface org.apache.flink.runtime.state.CheckpointStorageLocation
-
Gets a reference to the storage location.
- getLocationReference() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
-
- getLocationReference() - Method in class org.apache.flink.runtime.state.memory.NonPersistentMetadataCheckpointStorageLocation
-
- getLocationReference() - Method in class org.apache.flink.runtime.state.memory.PersistentMetadataCheckpointStorageLocation
-
- getLockPath(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Returns the path for the lock node relative to the given path.
- getLogicalScope(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Returns the logical scope of this group, for example
"taskmanager.job.task"
.
- getLogicalScope(CharacterFilter, char) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Returns the logical scope of this group, for example
"taskmanager.job.task"
.
- getLogicalScope(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
-
- getLogicalScope(CharacterFilter, char) - Method in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
-
- getLogicalSlotFuture() - Method in class org.apache.flink.runtime.scheduler.SlotExecutionVertexAssignment
-
- getLoginContextNames() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
-
- getMainThreadExecutor() - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerServices
-
Gets the executor which executes in the main thread of the ResourceManager
- getMainThreadExecutor() - Method in class org.apache.flink.runtime.rpc.FencedRpcEndpoint
-
Returns a main thread executor which is bound to the currently valid fencing token.
- getMainThreadExecutor() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Gets the main thread execution context.
- getManagedKeyedState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
-
Returns a handle to the managed keyed state.
- getManagedKeyedState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
- getManagedKeyedStateHandles(OperatorState, KeyGroupRange) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
-
- getManagedMemoryFraction(Configuration) - Static method in class org.apache.flink.runtime.util.ConfigurationParserUtils
-
Parses the configuration to get the fraction of managed memory and validates the value.
- getManagedMemoryFromHeapAndManaged(Configuration, long) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
Gets the size of managed memory from the heap size after subtracting network buffer memory.
- getManagedMemoryFromProcessMemory(Configuration, long) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
Gets the size of managed memory from the JVM process size, which at that point includes
network buffer memory, managed memory, and non-flink-managed heap memory.
- getManagedMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the managed memory needed in MB.
- getManagedMemorySize(Configuration) - Static method in class org.apache.flink.runtime.util.ConfigurationParserUtils
-
Parses the configuration to get the managed memory size and validates the value.
- getManagedOperatorState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
-
Returns a handle to the managed operator state.
- getManagedOperatorState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
- getMapForKeyGroup(int) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- getMapState(MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
-
- getMasterHooks() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
-
- getMasterHookStates() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getMasterStates() - Method in interface org.apache.flink.runtime.checkpoint.savepoint.Savepoint
-
Gets the checkpointed states generated by the master.
- getMasterStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
-
- getMasterStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
-
- getMatchesFor(PT) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
- getMatchFor(PT, BT) - Method in class org.apache.flink.runtime.operators.hash.AbstractHashTableProber
-
- getMatchFor(PT) - Method in class org.apache.flink.runtime.operators.hash.AbstractHashTableProber
-
- getMatchFor(PT, T) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable.HashTableProber
-
- getMatchFor(PT) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable.HashTableProber
-
- getMatchFor(PT, T) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
-
Searches the hash table for the record with the given key.
- getMatchFor(PT) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
-
- getMax() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
-
- getMax() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
-
- getMaxBackPressureRatio() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
-
Returns the maximum back pressure ratio of all sub tasks.
- getMaxCapacity() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Returns the maximum size of the buffer, i.e.
- getMaxCapacity() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
- getMaxCapacity() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getMaxCapacity() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- getMaxCheckpointStatisticCacheEntries() - Method in class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
-
- getMaxConcurrentCheckpoints() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
-
- getMaxContentLength() - Method in class org.apache.flink.runtime.rest.RestClientConfiguration
-
Returns the max content length that the REST client endpoint could handle.
- getMaxContentLength() - Method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
-
Returns the max content length that the REST server endpoint could handle.
- getMaxDepth(int) - Static method in class org.apache.flink.runtime.operators.sort.QuickSort
-
Deepest recursion before giving up and doing a heapsort.
- getMaximum() - Method in class org.apache.flink.runtime.checkpoint.MinMaxAvgStats
-
Returns the maximum seen value.
- getMaximum() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
-
- getMaximumFramesize() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcServiceConfiguration
-
- getMaximumParallelism() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Gets the maximum parallelism of all operations in this job graph.
- getMaxJvmHeapMemory() - Method in class org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
-
- getMaxJvmHeapMemory() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
The maximum JVM heap size, in bytes.
- getMaxNumberOfMemorySegments() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
Returns the maximum number of memory segments this buffer pool should use.
- getMaxNumberOfRetainedCheckpoints() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
Returns the max number of retained checkpoints.
- getMaxNumberOfRetainedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
-
- getMaxNumberOfRetainedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
-
- getMaxNumberOfSubtaks() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
-
- getMaxNumThreads() - Method in class org.apache.flink.runtime.clusterframework.BootstrapTools.FixedThreadPoolExecutorConfiguration
-
- getMaxParallelism() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
-
- getMaxParallelism() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getMaxParallelism() - Method in class org.apache.flink.runtime.clusterframework.BootstrapTools.ForkJoinExecutorConfiguration
-
- getMaxParallelism() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- getMaxParallelism() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
Returns the max parallelism for this job vertex.
- getMaxParallelism() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
-
- getMaxParallelism() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getMaxParallelism() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getMaxParallelism() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Gets the maximum parallelism for the task.
- getMaxRegistrationDuration() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getMaxRegistrationPause() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getMaxRegistrationTimeoutMillis() - Method in class org.apache.flink.runtime.registration.RetryingRegistrationConfiguration
-
- getMaxStateSize() - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
-
Gets the size (in bytes) that a individual chunk of state may have at most.
- getMaxStateSize() - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
-
Gets the maximum size that an individual state can have, as configured in the
constructor (by default
5242880).
- getMean() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
-
- getMemoryFraction() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- getMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the total memory needed in MB.
- getMemoryManager() - Method in interface org.apache.flink.runtime.execution.Environment
-
- getMemoryManager() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getMemoryManager() - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getMemoryManager() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- getMemoryManager() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getMemoryPoolStatsAsString(List<MemoryPoolMXBean>) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
-
Gets the memory pool statistics from the JVM.
- getMemorySegment() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Deprecated.
- getMemorySegment() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getMemorySegment() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
Returns the underlying memory segment.
- getMemorySegmentOffset() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Deprecated.
- getMemorySegmentOffset() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getMemorySegmentOffset() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- getMemorySize() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Returns the total size of memory handled by this memory manager.
- getMemoryType() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Gets the type of memory (heap / off-heap) managed by this memory manager.
- getMemoryType(Configuration) - Static method in class org.apache.flink.runtime.util.ConfigurationParserUtils
-
Parses the configuration to get the type of memory.
- 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.
- getMessageHeaders() - Method in class org.apache.flink.runtime.rest.handler.AbstractRestHandler
-
- getMetadataFilePath() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
-
- getMetadataHandle() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getMetadataHandle() - Method in interface org.apache.flink.runtime.state.CompletedCheckpointStorageLocation
-
Gets the state handle to the checkpoint's metadata.
- getMetadataHandle() - Method in class org.apache.flink.runtime.state.filesystem.FsCompletedCheckpointStorageLocation
-
- getMetaDataState() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
-
- getMetaInfo() - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueSnapshotRestoreWrapper
-
- getMetaInfo() - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- getMetaInfoSnapshot() - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueStateSnapshot
-
- getMetaInfoSnapshot() - Method in interface org.apache.flink.runtime.state.StateSnapshot
-
Returns a snapshot of the state's meta data.
- getMetaStateHandle() - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
-
- getMethodName() - Method in class org.apache.flink.runtime.rpc.messages.LocalRpcInvocation
-
- getMethodName() - Method in class org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation
-
- getMethodName() - Method in interface org.apache.flink.runtime.rpc.messages.RpcInvocation
-
Returns the method's name.
- getMetric(String) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.ComponentMetricStore
-
- getMetric(String, String) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.ComponentMetricStore
-
- getMetricGroup() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the task specific metric group.
- getMetricGroup() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getMetricGroup() - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getMetricGroup() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getMetricGroup() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getMetricIdentifier(String) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Returns the fully qualified metric name, for example
"host-7.taskmanager-2.window_word_count.my-mapper.metricName"
.
- getMetricIdentifier(String, CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Returns the fully qualified metric name, for example
"host-7.taskmanager-2.window_word_count.my-mapper.metricName"
.
- getMetricIdentifier(String, CharacterFilter, int) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Returns the fully qualified metric name using the configured delimiter for the reporter with the given index, for example
"host-7.taskmanager-2.window_word_count.my-mapper.metricName"
.
- getMetricIdentifier(String) - Method in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
-
- getMetricIdentifier(String, CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
-
- getMetricIdentifier(String) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- getMetricIdentifier(String, CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- getMetricQueryServiceGatewayRpcAddress() - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
-
- getMetricQueryServiceGatewayRpcAddress() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
- getMetricQueryServiceRpcService() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
- getMetrics() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetricsResponseBody
-
- getMetrics() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricCollectionResponseBody
-
- getMetricStore() - Method in interface org.apache.flink.runtime.rest.handler.legacy.metrics.MetricFetcher
-
Get
MetricStore
which contains all currently fetched metrics.
- getMetricStore() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricFetcherImpl
-
Returns the MetricStore containing all stored metrics.
- getMetricStore() - Method in enum org.apache.flink.runtime.rest.handler.legacy.metrics.VoidMetricFetcher
-
- getMimeTypeForExtension(String) - Static method in class org.apache.flink.runtime.rest.handler.util.MimeTypes
-
Gets the MIME type for the file with the given extension.
- getMimeTypeForFileName(String) - Static method in class org.apache.flink.runtime.rest.handler.util.MimeTypes
-
Gets the MIME type for the file with the given name, by extension.
- getMin() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
-
- getMin() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
-
- getMinFileSizeThreshold() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Gets the threshold below which state is stored as part of the metadata, rather than in files.
- getMinimum() - Method in class org.apache.flink.runtime.checkpoint.MinMaxAvgStats
-
Returns the minimum seen value.
- getMinimum() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.MinMaxAvgStatistics
-
- getMinNumThreads() - Method in class org.apache.flink.runtime.clusterframework.BootstrapTools.FixedThreadPoolExecutorConfiguration
-
- getMinOffloadingSize() - Method in class org.apache.flink.runtime.blob.BlobServer
-
Returns the configuration used by the BLOB server.
- getMinOffloadingSize() - Method in interface org.apache.flink.runtime.blob.BlobWriter
-
Returns the min size before data will be offloaded to the BLOB store.
- getMinOffloadingSize() - Method in class org.apache.flink.runtime.blob.VoidBlobWriter
-
- getMinParallelism() - Method in class org.apache.flink.runtime.clusterframework.BootstrapTools.ForkJoinExecutorConfiguration
-
- getMinPauseBetweenCheckpoints() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
-
- getMinResources() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Gets the minimum resource for the task.
- getMultipartFileUploads(ChannelHandlerContext) - Static method in class org.apache.flink.runtime.rest.FileUploadHandler
-
- getMutableObjectMode() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getName() - Method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
-
- getName() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
-
- getName() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
Returns the name for this job vertex.
- getName() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
-
- getName() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getName() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns the name assigned to the job graph.
- getName() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns the name of the vertex.
- getName() - Method in class org.apache.flink.runtime.metrics.ReporterSetup
-
- getName() - Method in class org.apache.flink.runtime.rest.handler.router.RouterHandler
-
- getName() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- getName() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- getName() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
-
- getName() - Method in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
-
- getName() - Method in class org.apache.flink.runtime.state.RegisteredStateMetaInfoBase
-
- getNamespace() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap.StateMapEntry
-
- getNamespace() - Method in interface org.apache.flink.runtime.state.StateEntry
-
Returns the namespace of this entry.
- getNamespace() - Method in class org.apache.flink.runtime.state.StateEntry.SimpleStateEntry
-
- getNamespaceMap() - Method in class org.apache.flink.runtime.state.heap.NestedStateMap
-
- getNamespaceSerializer() - Method in class org.apache.flink.runtime.query.KvStateInfo
-
- getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- getNamespaceSerializer() - Method in interface org.apache.flink.runtime.state.internal.InternalKvState
-
Returns the TypeSerializer
for the type of namespace this state is associated to.
- getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
-
- getNativeMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the native memory needed in MB.
- getNestedSerializers(ArrayListSerializer<T>) - Method in class org.apache.flink.runtime.state.ArrayListSerializerSnapshot
-
- getNestedSerializers(TtlStateFactory.TtlSerializer<T>) - Method in class org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializerSnapshot
-
- getNetRuntime() - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
-
- getNetRuntime(TimeUnit) - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
-
Gets the net execution time of the job, i.e., the execution time in the parallel system,
without the pre-flight steps like the optimizer in a desired time unit.
- getNetRuntime() - Method in class org.apache.flink.runtime.jobmaster.JobResult
-
- getNettyHttpMethod() - Method in enum org.apache.flink.runtime.rest.HttpMethodWrapper
-
- getNetworkBufferPool() - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
- getNetworkInterfaceNames() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
-
- getNetworkMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the memory needed for task to communicate with its upstreams and downstreams in MB.
- getNewInMemoryPartition(int, int) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Returns a new inMemoryPartition object.
- getNewInMemoryPartition(int, int) - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
-
- getNext() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
- getNext() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- getNext() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
-
- getNext() - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
-
- getNextBuffer() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
- getNextBuffer() - Method in class org.apache.flink.runtime.io.network.partition.NoOpResultSubpartitionView
-
- getNextBuffer() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
-
Returns the next
Buffer
instance of this queue iterator.
- getNextInputSplit() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getNextInputSplit(String) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getNextInputSplit(ClassLoader) - Method in interface org.apache.flink.runtime.jobgraph.tasks.InputSplitProvider
-
Requests the next input split to be consumed by the calling task.
- getNextInputSplit(ClassLoader) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcInputSplitProvider
-
- getNextRecord(T) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
-
- getNextRecord(T) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
-
- getNextReturnedBlock() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockReader
-
Gets the next memory segment that has been filled with data by the reader.
- getNextReturnedBlock() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockWriter
-
Gets the next memory segment that has been written and is available again.
- getNextReturnedBlock() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelReader
-
Gets the next memory segment that has been filled with data by the reader.
- getNextReturnedBlock() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelWriter
-
Gets the next memory segment that has been written and is available again.
- getNioBuffer(int, int) - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Gets a new
ByteBuffer
instance wrapping this buffer's bytes.
- getNioBuffer(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getNioBuffer(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- getNioBufferReadable() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Gets a new
ByteBuffer
instance wrapping this buffer's readable bytes, i.e.
- getNioBufferReadable() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getNioBufferReadable() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- getNioFileChannel() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
-
- getNioFileChannel() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
-
- getNonReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
-
- getNonReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.FullOuterJoinDriver
-
- getNonReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.LeftOuterJoinDriver
-
- getNonReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.RightOuterJoinDriver
-
- getNow() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- getNow() - Method in interface org.apache.flink.runtime.webmonitor.retriever.GatewayRetriever
-
Returns the currently retrieved gateway if there is such an object.
- getNumAckSubtasks() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- getNumAckSubtasks() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- getNumberAssignedPendingTaskManagerSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
- getNumberAvailableSlots() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
-
- getNumberCollectedStates() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
-
- getNumberCollectedStates() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getNumberCompletedCheckpoints() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
-
- getNumberCPUCores() - Static method in class org.apache.flink.runtime.util.Hardware
-
Gets the number of CPU cores (hardware contexts) that the JVM has access to.
- getNumberFailedCheckpoints() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
-
- getNumberFreeSlots() - Method in class org.apache.flink.runtime.resourcemanager.ResourceOverview
-
- getNumberFreeSlots() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
- getNumberFreeSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
- getNumberFreeSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
-
- getNumberFreeSlotsOf(InstanceID) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
- getNumberFreeSlotsOf(InstanceID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
- getNumberInProgressCheckpoints() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
-
- getNumberLeaves() - Method in class org.apache.flink.runtime.instance.SharedSlot
-
- getNumberLeaves() - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
- getNumberLeaves() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the number of simple slots that are at the leaves of the tree of slots.
- getNumberOfAcknowledgedSubtasks() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the number of acknowledged subtasks.
- getNumberOfAcknowledgedSubtasks() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
-
- getNumberOfAcknowledgedSubtasks() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
-
- getNumberOfAcknowledgedSubtasks() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
-
- getNumberOfAcknowledgedSubtasks() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
-
Returns the number of acknowledged subtasks.
- getNumberOfAcknowledgedTasks() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- getNumberOfActiveConnections() - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
-
- getNumberOfActiveConnections() - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
-
- getNumberOfActiveConnections() - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
-
- getNumberOfAllocatedBytes() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
-
Returns the number of currently allocated bytes.
- getNumberOfAllocatedSlots() - Method in class org.apache.flink.runtime.instance.Instance
-
- getNumberOfArenas() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getNumberOfAssignedPartitions() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- getNumberOfAvailableBuffers() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
- 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
-
- 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.
- getNumberOfFullRestarts() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Gets the number of full restarts that the execution graph went through.
- getNumberOfInProgressCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
-
Returns the number of in progress checkpoints.
- getNumberOfInputChannels() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
- getNumberOfInputChannels() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- getNumberOfInputChannels() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
-
Returns the total number of input channels across all unioned input gates.
- getNumberOfInputChannels() - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns the number of inputs.
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.CrossDriver
-
- getNumberOfInputs() - Method in interface org.apache.flink.runtime.operators.Driver
-
Gets the number of inputs that the task has.
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.JoinDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.MapDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.NoOpDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.ReduceDriver
-
- getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
-
- getNumberOfIterations() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getNumberOfKeyGroups() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- getNumberOfKeyGroups() - Method in interface org.apache.flink.runtime.state.heap.InternalKeyContext
-
Returns the number of key-groups aka max parallelism.
- getNumberOfKeyGroups() - Method in class org.apache.flink.runtime.state.heap.InternalKeyContextImpl
-
- 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.
- getNumberOfNonAcknowledgedTasks() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- getNumberOfOutstandingRequests() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileWriter
-
- getNumberOfOutstandingRequests() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileWriter
-
Returns the number of outstanding requests.
- getNumberOfPartitions() - Method in class org.apache.flink.runtime.state.OperatorStateCheckpointOutputStream
-
- getNumberOfPendingCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- getNumberOfProducedIntermediateDataSets() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Returns the number of produced intermediate data sets.
- getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
Gets the current number of received buffers which have not been processed yet.
- getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getNumberOfReferenceHolders(JobID) - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
-
- getNumberOfRegisteredBufferPools() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- getNumberOfRegisteredMasterHooks() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Gets the number of currently register master hooks.
- getNumberOfRegisteredTaskManagers() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- getNumberOfRegisteredTaskManagers() - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Gets the currently registered number of TaskManagers.
- getNumberOfRequiredBuffers() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
- getNumberOfRequiredMemorySegments() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
Returns the number of guaranteed (minimum number of) memory segments of this buffer pool.
- getNumberOfRestoredCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
-
Returns the number of restored checkpoints.
- getNumberOfRetainedCheckpoints() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
Returns the current number of retained checkpoints.
- getNumberOfRetainedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
-
- getNumberOfRetainedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
-
- getNumberOfRetainedSuccessfulCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- getNumberOfSlots() - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
-
Gets the number of slots that are currently governed by this assignment group.
- getNumberOfSlots() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getNumberOfSlots() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- getNumberOfSubpartitions() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- getNumberOfSubpartitions() - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
- getNumberOfSubpartitions() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getNumberOfSubpartitions() - Method in class org.apache.flink.runtime.shuffle.PartitionDescriptor
-
- getNumberOfSubpartitions() - Method in class org.apache.flink.runtime.taskmanager.ConsumableNotifyingResultPartitionWriterDecorator
-
- getNumberOfSubtasks() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the total number of subtasks involved in this checkpoint.
- getNumberOfSubtasks() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
-
Returns the number of subtasks.
- getNumberOfSubtasks() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
-
- getNumberOfSubTasks() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
-
Returns the number of sub tasks.
- getNumberOfVariablesWithReferences() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableManager
-
- getNumberOfVertices() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns the number of all vertices.
- getNumberPendingSlotRequests() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
- getNumberPendingSlotRequests() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
- getNumberPendingTaskManagerSlots() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
- getNumberPendingTaskManagerSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
- getNumberRegisteredSlots() - Method in class org.apache.flink.runtime.resourcemanager.ResourceOverview
-
- getNumberRegisteredSlots() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
- getNumberRegisteredSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
- getNumberRegisteredSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
-
- getNumberRegisteredSlotsOf(InstanceID) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
- getNumberRegisteredSlotsOf(InstanceID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
- getNumberReporters() - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
-
Returns the number of registered reporters.
- getNumberReporters() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
- getNumberReporters() - Method in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
-
- getNumberRequiredTaskManagerSlots() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- getNumberRestoredCheckpoints() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
-
- getNumberSlots() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
-
- getNumberSlots() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getNumberTaskManagers() - Method in class org.apache.flink.runtime.resourcemanager.ResourceOverview
-
- getNumBroadcastInputs() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getNumBuffers() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
Returns the current size of this buffer pool.
- getNumBuffersInLocalCounter() - Method in class org.apache.flink.runtime.io.network.metrics.InputChannelMetrics
-
- getNumBuffersInRemoteCounter() - Method in class org.apache.flink.runtime.io.network.metrics.InputChannelMetrics
-
- getNumBuffersOutCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
- getNumBytes() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
-
Get output bytes.
- getNumBytesIn() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
-
- getNumBytesInCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
- getNumBytesInLocalCounter() - Method in class org.apache.flink.runtime.io.network.metrics.InputChannelMetrics
-
- getNumBytesInRemoteCounter() - Method in class org.apache.flink.runtime.io.network.metrics.InputChannelMetrics
-
- getNumBytesOut() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
-
- getNumBytesOutCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
- getNumCompressedBytes() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractChannelWriterOutputView
-
Get output compressed bytes, return num bytes if there is no compression.
- getNumFuturesCompleted() - Method in class org.apache.flink.runtime.concurrent.FutureUtils.ConjunctFuture
-
Gets the number of Futures in the conjunction that are already complete.
- getNumFuturesTotal() - Method in class org.apache.flink.runtime.concurrent.FutureUtils.ConjunctFuture
-
Gets the total number of Futures in the conjunction.
- getNumInputs() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
-
- getNumInputs() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getNumJobsCancelled() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
-
- getNumJobsFailed() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
-
- getNumJobsFinished() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
-
- getNumJobsRunningOrPending() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
-
- getNumKeyGroups() - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Returns the number of key groups of the operator the KvState instances belong to.
- getNumOccupiedMemorySegments() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
Gets the number of memory segments used by this partition, which includes build side
memory buffers and overflow memory segments.
- getNumOutputs() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getNumRecordsIn() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
-
- getNumRecordsInCounter() - Method in class org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
-
- getNumRecordsInCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
-
- 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
-
- getNumRecordsOutRate() - Method in class org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
-
- getNumRegisteredKeyGroups() - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Returns the current number of registered key groups.
- getNumRequiredComparators() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
-
- getNumSlotsAvailable() - Method in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
-
- getNumSlotsTotal() - Method in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
-
- getNumSubtasks() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- getNumSubtasks() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- getNumTargetKeyGroups() - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
- getNumTargetKeyGroups() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getNumTargetKeyGroups() - Method in class org.apache.flink.runtime.taskmanager.ConsumableNotifyingResultPartitionWriterDecorator
-
- getNumTaskInputs() - Method in class org.apache.flink.runtime.iterative.task.IterationHeadTask
-
- getNumTaskInputs() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getNumTaskManagers() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
-
- getNumTaskManagersConnected() - Method in class org.apache.flink.runtime.messages.webmonitor.ClusterOverview
-
- getNumTasks() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getNumWriteBehindBuffers(int) - Static method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Determines the number of buffers to be used for asynchronous write behind.
- getOccupancy() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
Gets the number of bytes currently occupied in this hash table.
- getOccupancy() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- getOccupancy() - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Gets the number of bytes currently occupied in this sorter, records and sort index.
- getOccupancy() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- getOffsetForKeyGroup(int) - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
-
- getOffsets() - Method in class org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
-
- getOpenFileHandlesLimit() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Tries to retrieve the maximum number of open file handles.
- getOperationKey(HandlerRequest<EmptyRequestBody, M>) - Method in class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.StatusHandler
-
Extract the operation key under which the operation result future is stored.
- getOperationKey(HandlerRequest<EmptyRequestBody, RescalingStatusMessageParameters>) - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingStatusHandler
-
- getOperationKey(HandlerRequest<EmptyRequestBody, SavepointDisposalStatusMessageParameters>) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalStatusHandler
-
- getOperationKey(HandlerRequest<EmptyRequestBody, SavepointStatusMessageParameters>) - Method in class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointStatusHandler
-
- getOperatorBackPressureStats(ExecutionJobVertex) - Method in interface org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTracker
-
Returns back pressure statistics for a operator.
- getOperatorBackPressureStats(ExecutionJobVertex) - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTrackerImpl
-
Returns back pressure statistics for a operator.
- getOperatorBackPressureStats() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStatsResponse
-
- getOperatorDescription() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getOperatorFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
-
- getOperatorID() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
-
- getOperatorId() - Method in class org.apache.flink.runtime.jobgraph.OperatorInstanceID
-
- getOperatorIDs() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
Returns a list containing the IDs of all operators contained in this execution job vertex.
- getOperatorIDs() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getOperatorLevelCachingDescription() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Gets the operator-level caching description for this input.
- getOperatorName() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getOperatorPrettyName() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getOperatorsMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Get the memory the operators needed in MB.
- getOperatorState(ListStateDescriptor<S>) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- getOperatorStateMetaInfoSnapshots() - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
-
- getOperatorStates() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getOperatorStates() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- getOperatorStates() - Method in interface org.apache.flink.runtime.checkpoint.savepoint.Savepoint
-
Returns the snapshotted operator states.
- getOperatorStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
-
- getOperatorStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
-
- getOperatorStateStore() - Method in interface org.apache.flink.runtime.state.ManagedInitializationContext
-
Returns an interface that allows for registering operator state with the backend.
- getOperatorStateStore() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
-
- getOperatorStateStreamFuture() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
-
- getOption(String) - Method in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
-
- getOption(StateMetaInfoSnapshot.CommonOptionsKeys) - Method in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
-
- getOptions() - Method in class org.apache.flink.runtime.entrypoint.ClusterConfigurationParserFactory
-
- getOptions() - Method in class org.apache.flink.runtime.entrypoint.EntrypointClusterConfigurationParserFactory
-
- getOptions() - Method in interface org.apache.flink.runtime.entrypoint.parser.ParserResultFactory
-
Returns all relevant Options
for parsing the command line
arguments.
- getOptionsImmutable() - Method in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
-
- getOrAddOperator(String) - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- getOrAddOperator(OperatorID, String) - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- getOrAddOperator(OperatorID, String) - Method in class org.apache.flink.runtime.metrics.groups.UnregisteredMetricGroups.UnregisteredTaskMetricGroup
-
- getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, V>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, T>) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
-
Creates or retrieves a keyed state backed by this state backend.
- getOutputCollector() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getOutputCollector(AbstractInvokable, TaskConfig, ClassLoader, List<RecordWriter<?>>, int, int) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Creates the Collector
for the given task, as described by the given configuration.
- getOutputCollector() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- getOutputCollector() - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getOutputComparator(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getOutputDataDistribution(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getOutputEdges() - Method in interface org.apache.flink.runtime.executiongraph.failover.flip1.FailoverVertex
-
Returns all output edges of this vertex.
- getOutputFormats() - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer.FormatUserCodeTable
-
- getOutputFormats() - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
-
- getOutputGroup() - Method in class org.apache.flink.runtime.shuffle.ShuffleIOOwnerContext
-
- getOutputPartitioner(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- 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.
- getOwnerName() - Method in class org.apache.flink.runtime.shuffle.ShuffleIOOwnerContext
-
- getOwningJob(AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
- getOwningTaskName() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getPageSize() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Gets the size of the pages handled by the memory manager.
- getPageSize() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- getPageSize(Configuration) - Static method in class org.apache.flink.runtime.util.ConfigurationParserUtils
-
Parses the configuration to get the page size and validates the value.
- getPairComparatorFactory(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getParallelism() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
-
- getParallelism() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getParallelism() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
Returns the parallelism for this job vertex.
- getParallelism() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
-
- getParallelism() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getParallelism() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Gets the parallelism of the task.
- getParallelism() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- getParallelismFactor() - Method in class org.apache.flink.runtime.clusterframework.BootstrapTools.ForkJoinExecutorConfiguration
-
- getParallelSubtaskIndex() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
Returns the subtask index of this execution.
- getParallelSubtaskIndex() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
Returns the subtask index of this execution vertex.
- getParallelSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
-
- getParallelSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
-
- getParallelSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getParallelSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getParameters(OperatorID) - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
-
- getParameterTypes() - Method in class org.apache.flink.runtime.rpc.messages.LocalRpcInvocation
-
- getParameterTypes() - Method in class org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation
-
- getParameterTypes() - Method in interface org.apache.flink.runtime.rpc.messages.RpcInvocation
-
Returns the method's parameter types
- getParent() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the parent slot of this slot.
- getParentGroup() - Method in class org.apache.flink.runtime.shuffle.ShuffleIOOwnerContext
-
- getParentMetricGroup() - Method in class org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
-
- getPartitionById(IntermediateResultPartitionID) - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
Returns the partition with the given ID.
- getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
TODO: NOTE: This method does a lot of work caching / retrieving states just to update the namespace.
- getPartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
-
- getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
-
Creates or retrieves a partitioned state backed by this state backend.
- getPartitionId() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- getPartitionId() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
-
- getPartitionId() - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
- getPartitionId() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
- getPartitionId() - Method in exception org.apache.flink.runtime.io.network.partition.PartitionException
-
- getPartitionId() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- getPartitionId() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionID
-
- getPartitionId() - Method in class org.apache.flink.runtime.shuffle.PartitionDescriptor
-
- getPartitionId() - Method in class org.apache.flink.runtime.taskmanager.ConsumableNotifyingResultPartitionWriterDecorator
-
- 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.
- getPartitions() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- getPartitionsOccupyingLocalResources() - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
Report unreleased partitions.
- getPartitionsOccupyingLocalResources() - Method in interface org.apache.flink.runtime.shuffle.ShuffleEnvironment
-
Report partitions which still occupy some resources locally.
- getPartitionStateChecker() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
-
- getPartitionStateSerializer() - Method in class org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
-
- getPartitionTracker() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getPartitionType() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- getPartitionType() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Returns the type of this result partition.
- getPartitionType() - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingResultPartition
-
- getPartitionType() - Method in class org.apache.flink.runtime.shuffle.PartitionDescriptor
-
- getPath() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
-
Returns the path to the underlying temporary file.
- getPath() - Method in class org.apache.flink.runtime.rest.handler.router.RoutedRequest
-
- getPath() - Method in class org.apache.flink.runtime.webmonitor.history.ArchivedJson
-
- getPathFile() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
-
Returns the path to the underlying temporary file as a File.
- getPathForJob(JobID) - Static method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
-
Returns the JobID as a String (with leading slash).
- getPathParameter(Class<PP>) - Method in class org.apache.flink.runtime.rest.handler.HandlerRequest
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.EmptyMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedJobMetricsParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedSubtaskMetricsParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregateTaskManagerMetricsParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskAttemptMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.JobCancellationMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.JobMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.JobVertexMessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.MessageParameters
-
- getPathParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMessageParameters
-
- getPaths() - Method in interface org.apache.flink.runtime.io.disk.FileChannelManager
-
Gets all the files corresponding to the config temp dirs.
- getPaths() - Method in class org.apache.flink.runtime.io.disk.FileChannelManagerImpl
-
- getPaths() - Method in interface org.apache.flink.runtime.rest.handler.WebHandler
-
Returns an array of REST URL's under which this handler can be registered.
- getPayload() - Method in class org.apache.flink.runtime.instance.SharedSlot
-
- getPayload() - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
- getPayload() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Returns the set payload or null if none.
- getPayload() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- getPayload() - Method in interface org.apache.flink.runtime.rpc.messages.FencedMessage
-
- getPayload() - Method in class org.apache.flink.runtime.rpc.messages.LocalFencedMessage
-
- getPayload() - Method in class org.apache.flink.runtime.rpc.messages.RemoteFencedMessage
-
- getPayload() - Method in class org.apache.flink.runtime.rpc.messages.UnfencedMessage
-
- getPendingCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- getPermanentBlobService() - Method in class org.apache.flink.runtime.blob.BlobCacheService
-
- getPermanentBlobService() - Method in class org.apache.flink.runtime.blob.BlobServer
-
- getPermanentBlobService() - Method in interface org.apache.flink.runtime.blob.BlobService
-
Returns a BLOB service for accessing permanent BLOBs.
- getPhysicalSlotNumber() - Method in class org.apache.flink.runtime.instance.SharedSlot
-
- getPhysicalSlotNumber() - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
- getPhysicalSlotNumber() - Method in class org.apache.flink.runtime.instance.SimpleSlotContext
-
- getPhysicalSlotNumber() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Gets the slot number on the TaskManager.
- getPhysicalSlotNumber() - Method in interface org.apache.flink.runtime.jobmaster.SlotInfo
-
Gets the number of the slot.
- getPhysicalSlotNumber() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- getPipelineBreakingExchange(ExecutionMode) - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
-
- getPort() - Method in class org.apache.flink.runtime.blob.AbstractBlobCache
-
Returns the port the BLOB server is listening on.
- getPort() - Method in class org.apache.flink.runtime.blob.BlobCacheService
-
- getPort() - Method in class org.apache.flink.runtime.blob.BlobServer
-
Returns the port on which the server is listening.
- getPort() - Method in interface org.apache.flink.runtime.blob.BlobService
-
Returns the port of the BLOB server that this BLOB service is working with.
- getPort() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- getPort() - Method in interface org.apache.flink.runtime.rpc.RpcService
-
Return the port under which the rpc service is reachable.
- getPort() - Method in class org.apache.flink.runtime.util.LeaderConnectionInfo
-
- getPos() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
-
- getPos() - Method in class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
-
- getPos() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
-
- getPos() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
-
- getPos() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
-
- getPosition() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileSegment
-
- getPreferredAllocations() - Method in class org.apache.flink.runtime.clusterframework.types.SlotProfile
-
Returns the desired allocation ids for the slot.
- getPreferredLocations() - Method in class org.apache.flink.runtime.clusterframework.types.SlotProfile
-
Returns the preferred locations for the slot.
- getPreferredLocations() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
Gets the overall preferred execution location for this vertex's current execution.
- getPreferredLocations() - Method in class org.apache.flink.runtime.scheduler.ExecutionVertexSchedulingRequirements
-
- getPreferredLocationsBasedOnInputs() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
Gets the location preferences of the vertex's current task execution, as determined by the locations
of the predecessors from which it receives input data.
- getPreferredLocationsBasedOnState() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
Gets the preferred location to execute the current task execution attempt, based on the state
that the execution attempt will resume.
- getPreferredResources() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Gets the preferred resource for the task.
- getPreProcessingOperationName() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Gets the name of the pro-processing operation for this input.
- getPreviousAllocationId() - Method in class org.apache.flink.runtime.scheduler.ExecutionVertexSchedulingRequirements
-
- getPreviousElementSerializer() - Method in class org.apache.flink.runtime.state.RegisteredPriorityQueueStateBackendMetaInfo
-
- getPreviousExecutionGraphAllocations() - Method in class org.apache.flink.runtime.clusterframework.types.SlotProfile
-
Returns a set of all previous allocation ids from the execution graph.
- getPreviousGlobalAggregate(String) - Method in class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
-
- getPreviousKeySerializer() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
-
- getPreviousNamespaceSerializer() - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
-
- getPreviousPartitionStateSerializer() - Method in class org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
-
- getPreviousSerializerSnapshot() - Method in class org.apache.flink.runtime.state.StateSerializerProvider
-
Gets the previous serializer snapshot.
- getPreviousStateSerializer() - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
-
- getPreviousStateSerializerSnapshot() - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
-
- getPreviousValueSerializer() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
-
- getPrincipal() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
-
- getPriorExecutionAttempt(int) - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
-
Returns the execution for the given attempt number.
- getPriorExecutionAttempt(int) - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
-
- getPriorExecutionAttempt(int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getPrioritizedManagedKeyedState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns an immutable list with all alternative snapshots to restore the managed keyed state, in the order in
which we should attempt to restore.
- getPrioritizedManagedOperatorState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns an immutable list with all alternative snapshots to restore the managed operator state, in the order in
which we should attempt to restore.
- getPrioritizedRawKeyedState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns an immutable list with all alternative snapshots to restore the raw keyed state, in the order in which we
should attempt to restore.
- getPrioritizedRawOperatorState() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns an immutable list with all alternative snapshots to restore the raw operator state, in the order in
which we should attempt to restore.
- getPriorityQueue() - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueSnapshotRestoreWrapper
-
- getPrivateState() - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
-
- getProber(TypeComparator<PT>, TypePairComparator<PT, T>) - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
- getProber(TypeComparator<PT>, TypePairComparator<PT, T>) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
-
- getProber(TypeComparator<PT>, TypePairComparator<PT, T>) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
- getProbeSideBlockCount() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- getProbeSideChannel() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- getProbeSideComparator() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
- getProbeSideRecordCount() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- getProcessorsCount() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
-
- getProducedDataSets() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getProducedDataSets() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getProducedPartitions() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
- getProducedPartitions() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getProducedResultPartitions() - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingExecutionVertex
-
Get all produced result partitions.
- getProducer() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- getProducer() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
-
- getProducer() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
-
- getProducer() - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingResultPartition
-
Gets the producer of this result partition.
- getProducerExecutionId() - Method in class org.apache.flink.runtime.shuffle.ProducerDescriptor
-
- getProducerExecutionState() - Method in interface org.apache.flink.runtime.io.network.partition.PartitionProducerStateProvider.ResponseHandle
-
- getProducerId() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionID
-
- getProducerLocation() - Method in class org.apache.flink.runtime.shuffle.ProducerDescriptor
-
- getProperties() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the properties of this checkpoint.
- getProperties() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getProperties() - Method in class org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
-
Returns the properties of the restored checkpoint.
- getProxyPortRange() - Method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
-
Returns the port range where the queryable state client proxy can listen.
- getPushChainDriverClass() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
-
- getQuantile(double) - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
-
- getQueryParameter(Class<QP>) - Method in class org.apache.flink.runtime.rest.handler.HandlerRequest
-
- getQueryParameter(HandlerRequest<R, M>, Class<P>) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRequestUtils
-
Returns the value of a query parameter, or null
if the query parameter is not set.
- getQueryParameter(HandlerRequest<R, M>, Class<P>, X) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRequestUtils
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.EmptyMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexMetricsMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.JobCancellationMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.JobMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.JobVertexMessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.MessageParameters
-
- getQueryParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerMessageParameters
-
- getQueryServiceMessageSizeLimit() - Method in class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
-
- getQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Returns the metric query service scope for this group.
- getRatio() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
-
- getRawKeyedOperatorStateOutput() - Method in interface org.apache.flink.runtime.state.StateSnapshotContext
-
Returns an output stream for keyed state
- getRawKeyedOperatorStateOutput() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
-
- getRawKeyedState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
-
Returns a handle to the raw keyed state.
- getRawKeyedState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
- getRawKeyedStateHandles(OperatorState, KeyGroupRange) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
-
- getRawKeyedStateInputs() - Method in interface org.apache.flink.runtime.state.StateInitializationContext
-
Returns an iterable to obtain input streams for previously stored keyed state partitions that are assigned to
this operator.
- getRawKeyedStateInputs() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
-
- getRawOperatorState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
-
Returns a handle to the raw operator state.
- getRawOperatorState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
- getRawOperatorStateInputs() - Method in interface org.apache.flink.runtime.state.StateInitializationContext
-
Returns an iterable to obtain input streams for previously stored operator state partitions that are assigned to
this operator.
- getRawOperatorStateInputs() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
-
- getRawOperatorStateOutput() - Method in interface org.apache.flink.runtime.state.StateSnapshotContext
-
Returns an output stream for operator state
- getRawOperatorStateOutput() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
-
- getReadEndAfterSuperstepEnded() - Method in class org.apache.flink.runtime.iterative.concurrent.BlockingBackChannel
-
Called by iteration head after it has sent all input for the current superstep through the data channel
(blocks iteration head).
- getReader(int, StateMetaInfoSnapshotReadersWriters.StateTypeHint) - Static method in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshotReadersWriters
-
- getReaderIndex() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Returns the reader index of this buffer.
- getReaderIndex() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getReaderIndex() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- getReadingThread(ExceptionHandler<IOException>, MutableObjectIterator<E>, UnilateralSortMerger.CircularQueues<E>, LargeRecordHandler<E>, AbstractInvokable, TypeSerializer<E>, long) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
Creates the reading thread.
- getReadPosition() - Method in class org.apache.flink.runtime.io.disk.RandomAccessInputView
-
- getReason() - Method in class org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint
-
Gets the reason why the checkpoint was declined.
- getReason() - Method in class org.apache.flink.runtime.registration.RegistrationResponse.Decline
-
Gets the reason for the rejection.
- getReceiveRatePerInterface(int) - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
-
- getReceiverId() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
- getRecord(int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- getRecord(T, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- getRecord(int) - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Gets the record at the given logical position.
- getRecord(T, int) - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Gets the record at the given logical position.
- getRecord(int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- getRecord(T, int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- getRecordCount() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
number of records in partition including garbage
- getRecordsRead() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
-
- getRecordsWritten() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
-
- getRecursionLevel() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
Gets this partition's recursion level.
- getRecycler() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Gets the buffer's recycler.
- getRecycler() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getRecycler() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- getRedirectResponse(String, String, HttpResponseStatus) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRedirectUtils
-
- getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
-
- getReference() - Method in class org.apache.flink.runtime.state.SharedStateRegistry.Result
-
- getReferenceBytes() - Method in class org.apache.flink.runtime.state.CheckpointStorageLocationReference
-
Gets the reference bytes.
- getReferenceCount() - Method in class org.apache.flink.runtime.state.SharedStateRegistry.Result
-
- getRefreshInterval() - Method in class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
-
- getRefreshInterval() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
-
- getRefusedDelayMillis() - Method in class org.apache.flink.runtime.registration.RetryingRegistrationConfiguration
-
- getRefusedRegistrationPause() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getRegisteredBroadcastStateNames() - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- getRegisteredExecutions() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getRegisteredStateNames() - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- getRegistrationId() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
-
Gets the ID that the ResourceManager assigned the registration.
- getRegistrationName() - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Returns the name under which the KvState instances have been registered.
- getRegistrationName() - Method in class org.apache.flink.runtime.query.KvStateMessage.LookupKvStateLocation
-
Returns the name under which the KvState has been registered.
- getRegistrationName() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
-
Returns the name under which the KvState has been registered.
- getRegistrationName() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
-
Returns the name under which the KvState has been registered.
- getRelativeBackChannelMemory() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getRelativeInputMaterializationMemory(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getRelativeMemoryDriver() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getRelativeMemoryInput(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getRelativeSolutionSetMemory() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getReleaseFuture() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Gets the release future which is completed once the execution reaches a terminal
state and the assigned resource has been released.
- getRemainingResources() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSelectionStrategy.SlotInfoAndResources
-
- getReporter() - Method in class org.apache.flink.runtime.metrics.ReporterSetup
-
- getReporters() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
- getRequest() - Method in class org.apache.flink.runtime.rest.handler.router.RoutedRequest
-
- getRequestBody() - Method in class org.apache.flink.runtime.rest.handler.HandlerRequest
-
Returns the request body.
- getRequestClass() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointTriggerHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobCancellationHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
-
- getRequestClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerStdoutFileHeaders
-
- getRequestClass() - Method in interface org.apache.flink.runtime.rest.messages.UntypedResponseMessageHeaders
-
Returns the class of the request message.
- getRequestFuture() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
-
- getRequestSegmentsTimeout() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
-
- getRequiredClasspaths() - Method in class org.apache.flink.runtime.jobmaster.message.ClassloadingProps
-
- getRequiredClasspathURLs() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
-
- getRequiredJarFileBlobKeys() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
-
- getRequiredJarFiles() - Method in class org.apache.flink.runtime.jobmaster.message.ClassloadingProps
-
- getReservedNetworkMemory(Configuration, long) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
Gets the amount of memory reserved for networking, given the total JVM memory.
- getReservedResources() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.MultiTaskSlot
-
- getReservedResources() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.SingleTaskSlot
-
- getReservedResources() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.TaskSlot
-
Gets the total reserved resources of the slot and its descendants.
- getResolvedRootSlot(SlotInfo) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager
-
- getResolvedRootSlots() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager
-
Returns a collection of all resolved root slots.
- getResourceID() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceID
-
A ResourceID can always retrieve a ResourceID.
- getResourceID() - Method in interface org.apache.flink.runtime.clusterframework.types.ResourceIDRetrievable
-
Gets the ResourceID of the object.
- getResourceID() - Method in class org.apache.flink.runtime.clusterframework.types.SlotID
-
- getResourceID() - Method in class org.apache.flink.runtime.jobmaster.JMTMRegistrationSuccess
-
- getResourceID() - Method in class org.apache.flink.runtime.resourcemanager.registration.TaskExecutorConnection
-
- getResourceId() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerInfo
-
- getResourceID() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
-
- getResourceID() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- getResourceID() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- 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.
- getResourceManagerId() - Method in class org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess
-
- getResourceManagerId() - Method in class org.apache.flink.runtime.jobmaster.ResourceManagerAddress
-
- getResourceManagerId() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
-
Gets the unique ID that identifies the ResourceManager.
- getResourceManagerLeaderElectionService() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the leader election service for the cluster's resource manager.
- getResourceManagerLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
-
- getResourceManagerLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
- getResourceManagerLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getResourceManagerLeaderRetriever() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the leader retriever for the cluster's resource manager.
- getResourceManagerLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
-
- getResourceManagerLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
- getResourceManagerLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getResourceManagerResourceId() - Method in class org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess
-
- getResourceProfile() - Method in class org.apache.flink.runtime.clusterframework.types.SlotProfile
-
Returns the desired resource profile for the slot.
- getResourceProfile() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
- getResourceProfile() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
Returns the resource profile for this job vertex.
- getResourceProfile() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
-
- getResourceProfile() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getResourceProfile() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- getResourceProfile() - Method in class org.apache.flink.runtime.instance.SimpleSlotContext
-
- getResourceProfile() - Method in interface org.apache.flink.runtime.jobmaster.SlotInfo
-
Returns the resource profile of the slot.
- getResourceProfile() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl.PendingRequest
-
- getResourceProfile() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
-
- getResourceProfile() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingTaskManagerSlot
-
- getResourceProfile() - Method in class org.apache.flink.runtime.resourcemanager.SlotRequest
-
Get the resource profile of the desired slot
- getResourceProfile() - Method in class org.apache.flink.runtime.scheduler.ExecutionVertexSchedulingRequirements
-
- getResourceProfile() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotOffer
-
- getResourceProfile() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
- getResourceProfile() - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
-
Get the resource profile of this slot.
- getResources() - Method in class org.apache.flink.runtime.instance.Instance
-
- getResponse(HttpResponseStatus, String) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerRedirectUtils
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationStatusMessageHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationTriggerMessageHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobCancellationHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
-
- getResponseClass() - Method in interface org.apache.flink.runtime.rest.messages.MessageHeaders
-
Returns the class of the response message.
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
-
- getResponseClass() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
-
- getResponseHeaders() - Method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
-
Response headers that should be added to every HTTP response.
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractAggregatedMetricsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointTriggerHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobCancellationHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
-
- getResponseStatusCode() - Method in interface org.apache.flink.runtime.rest.messages.MessageHeaders
-
Returns the http status code for the response.
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
-
- getResponseStatusCode() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
-
- getResponseTypeParameters() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationStatusMessageHeaders
-
- getResponseTypeParameters() - Method in interface org.apache.flink.runtime.rest.messages.MessageHeaders
-
Returns the collection of type parameters for the response type.
- getRestAddress() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- getRestAddress() - Method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
-
- getRestAddress() - Method in interface org.apache.flink.runtime.webmonitor.WebMonitor
-
Returns the REST address of this WebMonitor.
- getRestartDelayMS() - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.FailureHandlingResult
-
Returns the delay before the restarting.
- getRestartStrategy() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getRestartStrategyFactory() - Method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
-
- getRestBaseUrl() - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
-
Returns the base URL of the REST server endpoint.
- getRestBindAddress() - Method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
-
Returns the address that the REST server endpoint should bind itself to.
- getRestBindPortRange() - Method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
-
Returns the port range that the REST server endpoint should listen on.
- getRestoreCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.JobManagerTaskRestore
-
- getRestoredCheckpointStatistics() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
-
- getRestorePath() - Method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
-
Returns the path to the savepoint to restore from.
- getRestoreTimestamp() - Method in class org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
-
Returns the timestamp when the checkpoint was restored.
- getRestoreTimestamp() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
-
- getRestPort() - Method in class org.apache.flink.runtime.entrypoint.EntrypointClusterConfiguration
-
- getResultFuture() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
-
- getResultId() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- getResultId() - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingResultPartition
-
Gets id of the intermediate result.
- getResultId() - Method in class org.apache.flink.runtime.shuffle.PartitionDescriptor
-
- getResultOptimizerProperties() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getResultPartition(IntermediateResultPartitionID) - Method in class org.apache.flink.runtime.scheduler.adapter.ExecutionGraphToSchedulingTopologyAdapter
-
- getResultPartition(IntermediateResultPartitionID) - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingTopology
-
- getResultPartitionAvailabilityChecker() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getResultPartitionConsumableNotifier() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
-
- getResultPartitionDeploymentDescriptor(IntermediateResultPartitionID) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getResultPartitionID() - Method in interface org.apache.flink.runtime.executiongraph.failover.flip1.FailoverEdge
-
Returns the ID of the result partition that the source produces.
- getResultPartitionID() - Method in class org.apache.flink.runtime.shuffle.NettyShuffleDescriptor
-
- getResultPartitionID() - Method in interface org.apache.flink.runtime.shuffle.ShuffleDescriptor
-
- getResultPartitionID() - Method in class org.apache.flink.runtime.shuffle.UnknownShuffleDescriptor
-
- getResultPartitionManager() - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
- getResultPartitionOrThrow(IntermediateResultPartitionID) - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingTopology
-
- getResultPartitionType() - Method in interface org.apache.flink.runtime.executiongraph.failover.flip1.FailoverEdge
-
- getResultType() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- getResultType() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
-
- getResultType() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
-
- getRetryingRegistrationConfiguration() - Method in class org.apache.flink.runtime.jobmaster.JobMasterConfiguration
-
- getRetryingRegistrationConfiguration() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getReturnQueue() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockReader
-
Gets the queue in which the full memory segments are queued after the asynchronous read
is complete.
- getReturnQueue() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockWriter
-
Gets the queue in which the memory segments are queued after the asynchronous write is completed.
- getReturnQueue() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelReader
-
Gets the queue in which the full memory segments are queued after the read is complete.
- getReturnQueue() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelWriter
-
Gets the queue in which the memory segments are queued after the asynchronous write
is completed
- getReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
-
- getReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.FullOuterJoinDriver
-
- getReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.LeftOuterJoinDriver
-
- getReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.RightOuterJoinDriver
-
- getRevisionInformation() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Returns the code revision (commit and commit date) of Flink, as generated by the Maven builds.
- 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.
- getRouteResult() - Method in class org.apache.flink.runtime.rest.handler.router.RoutedRequest
-
- getRpcGateway() - Method in class org.apache.flink.runtime.rpc.messages.RemoteHandshakeMessage
-
- getRPCPortRange(Configuration) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- getRpcService() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Gets the endpoint's RPC service.
- getRpcServiceSharing() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
-
- getRpcTimeout() - Method in class org.apache.flink.runtime.jobmaster.JobMasterConfiguration
-
- getRpcTimeout() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
-
- getRpcUrl(String, int, String, HighAvailabilityServicesUtils.AddressResolution, Configuration) - Static method in class org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
-
- getRpcUrl(String, int, String, HighAvailabilityServicesUtils.AddressResolution, AkkaRpcServiceUtils.AkkaProtocol) - Static method in class org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
-
- getRunnable() - Method in class org.apache.flink.runtime.rpc.messages.RunAsync
-
- getRunningJobsRegistry() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the registry that holds information about whether jobs are currently running.
- getRunningJobsRegistry() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
-
- getRunningJobsRegistry() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getSampleId() - Method in class org.apache.flink.runtime.messages.StackTraceSampleResponse
-
- getSampleId() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.OperatorBackPressureStats
-
Returns the ID of the sample.
- getSampleId() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSample
-
Returns the ID of the sample.
- getSamples() - Method in class org.apache.flink.runtime.messages.StackTraceSampleResponse
-
- getSavepointPath() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalRequest
-
- getSavepointPath() - Method in class org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
-
Gets the directory where savepoints are stored by default (when no custom path is given
to the savepoint trigger command).
- getSavepointRestoreSettings() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns the configured savepoint restore setting.
- getSavepointStatistics() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.LatestCheckpoints
-
- getScheduledExecutor() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- getScheduledExecutor() - Method in interface org.apache.flink.runtime.rpc.RpcService
-
Gets a scheduled executor from the RPC service.
- getScheduledExecutorService() - Method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
-
- getScheduleMode() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getScheduleMode() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- getScopeComponents() - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
Gets the scope as an array of the scope components, for example
["host-7", "taskmanager-2", "window_word_count", "my-mapper"]
.
- getScopeComponents() - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
-
- getScopeFormats() - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
-
Returns the scope formats.
- getScopeFormats() - Method in class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
-
- getScopeFormats() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
- getScopeFormats() - Method in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
-
- getSecondaryStreamException() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
-
- getSecurityConfig() - Method in class org.apache.flink.runtime.security.modules.HadoopModule
-
- getSecurityModuleFactories() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
-
- getSegmentsForReaders(List<List<MemorySegment>>, List<MemorySegment>, int) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
-
Divides the given collection of memory buffers among numChannels
sublists.
- getSegmentSize() - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
Gets the size of the segments used by this view.
- getSelfGateway(Class<C>) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Returns a self gateway of the specified type which can be used to issue asynchronous
calls against the RpcEndpoint.
- getSendAndReceiveBufferSize() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getSenderBacklog() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
- getSendRatePerInterface(int) - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
-
- getSequenceNumber() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
- getSerializableListState(String) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- getSerializedAccumulatorResults() - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
-
- getSerializedExecutionConfig() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
-
- getSerializedExecutionConfig() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns the ExecutionConfig
- getSerializedJobInformation() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Return the sub task's serialized job information.
- getSerializedTaskInformation() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Return the sub task's serialized task information.
- getSerializedThrowable() - Method in class org.apache.flink.runtime.jobmaster.JobResult
-
Returns an empty Optional
if the job finished successfully, otherwise the
Optional
will carry the failure cause.
- getSerializedUserAccumulators() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
-
- getSerializedValue(byte[], TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<SV>) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
- getSerializedValue(byte[], TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<V>) - Method in interface org.apache.flink.runtime.state.internal.InternalKvState
-
Returns the serialized value for the given key and namespace.
- getSerializer(T) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializers
-
- getSerializer(int) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializers
-
- getSerializerSnapshotsImmutable() - Method in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
-
- getServerAddress() - Method in interface org.apache.flink.runtime.query.KvStateServer
-
Returns the
address
the server is listening to.
- getServerAddress() - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
-
Returns the address on which this endpoint is accepting requests.
- getServerChannelHandlers() - Method in class org.apache.flink.runtime.io.network.netty.NettyProtocol
-
Returns the server channel handlers.
- getServerConnectBacklog() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getServerNumThreads() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getServerPort() - Method in interface org.apache.flink.runtime.webmonitor.WebMonitor
-
Gets the port that the web server actually binds to.
- getSessionTimeout() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Gets the timeout after which the corresponding ExecutionGraph is removed at the
job manager after it has been executed.
- getSharedSlot() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
-
Gets the shared slot into which this constraint's tasks are places.
- getSharedSlotForTask(AbstractID, Iterable<TaskManagerLocation>, boolean) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
-
- getSharedState() - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
-
- getSharedStateDirectory() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
-
- getSharedStateHandleIDs() - Method in interface org.apache.flink.runtime.state.IncrementalKeyedStateHandle
-
Returns a set of ids of all registered shared states in the backend at the time this was created.
- getSharedStateHandleIDs() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
-
- getSharedStateHandleIDs() - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
-
- getSharedStateRegistry() - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
-
- getShipStrategyName() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Gets the name of the ship strategy for the represented input, like "forward", "partition hash",
"rebalance", "broadcast", ...
- getShuffleDescriptor() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- getShuffleDescriptor() - Method in class org.apache.flink.runtime.executiongraph.PartitionInfo
-
- getShuffleDescriptors() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
-
- getShuffleEnvironment() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- getShutDownFuture() - Method in class org.apache.flink.runtime.entrypoint.component.DispatcherResourceManagerComponent
-
- getSize() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
-
- getSize() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
-
Gets the size (in bytes) of the file underlying the channel.
- getSize() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Returns the size of the written data, i.e.
- getSize() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- getSize() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- getSize() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
-
- getSize() - Method in class org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation
-
Size (#bytes of the serialized data) of the rpc invocation message.
- getSizeLimit() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
-
- getSizeOfFreeHeapMemory() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Gets an estimate of the size of the free heap memory.
- getSizeOfFreeHeapMemoryWithDefrag() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Gets an estimate of the size of the free heap memory.
- getSizeOfJvmHeap() - Method in class org.apache.flink.runtime.instance.HardwareDescription
-
Returns the size of the JVM heap memory
- getSizeOfManagedMemory() - Method in class org.apache.flink.runtime.instance.HardwareDescription
-
Returns the size of the memory managed by the system for caching, hashing, sorting, ...
- getSizeOfPhysicalMemory() - Method in class org.apache.flink.runtime.instance.HardwareDescription
-
Returns the size of physical memory in bytes available on the compute node.
- getSizeOfPhysicalMemory() - Static method in class org.apache.flink.runtime.util.Hardware
-
Returns the size of the physical memory in bytes.
- getSlot() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotAndLocality
-
- getSlot(Configuration) - Static method in class org.apache.flink.runtime.util.ConfigurationParserUtils
-
Parses the configuration to get the number of slots and validates the value.
- getSlotContext() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the allocated slot that this slot refers to.
- getSlotForTask(JobVertexID, Iterable<TaskManagerLocation>) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
-
Gets a slot suitable for the given task vertex.
- getSlotForTask(CoLocationConstraint, Iterable<TaskManagerLocation>) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
-
Gets a slot for a task that has a co-location constraint.
- getSlotId() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
- getSlotID() - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
-
Get the unique identification of this slot.
- getSlotIndex() - Method in class org.apache.flink.runtime.jobmaster.AllocatedSlotInfo
-
- getSlotIndex() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotOffer
-
- getSlotInfo() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSelectionStrategy.SlotInfoAndLocality
-
- getSlotInfo() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSelectionStrategy.SlotInfoAndResources
-
- getSlotManager() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
-
- getSlotManagerConfiguration() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
-
- getSlotNumber() - Method in class org.apache.flink.runtime.clusterframework.types.SlotID
-
- getSlotNumber() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the number of the slot.
- getSlotProviderStrategy() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getSlotRequestId() - Method in class org.apache.flink.runtime.instance.SharedSlot
-
- getSlotRequestId() - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
- getSlotRequestId() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
-
Returns the currently assigned slot request id identifying the slot to which tasks
belonging to this co-location constraint will be deployed to.
- getSlotRequestId() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Gets the slot request id uniquely identifying the request with which this
slot has been allocated.
- getSlotRequestId() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- getSlotRequestId() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl.PendingRequest
-
- getSlotRequestId() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.TaskSlot
-
- getSlotRequestTimeout() - Method in class org.apache.flink.runtime.jobmaster.JobMasterConfiguration
-
- getSlotRequestTimeout() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
-
- getSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
-
- getSlotSharingGroup() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getSlotSharingGroup() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Gets the slot sharing group that this vertex is associated with.
- getSlotSharingGroupId() - Method in class org.apache.flink.runtime.instance.SharedSlot
-
- getSlotSharingGroupId() - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
- getSlotSharingGroupId() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- getSlotSharingGroupId() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
-
- getSlotSharingGroupId() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Gets the slot sharing group id to which this slot belongs.
- getSlotSharingGroupId() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- getSlotSharingGroupId() - Method in class org.apache.flink.runtime.scheduler.ExecutionVertexSchedulingRequirements
-
- getSnapshot() - Method in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
-
Creates a snapshot of this accumulator registry.
- getSolutionSetComparator(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getSolutionSetSerializer(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getSortingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
- getSource() - Method in class org.apache.flink.runtime.executiongraph.ExecutionEdge
-
- getSource() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Returns the data set at the source of the edge.
- getSourceId() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Gets the ID of the consumed data set.
- getSourceVertex() - Method in interface org.apache.flink.runtime.executiongraph.failover.flip1.FailoverEdge
-
Returns the source vertex, i.e., the producer of the result partition.
- 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
-
- getSslHandlerFactory() - Method in class org.apache.flink.runtime.rest.RestClientConfiguration
-
Returns the
SSLEngine
that the REST client endpoint should use.
- getSslHandlerFactory() - Method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
-
Returns the
SSLEngine
that the REST server endpoint should use.
- getStackTraceOfExecutingThread() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getStackTraces() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSample
-
Returns the a map of stack traces by execution ID.
- getStartCommand(String, Map<String, String>) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Replaces placeholders in the template start command with values from startCommandValues.
- getStartKeyGroup() - Method in class org.apache.flink.runtime.state.KeyGroupRange
-
- getStartTime() - Method in class org.apache.flink.runtime.client.JobStatusMessage
-
- getStartTime() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getStartTime() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSample
-
Returns the time stamp, when the sample was triggered.
- getStartTime() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- getStartTime() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- getStartTime() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- getState(int) - Method in class org.apache.flink.runtime.checkpoint.OperatorState
-
- getState(int) - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getState() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
- getState() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
- getState() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the current
JobStatus
for this execution graph.
- getState() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
-
- getState() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getState() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getState() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getState() - Method in class org.apache.flink.runtime.executiongraph.failover.FailoverRegion
-
- getState() - Method in class org.apache.flink.runtime.query.KvStateEntry
-
- getState() - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingExecutionVertex
-
Gets the state of the execution vertex.
- getState() - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingResultPartition
-
- getState(ValueStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
-
- getState() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap.StateMapEntry
-
- getState() - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Returns the internal data structure.
- getState() - Method in interface org.apache.flink.runtime.state.StateEntry
-
Returns the state of this entry.
- getState() - Method in class org.apache.flink.runtime.state.StateEntry.SimpleStateEntry
-
- getStateIncrementalVisitor(int) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
- getStateIncrementalVisitor(int) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
- getStateIncrementalVisitor(int) - Method in class org.apache.flink.runtime.state.heap.NestedStateMap
-
- getStateIncrementalVisitor(int) - Method in class org.apache.flink.runtime.state.heap.StateMap
-
- getStateIncrementalVisitor(int) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- getStateIncrementalVisitor(int) - Method in interface org.apache.flink.runtime.state.internal.InternalKvState
-
Get global visitor of state entries.
- getStateMapSnapshotForKeyGroup(int) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTableSnapshot
-
- getStateMetaInfo() - Method in interface org.apache.flink.runtime.state.BackendWritableBroadcastState
-
- getStateMetaInfo() - Method in class org.apache.flink.runtime.state.HeapBroadcastState
-
- getStateMetaInfo() - Method in class org.apache.flink.runtime.state.PartitionableListState
-
- getStateMetaInfoSnapshots() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
-
- getStateNameToPartitionOffsets() - Method in interface org.apache.flink.runtime.state.OperatorStateHandle
-
Returns a map of meta data for all contained states by their name.
- getStateNameToPartitionOffsets() - Method in class org.apache.flink.runtime.state.OperatorStreamStateHandle
-
- getStates() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
-
- getStates() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getStateSerializer() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
- getStateSerializer() - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- getStateSerializer() - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
-
- getStateServerPortRange() - Method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
-
Returns the port range where the queryable state client proxy can listen.
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the total checkpoint state size over all subtasks.
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
-
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
-
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
-
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
-
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
-
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
-
Returns the size of the checkpointed state at this subtask.
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
-
- getStateSize() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
-
Returns the total checkpoint state size over all subtasks.
- getStateSize() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
-
- getStateSize() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- getStateSize() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics
-
- getStateSize() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatistics
-
- getStateSize() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
-
- getStateSize() - Method in class org.apache.flink.runtime.state.ChainedStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.DirectoryKeyedStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.DirectoryStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
-
Returns the file size in bytes.
- getStateSize() - Method in class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.OperatorStreamStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.PlaceholderStreamStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.RetrievableStreamStateHandle
-
- getStateSize() - Method in class org.apache.flink.runtime.state.SnapshotResult
-
- getStateSize() - Method in interface org.apache.flink.runtime.state.StateObject
-
Returns the size of the state in bytes.
- getStateSize(StateObject) - Static method in class org.apache.flink.runtime.state.StateUtil
-
Returns the size of a state object
- getStateSizeStats() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummary
-
Returns the summary stats for the state size of completed checkpoints.
- getStateSizeStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
-
Returns the summary stats for the state size.
- getStateSnapshotTransformFactory() - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
-
- getStateTable() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
This should only be used for testing.
- getStateTimestamp(ExecutionState) - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
- 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.RegisteredKeyValueStateBackendMetaInfo
-
- getStateValueSerializer() - Method in class org.apache.flink.runtime.query.KvStateInfo
-
- getStatistics() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogram
-
- getStatus() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the status of this checkpoint.
- getStatus() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
-
- getStatus() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
-
- getStatus() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
-
- getStatus() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getStatus() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- getStatus() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
-
- getStatus() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- getStatus() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
-
- getStatusTimestamp(JobStatus) - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns the timestamp for the given
JobStatus
.
- getStatusTimestamp(JobStatus) - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getStatusTimestamp(JobStatus) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getStdDev() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
-
- getStorageLocation(JobID, BlobKey) - Method in class org.apache.flink.runtime.blob.BlobServer
-
Returns a file handle to the file associated with the given blob key on the blob
server.
- getStorageLocation(JobID, BlobKey) - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
-
Returns a file handle to the file associated with the given blob key on the blob
server.
- getStorageLocation(JobID, BlobKey) - Method in class org.apache.flink.runtime.blob.TransientBlobCache
-
Returns a file handle to the file associated with the given blob key on the blob
server.
- getStoredJobsOverview() - Method in interface org.apache.flink.runtime.dispatcher.ArchivedExecutionGraphStore
-
- getStoredJobsOverview() - Method in class org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
-
- getStoredJobsOverview() - Method in class org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
-
- getStrategyName() - Method in class org.apache.flink.runtime.executiongraph.failover.AdaptedRestartPipelinedRegionStrategyNG
-
- getStrategyName() - Method in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategy
-
Gets the name of the failover strategy, for logging purposes.
- getStrategyName() - Method in class org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy
-
- getStrategyName() - Method in class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
-
- getStrategyName() - Method in class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
-
- getStream() - Method in class org.apache.flink.runtime.state.StatePartitionStreamProvider
-
Returns a stream with the data of one state partition.
- getStrictObjectMapper() - Static method in class org.apache.flink.runtime.rest.util.RestMapperUtils
-
Returns a preconfigured ObjectMapper
.
- getStub() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getStub() - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
-
- getStub() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- getStub() - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
-
- getStub() - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
-
- getStub() - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
-
- getStub() - Method in class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
-
- getStub() - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
-
- getStub() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
-
- getStub() - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
-
- getStub() - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getStubParameter(String, String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getStubParameters() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getStubType() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.CrossDriver
-
- getStubType() - Method in interface org.apache.flink.runtime.operators.Driver
-
Gets the class of the stub type that is run by this task.
- getStubType() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.JoinDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.MapDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.NoOpDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.ReduceDriver
-
- getStubType() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
-
- getStubWrapper(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getSubmittedJobGraphStore() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
Gets the submitted job graph store for the job manager
- getSubmittedJobGraphStore() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
-
- getSubmittedJobGraphStore() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getSubsetForKeyGroup(int) - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueSet
-
- getSubsetForKeyGroup(int) - Method in class org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
-
- getSubsetForKeyGroup(int) - Method in interface org.apache.flink.runtime.state.KeyGroupedInternalPriorityQueue
-
Returns the subset of elements in the priority queue that belongs to the given key-group, within the operator's
key-group range.
- getSubtask() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
-
- getSubtaskCheckpointStatistics() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails
-
- getSubtaskId() - Method in class org.apache.flink.runtime.jobgraph.OperatorInstanceID
-
- getSubtaskIndex() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
-
Returns the subtask index.
- getSubtaskIndex() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Returns the task's index in the subtask group.
- getSubtaskIndex() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- getSubtaskIndex() - Method in class org.apache.flink.runtime.scheduler.strategy.ExecutionVertexID
-
- getSubtaskMetricStore(String, String, int) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
- getSubtaskMetricStore(int) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore.TaskMetricStore
-
- getSubtasks() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo
-
- getSubtasks() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo
-
- getSubtaskState() - Method in class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
-
- getSubtaskStateByOperatorID(OperatorID) - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
-
Returns the subtask state for the given operator id (or null if not contained).
- getSubtaskStateMappings() - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
-
Returns the set of all mappings from operator id to the corresponding subtask state.
- getSubtaskStates() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
-
- getSubtaskStates() - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- getSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
-
Returns the stats for all subtasks.
- getSuccessfulCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- getSum() - Method in class org.apache.flink.runtime.checkpoint.MinMaxAvgStats
-
Returns the sum of all seen values.
- getSum() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
-
- getSummary() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics
-
- getSummary() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails
-
- getSummaryStats() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
-
Returns the snapshotted completed checkpoint summary stats.
- getSummaryStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
-
Returns the summary of the subtask stats.
- getSuperstep() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
-
- getSupportedAPIVersions() - Method in interface org.apache.flink.runtime.rest.handler.RestHandlerSpecification
-
Returns the supported API versions that this request supports.
- getSyncCheckpointDuration() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
-
Returns the duration of the synchronous part of the checkpoint.
- getSyncCheckpointDurationStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
-
Returns the summary stats for the sync checkpoint duration.
- getSyncDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration
-
- getSyncDurationMillis() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- getSynchronousDuration() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration
-
- getSystemPageSize() - Static method in class org.apache.flink.runtime.io.network.partition.PageSizeUtil
-
Tries to get the system page size.
- getSystemPageSizeOrConservativeMultiple() - Static method in class org.apache.flink.runtime.io.network.partition.PageSizeUtil
-
Tries to get the system page size.
- getSystemPageSizeOrDefault() - Static method in class org.apache.flink.runtime.io.network.partition.PageSizeUtil
-
Tries to get the system page size.
- getSystemProperties() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
-
Get the system properties.
- getSystemResourceMetricsProbingInterval() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- getTarget() - Method in class org.apache.flink.runtime.executiongraph.ExecutionEdge
-
- getTarget() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Returns the vertex connected to this edge.
- getTargetAddress() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
- getTargetAddress() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
-
- getTargetAddress() - Method in class org.apache.flink.runtime.resourcemanager.SlotRequest
-
- getTargetDirectory() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerRequestBody
-
- getTargetDirectory() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointRequestBody
-
- getTargetGateway() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
Gets the RegisteredGateway.
- getTargetLeaderId() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
- getTargetLocation() - Method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
-
Returns the target location for the checkpoint.
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.handler.legacy.files.LogFileHandlerSpecification
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.handler.legacy.files.StdoutFileHandlerSpecification
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.handler.legacy.files.WebContentHandlerSpecification
-
- getTargetRestEndpointURL() - Method in interface org.apache.flink.runtime.rest.handler.RestHandlerSpecification
-
Returns the generalized endpoint url that this request should be sent to, for example /job/:jobid
.
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedJobMetricsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedSubtaskMetricsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedTaskManagerMetricsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexMetricsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointTriggerHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobCancellationHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerStdoutFileHeaders
-
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.YarnCancelJobTerminationHeaders
-
Deprecated.
- getTargetRestEndpointURL() - Method in class org.apache.flink.runtime.rest.messages.YarnStopJobTerminationHeaders
-
Deprecated.
- getTargetSlotNumber() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
Gets the number of the slot into which the task is to be deployed.
- getTargetVertex() - Method in interface org.apache.flink.runtime.executiongraph.failover.flip1.FailoverEdge
-
Returns the target vertex, i.e., the consumer of the result partition.
- getTask(ExecutionAttemptID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Get the task for the given execution attempt id.
- getTaskAssignment() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
-
- getTaskConfig() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getTaskConfig() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- getTaskConfig() - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getTaskConfiguration() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the task-wide configuration object, originally attached to the job vertex.
- getTaskConfiguration() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
-
- getTaskConfiguration() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the task configuration object which was attached to the original
JobVertex
.
- getTaskConfiguration() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getTaskConfiguration() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getTaskEventDispatcher() - Method in interface org.apache.flink.runtime.execution.Environment
-
- getTaskEventDispatcher() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- getTaskEventDispatcher() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getTaskExecutionId() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
-
- getTaskExecutorGateway() - Method in class org.apache.flink.runtime.resourcemanager.registration.TaskExecutorConnection
-
- getTaskExecutorResourceId() - Method in class org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
-
- getTaskFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
-
- getTaskInfo() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the TaskInfo
object associated with this subtask
- getTaskInfo() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getTaskInfo() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getTaskInformationOrBlobKey() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getTaskKvStateRegistry() - Method in interface org.apache.flink.runtime.execution.Environment
-
- getTaskKvStateRegistry() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getTaskLocalSnapshot() - Method in class org.apache.flink.runtime.state.SnapshotResult
-
- getTaskManagerActions() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
-
- getTaskManagerBindAddress() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
-
- getTaskManagerConnection() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
- getTaskManagerConnection() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
-
- getTaskManagerFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
-
- getTaskManagerGateway() - Method in class org.apache.flink.runtime.instance.Instance
-
Returns the InstanceGateway of this Instance.
- getTaskManagerGateway() - Method in class org.apache.flink.runtime.instance.SimpleSlotContext
-
- getTaskManagerGateway() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the actor gateway that can be used to send messages to the TaskManager.
- getTaskManagerGateway() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Return the TaskManager gateway to talk to the TaskManager.
- getTaskManagerGateway() - Method in interface org.apache.flink.runtime.jobmaster.SlotContext
-
Gets the actor gateway that can be used to send messages to the TaskManager.
- getTaskManagerGateway() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- getTaskManagerID() - Method in class org.apache.flink.runtime.instance.Instance
-
- getTaskManagerID() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the ID of the TaskManager that offers this slot.
- getTaskManagerInfo() - Method in interface org.apache.flink.runtime.execution.Environment
-
Gets the task manager info, with configuration and hostname.
- getTaskManagerInfo() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- getTaskManagerInfo() - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getTaskManagerInfo() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getTaskManagerInfos() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersInfo
-
- getTaskManagerJobFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
-
- getTaskManagerLocation() - Method in class org.apache.flink.runtime.instance.Instance
-
- getTaskManagerLocation() - Method in class org.apache.flink.runtime.instance.SimpleSlotContext
-
- getTaskManagerLocation() - Method in class org.apache.flink.runtime.instance.Slot
-
Gets the location info of the TaskManager that offers this slot.
- getTaskManagerLocation() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Return the TaskManager location of this slot.
- getTaskManagerLocation() - Method in interface org.apache.flink.runtime.jobmaster.SlotInfo
-
Gets the location info of the TaskManager that offers this slot.
- getTaskManagerLocation() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- getTaskManagerLocation(ExecutionVertexID) - Method in class org.apache.flink.runtime.scheduler.ExecutionGraphToInputsLocationsRetrieverAdapter
-
- getTaskManagerLocation(ExecutionVertexID) - Method in interface org.apache.flink.runtime.scheduler.InputsLocationsRetriever
-
Get the task manager location future for an execution.
- getTaskManagerLocation() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- getTaskManagerLocationFuture() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getTaskManagerLogPath() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getTaskManagerMetricStore(String) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
- getTaskManagerRequestTimeout() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
-
- getTaskManagers() - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
- getTaskManagerShellCommand(Configuration, ContaineredTaskManagerParameters, String, String, boolean, boolean, boolean, Class<?>) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Generates the shell command to start a task manager.
- getTaskManagerSlotId() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingTaskManagerSlot
-
- getTaskManagerStateStore() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- getTaskManagerStdoutPath() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getTaskManagerTimeout() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
-
- getTaskMetricStore(String, String) - Method in class org.apache.flink.runtime.rest.handler.legacy.metrics.MetricStore
-
- 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
-
- getTaskOwnedStateDirectory() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorageLocation
-
- getTaskRestore() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
-
- getTaskRestore() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getTasks() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
Get all tasks running in this task slot.
- getTasks(JobID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Return an iterator over all tasks for a given job.
- getTaskSlotTable() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- getTasksNeedingRestart(ExecutionVertexID, Throwable) - Method in interface org.apache.flink.runtime.executiongraph.failover.flip1.FailoverStrategy
-
Returns a set of IDs corresponding to the set of vertices that should be restarted.
- getTasksNeedingRestart(ExecutionVertexID, Throwable) - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy
-
Returns a set of IDs corresponding to the set of vertices that should be restarted.
- getTasksPerState() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
-
- getTasksPerState() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
-
- getTaskStateManager() - Method in interface org.apache.flink.runtime.execution.Environment
-
- getTaskStateManager() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getTaskStates() - Method in interface org.apache.flink.runtime.checkpoint.savepoint.Savepoint
-
- getTaskStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
-
- getTaskStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
-
- getTaskStateSnapshot() - Method in class org.apache.flink.runtime.checkpoint.JobManagerTaskRestore
-
- getTaskStateStats(JobVertexID) - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the task state stats for the given job vertex ID or
null
if no task with such an ID is available.
- getTaskToExecute() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- getTaskVertices() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
-
Returns all execution vertices for this job vertex.
- getTaskVertices() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
-
- getTaskVertices() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- getTempDirs() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
-
- getTemporaryFileDirectory() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Gets the directory for temporary files, as returned by the JVM system property "java.io.tmpdir".
- getTerminalStateFuture() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Gets a future that completes once the task execution reaches a terminal state.
- getTerminalStateFuture() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot.Payload
-
Gets the terminal state future which is completed once the payload
has reached a terminal state.
- getTerminationFuture() - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- getTerminationFuture() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getTerminationFuture() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- getTerminationFuture() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Return a future which is completed with true when the rpc endpoint has been terminated.
- getTerminationFuture() - Method in interface org.apache.flink.runtime.rpc.RpcServer
-
Return a future which is completed when the rpc endpoint has been terminated.
- getTerminationFuture() - Method in interface org.apache.flink.runtime.rpc.RpcService
-
Returns a future indicating when the RPC service has been shut down.
- getTerminationFuture() - Method in class org.apache.flink.runtime.scheduler.LegacyScheduler
-
- getTerminationFuture() - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
-
- getTerminationFuture() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
-
- getTerminationFuture() - Method in class org.apache.flink.runtime.taskmanager.Task
-
- getThreadPriority() - Method in class org.apache.flink.runtime.clusterframework.BootstrapTools.FixedThreadPoolExecutorConfiguration
-
- getThrowableType(Throwable) - Static method in class org.apache.flink.runtime.throwable.ThrowableClassifier
-
- getTimeNanos() - Method in class org.apache.flink.runtime.rpc.messages.RunAsync
-
- getTimeout() - Method in class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
-
- getTimeout() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcServiceConfiguration
-
- getTimeout() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getTimestamp() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetaData
-
- getTimestamp() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
- getTimestamp() - Method in class org.apache.flink.runtime.executiongraph.ErrorInfo
-
Returns the timestamp for the contained exception.
- getTimestamp() - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
-
- getTimestamp() - Method in class org.apache.flink.runtime.messages.checkpoint.NotifyCheckpointComplete
-
- getTimestamp() - Method in class org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
-
- getTimestamps() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- getTimeZoneName() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
-
- getTimeZoneOffset() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfiguration
-
- getTmpDirectories() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- getTmpDirectories() - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
-
Gets the list of temporary file directories.
- getTmpDirectory() - Method in class org.apache.flink.runtime.jobmaster.JobMasterConfiguration
-
- getTmpDirPaths() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
-
- getTolerableCheckpointFailureNumber() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
-
- getTotalFields() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-
- getTotalNumberCheckpoints() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Counts
-
- getTotalNumberOfBuffers() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
Gets the total numbers of buffers (data buffers plus events).
- 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
-
- getTotalNumberOfVertices() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getTotalNumPages() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Gets the total number of memory pages managed by this memory manager.
- getTransientBlobService() - Method in class org.apache.flink.runtime.blob.BlobCacheService
-
- getTransientBlobService() - Method in class org.apache.flink.runtime.blob.BlobServer
-
- getTransientBlobService() - Method in interface org.apache.flink.runtime.blob.BlobService
-
Returns a BLOB service for accessing transient BLOBs.
- getTransportType() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
-
- getTriggerId() - Method in class org.apache.flink.runtime.rest.handler.async.OperationKey
-
Get the trigger id for the given operation key.
- getTriggerId() - Method in class org.apache.flink.runtime.rest.handler.async.TriggerResponse
-
- getTriggerTimestamp() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
-
Returns the timestamp when the checkpoint was triggered.
- getTriggerTimestamp() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- getType() - Method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
-
- getType() - Method in exception org.apache.flink.runtime.broadcast.InitializationTypeConflictException
-
- getType() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
-
- getTypeClass() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-
- getTypeSerializer(String) - Method in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
-
TODO this method should be removed once the serializer map is removed.
- getTypeSerializerSnapshot(String) - Method in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
-
- getTypeSerializerSnapshot(StateMetaInfoSnapshot.CommonSerializerKeys) - Method in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
-
- getUdfRuntimeContext() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- getUnannouncedCredit() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
Gets the currently unannounced credit.
- getUnfencedMainThreadExecutor() - Method in class org.apache.flink.runtime.rpc.FencedRpcEndpoint
-
Returns a main thread executor which is not bound to the fencing token.
- getUnionListState(ListStateDescriptor<S>) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- getUniqueInputFormat() - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
-
- getUniqueOutputFormat() - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
-
- getUnmodifiedExecutionVertices(Set<ExecutionVertexVersion>) - Method in class org.apache.flink.runtime.scheduler.ExecutionVertexVersioner
-
- getUnreleasedPartitions() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatisticsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatisticDetailsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.ClusterOverviewHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.DashboardConfigurationHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.JobSubmitHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AbstractMetricsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedJobMetricsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedSubtaskMetricsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedTaskManagerMetricsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobManagerMetricsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobMetricsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.JobVertexMetricsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.TaskManagerMetricsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalTriggerHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointTriggerHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobCancellationHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobConfigHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobExceptionsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobIdsWithStatusesOverviewHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobPlanHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobsOverviewHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobVertexAccumulatorsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobVertexBackPressureHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobVertexDetailsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.SubtasksAllAccumulatorsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerDetailsHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerLogFileHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagersHeaders
-
- getUnresolvedMessageParameters() - Method in class org.apache.flink.runtime.rest.messages.taskmanager.TaskManagerStdoutFileHeaders
-
- getUnresolvedMessageParameters() - Method in interface org.apache.flink.runtime.rest.messages.UntypedResponseMessageHeaders
-
- getUploadDir() - Method in class org.apache.flink.runtime.rest.RestServerEndpointConfiguration
-
Returns the directory used to temporarily store multipart/form-data uploads.
- getUploadedFiles() - Method in class org.apache.flink.runtime.rest.handler.FileUploads
-
- getUploadedFiles() - Method in class org.apache.flink.runtime.rest.handler.HandlerRequest
-
- getURLVersionPrefix() - Method in enum org.apache.flink.runtime.rest.versioning.RestAPIVersion
-
Returns the URL version prefix (e.g.
- getUseLargeRecordHandler() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getUserAccumulators() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getUserAccumulators() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo
-
- getUserAccumulatorsStringified() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
-
Returns the user-defined accumulators as strings.
- getUserAccumulatorsStringified() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
-
- getUserAccumulatorsStringified() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getUserArtifacts() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Gets the list of assigned user jar paths.
- getUserClassLoader() - Method in interface org.apache.flink.runtime.execution.Environment
-
Returns the user code class loader
- getUserClassLoader() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getUserClassLoader() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- getUserCodeClassLoader() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Returns the user code class loader of this invokable.
- getUserCodeClassLoader() - Method in interface org.apache.flink.runtime.operators.TaskContext
-
- getUserCodeClassLoaderInfo(ClassLoader) - Static method in class org.apache.flink.runtime.util.ClassLoaderUtil
-
Gets information about URL class loaders.
- getUserDefinedOperatorIDs() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
Returns a list containing the alternative IDs of all operators contained in this execution job vertex.
- getUserDefinedOperatorIDs() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- getUserJarBlobKeys() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns a set of BLOB keys referring to the JAR files required to run this job.
- getUserJars() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Gets the list of assigned user jar paths.
- getUserMap() - Method in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
-
Gets the map for user-defined accumulators.
- getUserValue() - Method in class org.apache.flink.runtime.state.ttl.TtlValue
-
- getValue() - Method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
-
- getValue() - Method in class org.apache.flink.runtime.executiongraph.metrics.DownTimeGauge
-
- getValue() - Method in class org.apache.flink.runtime.executiongraph.metrics.NumberOfFullRestartsGauge
-
- getValue() - Method in class org.apache.flink.runtime.executiongraph.metrics.RestartTimeGauge
-
- getValue() - Method in class org.apache.flink.runtime.executiongraph.metrics.UpTimeGauge
-
- getValue() - Method in class org.apache.flink.runtime.io.network.metrics.AbstractBuffersUsageGauge
-
- getValue() - Method in class org.apache.flink.runtime.io.network.metrics.InputBuffersGauge
-
- getValue() - Method in class org.apache.flink.runtime.io.network.metrics.OutputBufferPoolUsageGauge
-
- getValue() - Method in class org.apache.flink.runtime.io.network.metrics.OutputBuffersGauge
-
- getValue() - Method in class org.apache.flink.runtime.rest.messages.ClusterConfigurationInfoEntry
-
- getValue() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.Metric
-
- getValue() - Method in class org.apache.flink.runtime.rest.messages.JobAccumulatorsInfo.UserTaskAccumulator
-
- getValue() - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Returns the resolved value of this parameter, or null
if it isn't resolved yet.
- getValue() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
-
- getValue() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperVersionedValue
-
- getValueClass() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationStatusMessageHeaders
-
- getValueClass() - Method in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusHeaders
-
- getValueClass() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusHeaders
-
- getValueClass() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusHeaders
-
- getValues() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
-
- getValues() - Method in interface org.apache.flink.runtime.util.KeyGroupedIterator
-
- getValues() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator
-
Returns an iterator over all values that belong to the current key.
- getValues() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator
-
Returns an iterator over all values that belong to the current key.
- getValues1() - Method in class org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
-
- getValues1() - Method in class org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
-
- getValues1() - Method in interface org.apache.flink.runtime.operators.util.CoGroupTaskIterator
-
Returns an iterable over the left input values for the current key.
- getValues2() - Method in class org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
-
- getValues2() - Method in class org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
-
- getValues2() - Method in interface org.apache.flink.runtime.operators.util.CoGroupTaskIterator
-
Returns an iterable over the left input values for the current key.
- getValueSerializer() - Method in interface org.apache.flink.runtime.state.internal.InternalKvState
-
Returns the TypeSerializer
for the type of value this state holds.
- getValueSerializer() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
-
- getVariable() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
-
- getVariable(BroadcastVariableInitializer<T, C>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
-
- getVersion() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
-
- getVersion() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
-
- getVersion() - Method in class org.apache.flink.runtime.rest.handler.legacy.messages.ClusterOverviewWithVersion
-
- getVersion() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- getVersion() - Method in class org.apache.flink.runtime.rpc.messages.RemoteHandshakeMessage
-
- getVersion() - Method in class org.apache.flink.runtime.scheduler.ExecutionVertexVersion
-
- getVersion() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
-
- getVersion() - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
-
- getVersion() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
-
Returns the version of the code as String.
- getVersionedValue() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
-
- getVertex() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getVertex(ExecutionVertexID) - Method in class org.apache.flink.runtime.scheduler.adapter.ExecutionGraphToSchedulingTopologyAdapter
-
- getVertex(ExecutionVertexID) - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingTopology
-
- getVertexId() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
-
- getVertexOrThrow(ExecutionVertexID) - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingTopology
-
- getVertexWithAttempt() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- getVertices() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns an Iterable to iterate all vertices registered with the job graph.
- getVertices() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
-
- getVertices() - Method in class org.apache.flink.runtime.scheduler.adapter.ExecutionGraphToSchedulingTopologyAdapter
-
- getVertices() - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingTopology
-
- getVerticesAsArray() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Returns an array of all job vertices that are registered with the job graph.
- getVerticesSortedTopologicallyFromSources() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- getVerticesToAcknowledge() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
-
- getVerticesToConfirm() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
-
- getVerticesTopologically() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns an iterable containing all job vertices for this execution graph in the order they were created.
- getVerticesTopologically() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- getVerticesTopologically() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- getVerticesToRestart() - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.FailureHandlingResult
-
Returns the tasks to restart.
- getVerticesToTrigger() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
-
- getWaitForSolutionSetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- getWebMonitorEndpoint() - Method in class org.apache.flink.runtime.entrypoint.component.DispatcherResourceManagerComponent
-
- getWebMonitorLeaderElectionService() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
- getWebMonitorLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
-
- getWebMonitorLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
- getWebMonitorLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getWebMonitorLeaderRetriever() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
-
- getWebMonitorLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
-
- getWebMonitorLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
- getWebMonitorLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
-
- getWebUiDir() - Method in class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
-
- getWebUIPort() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- getWorker() - Method in class org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
-
- getWorkerIndex() - Method in class org.apache.flink.runtime.iterative.event.WorkerDoneEvent
-
- getWrappedException() - Method in exception org.apache.flink.runtime.operators.chaining.ExceptionInChainedStubException
-
- getWriteBufferSize() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Gets the write buffer size for created checkpoint stream.
- getWriteEnd() - Method in class org.apache.flink.runtime.iterative.concurrent.BlockingBackChannel
-
Called by iteration tail to save the output of the current superstep.
- getWriteOffset() - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
-
- getWriter(int) - Method in interface org.apache.flink.runtime.execution.Environment
-
- getWriter() - Static method in class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshotReadersWriters
-
- 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
- getWrittenBytes() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
-
- getZooKeeperEnsemble(Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Returns the configured ZooKeeper quorum (and removes whitespace, because ZooKeeper does not
tolerate it).
- getZooKeeperLoginContextName() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
-
- getZooKeeperServiceName() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
-
- GlobalAggregateManager - Interface in org.apache.flink.runtime.taskexecutor
-
This interface gives access to transient, named, global aggregates.
- GlobalModVersionMismatch - Exception in org.apache.flink.runtime.executiongraph
-
An exception that indicates a mismatch between the expected global modification version
of the execution graph, and the actual modification version.
- GlobalModVersionMismatch(long, long) - Constructor for exception org.apache.flink.runtime.executiongraph.GlobalModVersionMismatch
-
- go() - Method in class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger.CombiningSpillingThread
-
Entry point of the thread.
- go() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ReadingThread
-
The entry point for the thread.
- go() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SortingThread
-
Entry point of the thread.
- go() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
-
Entry point of the thread.
- go() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
-
Equivalent to the run() method.
- grantLeadership(UUID) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
Callback method when current resourceManager is granted leadership.
- grantLeadership(UUID) - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
-
- grantLeadership(UUID) - Method in interface org.apache.flink.runtime.leaderelection.LeaderContender
-
Callback method which is called by the
LeaderElectionService
upon selecting this
instance as the new leader.
- grantLeadership(UUID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
Callback method when current resourceManager is granted leadership.
- grantLeadership(UUID) - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
-
- GroupCombineChainedDriver<IN,OUT> - Class in org.apache.flink.runtime.operators.chaining
-
Chained variant of the GroupReduceCombineDriver
Acts like a combiner with a custom output type OUT.
- GroupCombineChainedDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
-
- GroupReduceCombineDriver<IN,OUT> - Class in org.apache.flink.runtime.operators
-
Non-chained combine driver which is used for a CombineGroup transformation or a GroupReduce transformation where
the user supplied a RichGroupReduceFunction with a combine method.
- GroupReduceCombineDriver() - Constructor for class org.apache.flink.runtime.operators.GroupReduceCombineDriver
-
- GroupReduceDriver<IT,OT> - Class in org.apache.flink.runtime.operators
-
GroupReduce task which is executed by a Task Manager.
- GroupReduceDriver() - Constructor for class org.apache.flink.runtime.operators.GroupReduceDriver
-
- id - Variable in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
-
The ID of the underlying channel.
- ID(File, int, Random) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
-
- IllegalExecutionStateException - Exception in org.apache.flink.runtime.executiongraph
-
- IllegalExecutionStateException(ExecutionState, ExecutionState) - Constructor for exception org.apache.flink.runtime.executiongraph.IllegalExecutionStateException
-
Creates a new IllegalExecutionStateException with the error message indicating
the expected and actual state.
- IllegalExecutionStateException(Execution, ExecutionState, ExecutionState) - Constructor for exception org.apache.flink.runtime.executiongraph.IllegalExecutionStateException
-
Creates a new IllegalExecutionStateException with the error message indicating
the expected and actual state.
- immutableEntries() - Method in class org.apache.flink.runtime.state.HeapBroadcastState
-
- includeAlternativeOperatorIDs(Map<OperatorID, ExecutionJobVertex>) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- includeLegacyJobVertexIDs(Map<JobVertexID, ExecutionJobVertex>) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- includeSerializedAccumulatorsParameter - Variable in class org.apache.flink.runtime.rest.messages.JobAccumulatorsMessageParameters
-
- increaseBackoff() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Increases the current backoff and returns whether the operation was successful.
- increment() - Method in class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
-
Increments the reference count and returns whether it was successful.
- IncrementalKeyedStateHandle - Interface in org.apache.flink.runtime.state
-
- IncrementalLocalKeyedStateHandle - Class in org.apache.flink.runtime.state
-
- IncrementalLocalKeyedStateHandle(UUID, long, DirectoryStateHandle, KeyGroupRange, StreamStateHandle, Set<StateHandleID>) - Constructor for class org.apache.flink.runtime.state.IncrementalLocalKeyedStateHandle
-
- IncrementalRemoteKeyedStateHandle - Class in org.apache.flink.runtime.state
-
The handle to states of an incremental snapshot.
- IncrementalRemoteKeyedStateHandle(UUID, KeyGroupRange, long, Map<StateHandleID, StreamStateHandle>, Map<StateHandleID, StreamStateHandle>, StreamStateHandle) - Constructor for class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
-
- incrementIterationCounter() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- index - Variable in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
The index of the subpartition at the parent partition.
- IndexedSortable - Interface in org.apache.flink.runtime.operators.sort
-
- IndexedSorter - Interface in org.apache.flink.runtime.operators.sort
-
- INDIVIDUAL_RESTART_STRATEGY_NAME - Static variable in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategyLoader
-
- INF_TIMEOUT - Static variable in class org.apache.flink.runtime.rpc.RpcUtils
-
HACK: Set to 21474835 seconds, Akka's maximum delay (Akka 2.4.20).
- inFirstIteration() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- INFO_CATEGORY_JM - Static variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
-
- INFO_CATEGORY_JOB - Static variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
-
- INFO_CATEGORY_OPERATOR - Static variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
-
- INFO_CATEGORY_TASK - Static variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
-
- INFO_CATEGORY_TM - Static variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
-
- InfoMessage - Interface in org.apache.flink.runtime.messages.webmonitor
-
Abstract base interface of all info messages exchanged between the
JobManager an for example the runtime monitor.
- 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
-
Indicates that a broadcast variable was initialized with a
DefaultBroadcastVariableInitializer
as a
non-
List
type, and later accessed using
RuntimeContext.getBroadcastVariable(String)
which
may only return lists.
- InitializationTypeConflictException(Class<?>) - Constructor for exception org.apache.flink.runtime.broadcast.InitializationTypeConflictException
-
- initialize() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- initialize() - Method in class org.apache.flink.runtime.iterative.task.IterationIntermediateTask
-
- initialize() - Method in class org.apache.flink.runtime.iterative.task.IterationTailTask
-
- initialize() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
-
- initialize() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- initialize() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- initialize() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- initialize() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
-
- initialize() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
-
- initialize() - Method in interface org.apache.flink.runtime.operators.ResettableDriver
-
- initialize() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
Initializes the framework specific components.
- initialize() - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
-
- initializeBroadcastVariable(Iterable<T>) - Method in class org.apache.flink.runtime.broadcast.DefaultBroadcastVariableInitializer
-
- initializeHandlers(CompletableFuture<String>) - Method in class org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint
-
- initializeHandlers(CompletableFuture<String>) - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
-
This method is called at the beginning of
RestServerEndpoint.start()
to setup all handlers that the REST server endpoint
implementation requires.
- initializeHandlers(CompletableFuture<String>) - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
-
- initializeLocationForCheckpoint(long) - Method in interface org.apache.flink.runtime.state.CheckpointStorageCoordinatorView
-
Initializes a storage location for new checkpoint with the given ID.
- initializeLocationForCheckpoint(long) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
-
- initializeLocationForCheckpoint(long) - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
-
- initializeLocationForSavepoint(long, String) - Method in interface org.apache.flink.runtime.state.CheckpointStorageCoordinatorView
-
Initializes a storage location for new savepoint with the given ID.
- initializeLocationForSavepoint(long, String) - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
-
Creates a file system based storage location for a savepoint.
- initializeOnMaster(ClassLoader) - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatVertex
-
- 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.
- initializeServices(Configuration) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- initialPartitionBuffersCount - Variable in class org.apache.flink.runtime.operators.hash.ReOpenableHashPartition
-
- initInputReaders() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- 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
-
- initTasks(List<ExecutionVertex>) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
-
- 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
-
- InMemorySorterFactory<T> - Interface in org.apache.flink.runtime.operators.sort
-
- InPlaceMutableHashTable<T> - Class in org.apache.flink.runtime.operators.hash
-
This hash table supports updating elements.
- InPlaceMutableHashTable(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
- InPlaceMutableHashTable.EntryIterator - Class in org.apache.flink.runtime.operators.hash
-
WARNING: Doing any other operation on the table invalidates the iterator! (Even
using getMatchFor of a prober!)
- InPlaceMutableHashTable.HashTableProber<PT> - Class in org.apache.flink.runtime.operators.hash
-
A prober for accessing the table.
- InPlaceMutableHashTable.ReduceFacade - Class in org.apache.flink.runtime.operators.hash
-
A facade for doing such operations on the hash table that are needed for a reduce operator driver.
- inProgress() - Static method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationResult
-
- inProgress() - Static method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
-
- inProgress() - Static method in class org.apache.flink.runtime.rest.messages.queue.QueueStatus
-
- input - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputGate.InputWithData
-
- input - Variable in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
-
- input - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
-
- input - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
-
- InputBufferPoolUsageGauge - Class in org.apache.flink.runtime.io.network.metrics
-
Gauge metric measuring the input buffer pool usage gauge for
SingleInputGate
s.
- InputBufferPoolUsageGauge(SingleInputGate[]) - Constructor for class org.apache.flink.runtime.io.network.metrics.InputBufferPoolUsageGauge
-
- InputBuffersGauge - Class in org.apache.flink.runtime.io.network.metrics
-
Gauge metric measuring the number of queued input buffers for
SingleInputGate
s.
- InputBuffersGauge(SingleInputGate[]) - Constructor for class org.apache.flink.runtime.io.network.metrics.InputBuffersGauge
-
- InputChannel - Class in org.apache.flink.runtime.io.network.partition.consumer
-
- InputChannel(SingleInputGate, int, ResultPartitionID, int, int, Counter, Counter) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
- InputChannel.BufferAndAvailability - Class in org.apache.flink.runtime.io.network.partition.consumer
-
A combination of a
Buffer
and a flag indicating availability of further buffers,
and the backlog length indicating how many non-event buffers are available in the
subpartition.
- InputChannelID - Class in org.apache.flink.runtime.io.network.partition.consumer
-
Identifier for input channels.
- InputChannelID() - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
-
- InputChannelID(long, long) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
-
- InputChannelID(AbstractID) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
-
- InputChannelMetrics - Class in org.apache.flink.runtime.io.network.metrics
-
- InputChannelMetrics(MetricGroup...) - Constructor for class org.apache.flink.runtime.io.network.metrics.InputChannelMetrics
-
- inputComparators - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The comparators for the central driver.
- InputDependencyConstraintChecker - Class in org.apache.flink.runtime.scheduler.strategy
-
A wrapper class for InputDependencyConstraint
checker.
- InputDependencyConstraintChecker() - Constructor for class org.apache.flink.runtime.scheduler.strategy.InputDependencyConstraintChecker
-
- inputGate - Variable in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
-
The input gate to read from.
- inputGate - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
- InputGate - Class in org.apache.flink.runtime.io.network.partition.consumer
-
An input gate consumes one or more partitions of a single produced intermediate result.
- InputGate() - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
- InputGate.InputWithData<INPUT,DATA> - Class in org.apache.flink.runtime.io.network.partition.consumer
-
Simple pojo for INPUT, DATA and moreAvailable.
- InputGateDeploymentDescriptor - Class in org.apache.flink.runtime.deployment
-
Deployment descriptor for a single input gate instance.
- InputGateDeploymentDescriptor(IntermediateDataSetID, ResultPartitionType, int, ShuffleDescriptor[]) - Constructor for class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
-
- InputGateID - Class in org.apache.flink.runtime.io.network.partition.consumer
-
- InputGateID(IntermediateDataSetID, ExecutionAttemptID) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputGateID
-
- InputGateMetrics - Class in org.apache.flink.runtime.io.network.metrics
-
Collects metrics of an input gate.
- inputGates - Variable in class org.apache.flink.runtime.io.network.metrics.AbstractBuffersUsageGauge
-
- InputGateWithMetrics - Class in org.apache.flink.runtime.taskmanager
-
This class wraps
InputGate
provided by shuffle service and it is mainly
used for increasing general input metrics from
TaskIOMetricGroup
.
- InputGateWithMetrics(InputGate, Counter) - Constructor for class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
-
- inputIterators - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The inputs reader, wrapped in an iterator.
- InputOutputFormatContainer - Class in org.apache.flink.runtime.jobgraph
-
A container for InputFormats
and OutputFormats
, along with
their Configuration
.
- InputOutputFormatContainer(ClassLoader) - Constructor for class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
-
- InputOutputFormatContainer(TaskConfig, ClassLoader) - Constructor for class org.apache.flink.runtime.jobgraph.InputOutputFormatContainer
-
- InputOutputFormatContainer.FormatUserCodeTable - Class in org.apache.flink.runtime.jobgraph
-
Container for multiple wrappers containing InputFormat
and OutputFormat
code.
- InputOutputFormatVertex - Class in org.apache.flink.runtime.jobgraph
-
A task vertex that runs an initialization and a finalization on the master.
- InputOutputFormatVertex(String) - Constructor for class org.apache.flink.runtime.jobgraph.InputOutputFormatVertex
-
- InputOutputFormatVertex(String, JobVertexID, List<JobVertexID>, List<OperatorID>, List<OperatorID>) - Constructor for class org.apache.flink.runtime.jobgraph.InputOutputFormatVertex
-
- 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.
- InputsLocationsRetriever - Interface in org.apache.flink.runtime.scheduler
-
Component to retrieve the inputs locations of a
Execution
.
- InputSplitProvider - Interface in org.apache.flink.runtime.jobgraph.tasks
-
An input split provider can be successively queried to provide a series of InputSplit
objects a
task is supposed to consume in the course of its execution.
- InputSplitProviderException - Exception in org.apache.flink.runtime.jobgraph.tasks
-
- InputSplitProviderException(String) - Constructor for exception org.apache.flink.runtime.jobgraph.tasks.InputSplitProviderException
-
- InputSplitProviderException(String, Throwable) - Constructor for exception org.apache.flink.runtime.jobgraph.tasks.InputSplitProviderException
-
- InputSplitProviderException(Throwable) - Constructor for exception org.apache.flink.runtime.jobgraph.tasks.InputSplitProviderException
-
- InputViewIterator<E> - Class in org.apache.flink.runtime.io.disk
-
- InputViewIterator(DataInputView, TypeSerializer<E>) - Constructor for class org.apache.flink.runtime.io.disk.InputViewIterator
-
- insert(T) - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
- insert(T) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
-
- insert(T) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
Inserts the given record into the hash table.
- insertAfterNoMatch(T) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
-
This method can be called after getMatchFor returned null.
- insertIntoBuildBuffer(BT) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
Inserts the given object into the current buffer.
- insertIntoProbeBuffer(PT) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
Inserts the given record into the probe side buffers.
- insertIntoTable(BT, int) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
- insertOrReplaceRecord(T) - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
- insertOrReplaceRecord(T) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
-
Replaces record in hash table if record already present or append record if not.
- insertOrReplaceRecord(T) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
-
Searches the hash table for a record with the given key.
- install() - Method in class org.apache.flink.runtime.security.modules.HadoopModule
-
- install() - Method in class org.apache.flink.runtime.security.modules.JaasModule
-
- install() - Method in interface org.apache.flink.runtime.security.modules.SecurityModule
-
Install the security module.
- install() - Method in class org.apache.flink.runtime.security.modules.ZooKeeperModule
-
- install(SecurityConfiguration) - Static method in class org.apache.flink.runtime.security.SecurityUtils
-
Installs a process-wide security configuration.
- installAsShutdownHook(Logger) - Static method in class org.apache.flink.runtime.util.JvmShutdownSafeguard
-
Installs the safeguard shutdown hook.
- installAsShutdownHook(Logger, long) - Static method in class org.apache.flink.runtime.util.JvmShutdownSafeguard
-
Installs the safeguard shutdown hook.
- installSecurityContext(Configuration) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- instance() - Static method in class org.apache.flink.runtime.broadcast.DefaultBroadcastVariableInitializer
-
- INSTANCE - Static variable in class org.apache.flink.runtime.checkpoint.RoundRobinOperatorStateRepartitioner
-
- INSTANCE - Static variable in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
-
- INSTANCE - Static variable in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2Serializer
-
The singleton instance of the serializer
- Instance - Class in org.apache.flink.runtime.instance
-
An instance represents a org.apache.flink.runtime.taskmanager.TaskManager
registered at a JobManager and ready to receive work.
- Instance(TaskManagerGateway, TaskManagerLocation, InstanceID, HardwareDescription, int) - Constructor for class org.apache.flink.runtime.instance.Instance
-
Constructs an instance reflecting a registered TaskManager.
- INSTANCE - Static variable in class org.apache.flink.runtime.io.network.api.EndOfPartitionEvent
-
The singleton instance of this event.
- INSTANCE - Static variable in class org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
-
The singleton instance of this event.
- INSTANCE - Static variable in class org.apache.flink.runtime.io.network.buffer.FreeingBufferRecycler
-
- instance() - Static method in class org.apache.flink.runtime.iterative.concurrent.BlockingBackChannelBroker
-
Retrieve singleton instance.
- instance() - Static method in class org.apache.flink.runtime.iterative.concurrent.IterationAggregatorBroker
-
Retrieve singleton instance.
- instance() - Static method in class org.apache.flink.runtime.iterative.concurrent.SolutionSetBroker
-
Retrieve the singleton instance.
- instance() - Static method in class org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrierBroker
-
- instance() - Static method in class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatchBroker
-
Retrieve the singleton instance.
- INSTANCE - Static variable in class org.apache.flink.runtime.iterative.event.TerminationEvent
-
- INSTANCE - Static variable in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
-
- INSTANCE - Static variable in class org.apache.flink.runtime.state.SnappyStreamCompressionDecorator
-
- INSTANCE - Static variable in class org.apache.flink.runtime.state.UncompressedStreamCompressionDecorator
-
- INSTANCE - Static variable in class org.apache.flink.runtime.state.VoidNamespace
-
The singleton instance
- INSTANCE - Static variable in class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- INSTANCE - Static variable in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-
- INSTANCE - Static variable in class org.apache.flink.runtime.util.FatalExitExceptionHandler
-
- 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
-
- instantiateJobManagerMetricGroup(MetricRegistry, String, Optional<Time>) - Static method in class org.apache.flink.runtime.metrics.util.MetricUtils
-
- instantiateStatusMetrics(MetricGroup) - Static method in class org.apache.flink.runtime.metrics.util.MetricUtils
-
- instantiateSystemMetrics(MetricGroup, Time) - Static method in class org.apache.flink.runtime.metrics.util.SystemResourcesMetricsInitializer
-
- instantiateTaskManagerMetricGroup(MetricRegistry, String, ResourceID, Optional<Time>) - Static method in class org.apache.flink.runtime.metrics.util.MetricUtils
-
- instantiateUserCode(TaskConfig, ClassLoader, Class<? super T>) - Static method in class org.apache.flink.runtime.operators.BatchTask
-
Instantiates a user code class from is definition in the task configuration.
- IntArrayList - Class in org.apache.flink.runtime.util
-
Minimal implementation of an array-backed list of ints
- IntArrayList(int) - Constructor for class org.apache.flink.runtime.util.IntArrayList
-
- IntermediateDataSet - Class in org.apache.flink.runtime.jobgraph
-
An intermediate data set is the data set produced by an operator - either a
source or any intermediate operation.
- IntermediateDataSet(IntermediateDataSetID, ResultPartitionType, JobVertex) - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateDataSet
-
- IntermediateDataSetID - Class in org.apache.flink.runtime.jobgraph
-
- IntermediateDataSetID() - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateDataSetID
-
Creates an new random intermediate data set ID.
- IntermediateDataSetID(AbstractID) - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateDataSetID
-
Creates a new intermediate data set ID with the bytes of the given ID.
- IntermediateDataSetID(UUID) - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateDataSetID
-
Creates a new intermediate data set ID with the bytes of the given UUID.
- IntermediateResult - Class in org.apache.flink.runtime.executiongraph
-
- IntermediateResult(IntermediateDataSetID, ExecutionJobVertex, int, ResultPartitionType) - Constructor for class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- IntermediateResultPartition - Class in org.apache.flink.runtime.executiongraph
-
- IntermediateResultPartition(IntermediateResult, ExecutionVertex, int) - Constructor for class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
-
- IntermediateResultPartitionID - Class in org.apache.flink.runtime.jobgraph
-
- IntermediateResultPartitionID() - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
-
Creates an new random intermediate result partition ID.
- IntermediateResultPartitionID(long, long) - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
-
- InternalAggregatingState<K,N,IN,SV,OUT> - Interface in org.apache.flink.runtime.state.internal
-
The peer to the AggregatingState
in the internal state type hierarchy.
- InternalAppendingState<K,N,IN,SV,OUT> - Interface in org.apache.flink.runtime.state.internal
-
The peer to the AppendingState
in the internal state type hierarchy.
- internalCallOnStart() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Internal method which is called by the RpcService implementation to start the RpcEndpoint.
- internalCallOnStop() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Internal method which is called by the RpcService implementation to stop the RpcEndpoint.
- internalDeregisterApplication(ApplicationStatus, String) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
The framework specific code to deregister the application.
- internalDeregisterApplication(ApplicationStatus, String) - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
-
- InternalFoldingState<K,N,T,ACC> - Interface in org.apache.flink.runtime.state.internal
-
- internalHandleException(IOException) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
-
Internally handles an exception and makes sure that this method returns without a problem.
- InternalKeyContext<K> - Interface in org.apache.flink.runtime.state.heap
-
This interface is the current context of a keyed state.
- InternalKeyContextImpl<K> - Class in org.apache.flink.runtime.state.heap
-
- InternalKeyContextImpl(KeyGroupRange, int) - Constructor for class org.apache.flink.runtime.state.heap.InternalKeyContextImpl
-
- InternalKvState<K,N,V> - Interface in org.apache.flink.runtime.state.internal
-
The InternalKvState
is the root of the internal state type hierarchy, similar to the
State
being the root of the public API state hierarchy.
- InternalKvState.StateIncrementalVisitor<K,N,V> - Interface in org.apache.flink.runtime.state.internal
-
The state entry visitor which supports remove and update of the last returned entries.
- InternalListState<K,N,T> - Interface in org.apache.flink.runtime.state.internal
-
The peer to the ListState
in the internal state type hierarchy.
- InternalMapState<K,N,UK,UV> - Interface in org.apache.flink.runtime.state.internal
-
The peer to the MapState
in the internal state type hierarchy.
- InternalMergingState<K,N,IN,SV,OUT> - Interface in org.apache.flink.runtime.state.internal
-
The peer to the MergingState
in the internal state type hierarchy.
- internalNioBuffer(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- InternalPriorityQueue<T> - Interface in org.apache.flink.runtime.state
-
Interface for collection that gives in order access to elements w.r.t their priority.
- InternalReducingState<K,N,T> - Interface in org.apache.flink.runtime.state.internal
-
The peer to the ReducingState
in the internal state type hierarchy.
- InternalValueState<K,N,T> - Interface in org.apache.flink.runtime.state.internal
-
The peer to the ValueState
in the internal state type hierarchy.
- invalidateCurrentSchemaSerializerAccess() - Method in class org.apache.flink.runtime.state.StateSerializerProvider
-
Invalidates access to the current schema serializer.
- inView - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
-
- inView - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
-
- invoke() - Method in class org.apache.flink.runtime.iterative.task.IterationSynchronizationSinkTask
-
- invoke() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Starts the execution.
- invoke() - Method in class org.apache.flink.runtime.operators.BatchTask
-
The main work method.
- invoke() - Method in class org.apache.flink.runtime.operators.DataSinkTask
-
- invoke() - Method in class org.apache.flink.runtime.operators.DataSourceTask
-
- invoke(Object, Method, Object[]) - Method in class org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
-
- invokeRegistration(G, F, long) - Method in class org.apache.flink.runtime.registration.RetryingRegistration
-
- IO_CURRENT_INPUT_1_WATERMARK - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_CURRENT_INPUT_2_WATERMARK - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_CURRENT_INPUT_WATERMARK - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_CURRENT_OUTPUT_WATERMARK - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_BUFFERS_IN - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_BUFFERS_OUT - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_BUFFERS_OUT_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_BYTES_IN - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_BYTES_IN_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_BYTES_OUT - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_BYTES_OUT_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_RECORDS_IN - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_RECORDS_IN_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_RECORDS_OUT - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- IO_NUM_RECORDS_OUT_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- 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
-
- 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 manager, writing files to the system 's temp directory.
- IOManagerAsync(String) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
Constructs a new asynchronous I/O manager, writing file to the given directory.
- IOManagerAsync(String[]) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
-
Constructs a new asynchronous I/O manager, writing file round robin across the given directories.
- 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) - Constructor for class org.apache.flink.runtime.executiongraph.IOMetrics
-
- IOMetrics(long, long, long, long) - Constructor for class org.apache.flink.runtime.executiongraph.IOMetrics
-
- IOMetricsInfo - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
IO metrics information.
- IOMetricsInfo(long, boolean, long, boolean, long, boolean, long, boolean) - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
-
- isAcknowledgedBy(ExecutionAttemptID) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- isActive(JobID, AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
- isAlive() - Method in class org.apache.flink.runtime.instance.Instance
-
- isAlive() - Method in class org.apache.flink.runtime.instance.Slot
-
Checks of the slot is still alive, i.e.
- isAlive() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
True if the slot is alive and has not been released.
- isAlive() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- isAllocated(JobID, AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
- isAllocated(int, JobID, AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Check whether the slot for the given index is allocated for the given job and allocation id.
- isArchived() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns whether this execution graph was archived.
- isArchived() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- isArchived() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- isAssigned() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
-
Checks whether the location of this constraint has been assigned.
- isAssigned() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
-
- isAssignedAndAlive() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
-
- isAvailable(IntermediateResultPartitionID) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraphResultPartitionAvailabilityChecker
-
- isAvailable(IntermediateResultPartitionID) - Method in interface org.apache.flink.runtime.executiongraph.failover.flip1.ResultPartitionAvailabilityChecker
-
Returns whether the given partition is available.
- isAvailable() - Method in interface org.apache.flink.runtime.io.AvailabilityListener
-
Check if this instance is available for further processing.
- isAvailable() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
Checks whether this reader is available or not.
- isAvailable - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
- isAvailable() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
- isAvailable() - Method in class org.apache.flink.runtime.io.network.partition.NoOpResultSubpartitionView
-
- isAvailable() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
-
- isAvailable() - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
-
- isBasicType() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-
- isBatchRequest() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl.PendingRequest
-
- isBlocking() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
- isBounded() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
Whether this partition uses a limited number of (network) buffers or not.
- isBroadcast() - Method in interface org.apache.flink.runtime.io.network.api.writer.ChannelSelector
-
Returns whether the channel selector always selects all the output channels.
- isBroadcast() - Method in class org.apache.flink.runtime.io.network.api.writer.RoundRobinChannelSelector
-
- isBroadcast() - Method in class org.apache.flink.runtime.operators.shipping.OutputEmitter
-
- isBuffer() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileSegment
-
- isBuffer() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Returns whether this buffer represents a buffer or an event.
- isBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
-
- isBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- isBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- isBuffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
-
- isBufferConsumed() - Method in enum org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
-
- isBytesReadComplete() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
-
- isBytesWrittenComplete() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
-
- isCanceled() - Method in class org.apache.flink.runtime.heartbeat.HeartbeatMonitorImpl
-
- isCanceled() - Method in class org.apache.flink.runtime.instance.Slot
-
Checks of the slot has been cancelled.
- isCanceled() - Method in class org.apache.flink.runtime.registration.RetryingRegistration
-
Checks if the registration was canceled.
- isCanceledOrFailed() - Method in class org.apache.flink.runtime.taskmanager.Task
-
Checks whether the task has failed, is canceled, or is being canceled at the moment.
- isCancelJob() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerRequestBody
-
- isCancelled() - Method in class org.apache.flink.runtime.concurrent.ScheduledFutureAdapter
-
- isCancelled() - Method in class org.apache.flink.runtime.state.DoneFuture
-
- isCheckpointingEnabled() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Checks if the checkpointing was enabled for this job graph
- isClosed() - Method in class org.apache.flink.runtime.blob.BlobClient
-
- isClosed() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
-
- isClosed() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
- isClosed() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
- isClosed() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
-
Checks whether the channel has been closed.
- isClosed() - Method in class org.apache.flink.runtime.io.disk.iomanager.RequestQueue
-
Checks whether this request queue is closed.
- isClosed() - Method in class org.apache.flink.runtime.io.disk.iomanager.SynchronousFileIOChannel
-
- isClosed() - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
- isClosed() - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
- isClosed() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
- isClosed() - Method in class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
-
- isClosed() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
-
- isClosed() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
-
Checks whether the stream is closed.
- isClosed() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
-
- isCompacted() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
- isCompleted() - Method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
-
Returns whether the checkpoint has completed successfully.
- isConnected() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
- isConsumable() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
-
- isConverged(int, LongValue) - Method in class org.apache.flink.runtime.iterative.convergence.WorksetEmptyConvergenceCriterion
-
- isCreditBased() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
-
- isDefaultReference() - Method in class org.apache.flink.runtime.state.CheckpointStorageLocationReference
-
Returns true, if this object is the default reference.
- isDefaultVersion() - Method in enum org.apache.flink.runtime.rest.versioning.RestAPIVersion
-
Returns whether this version is the default REST API version.
- isDestroyed() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
Checks whether this buffer pool has been destroyed.
- isDestroyed() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
Returns whether the buffer provider has been destroyed.
- isDestroyed() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- isDirect() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- isDiscarded() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
-
Returns whether the checkpoint has been discarded.
- isDiscarded() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- isDiscarded() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics.CompletedCheckpointStatistics
-
- isDisposed() - Method in class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
-
Returns whether the reference count has reached the disposed state.
- isDone() - Method in class org.apache.flink.runtime.concurrent.ScheduledFutureAdapter
-
- isDone() - Method in class org.apache.flink.runtime.state.DoneFuture
-
- isEmpty() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- isEmpty() - Method in class org.apache.flink.runtime.jobmaster.SerializedInputSplit
-
- isEmpty() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager
-
- isEmpty() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
Checks whether the buffer is empty.
- isEmpty() - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Checks whether the buffer is empty.
- isEmpty() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
Checks whether the buffer is empty.
- isEmpty() - Method in class org.apache.flink.runtime.state.ChainedStateHandle
-
Check if there are any states handles present.
- isEmpty() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
-
- isEmpty() - Method in class org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
-
- isEmpty() - Method in class org.apache.flink.runtime.state.heap.StateMap
-
- isEmpty() - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- isEmpty() - Method in interface org.apache.flink.runtime.state.InternalPriorityQueue
-
Check if the set contains any elements.
- isEmpty() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
- isEmpty() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
-
- isEmpty() - Method in class org.apache.flink.runtime.util.IntArrayList
-
- isEmpty() - Method in class org.apache.flink.runtime.util.LongArrayList
-
- isEndOfSuperstep() - Method in class org.apache.flink.runtime.iterative.task.SyncEventHandler
-
- isEvent(Buffer, Class<?>) - Static method in class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
-
Identifies whether the given buffer encodes the given event.
- isEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
-
- isExactlyOnce() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
-
- isFailed() - Method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
-
Returns whether the checkpoint has failed.
- isFinished() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- isFinished() - Method in interface org.apache.flink.runtime.io.AvailabilityListener
-
- isFinished() - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
-
- isFinished() - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
-
Returns whether the reader has consumed the input.
- isFinished() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
- isFinished() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
-
- isFinished() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
- isFinished() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- isFinished() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
-
- isFinished() - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
-
- isForcePartitionReleaseOnConsumption() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
-
- isFree() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
- isFull() - Method in class org.apache.flink.runtime.io.network.buffer.BufferBuilder
-
- isFullBuffer() - Method in enum org.apache.flink.runtime.io.network.api.serialization.RecordSerializer.SerializationResult
-
Whether the target buffer is full after the serialization process.
- isFullRecord() - Method in enum org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
-
- isFullRecord() - Method in enum org.apache.flink.runtime.io.network.api.serialization.RecordSerializer.SerializationResult
-
Whether the full record was serialized and completely written to
a target buffer.
- isFullyAcknowledged() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
- isGloballyTerminalState() - Method in enum org.apache.flink.runtime.jobgraph.JobStatus
-
Checks whether this state is globally terminal.
- isHighAvailabilityModeActivated(Configuration) - Static method in enum org.apache.flink.runtime.jobmanager.HighAvailabilityMode
-
Returns true if the defined recovery mode supports high availability.
- isIdle() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
-
- isIdReference() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
- isImmutableType() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- isImmutableType() - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- isInMemory() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
Checks whether this partition is in memory or spilled.
- isInProgress() - Method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
-
Returns whether the checkpoint is in progress.
- isInputAsynchronouslyMaterialized(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- isInputCached(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- isInputResettable(int) - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
-
- isInputResettable(int) - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- isInputResettable(int) - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- isInputResettable(int) - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
-
- isInputResettable(int) - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
-
- isInputResettable(int) - Method in interface org.apache.flink.runtime.operators.ResettableDriver
-
- isInputVertex() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- isInternalSSLEnabled(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
Checks whether SSL for internal communication (rpc, data transport, blob server) is enabled.
- isIterativeInputGate(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- isKeyGroupAlreadyFinished(int) - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
-
Returns true if the key group is already completely written and immutable.
- isKeyGroupAlreadyStarted(int) - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
-
Returns true, if the key group with the given id was already started.
- isKeyType() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-
- isLeader() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
-
- isLocalCommunicationOnly() - Method in class org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
-
- isLocalRecoveryEnabled() - Method in class org.apache.flink.runtime.state.LocalRecoveryConfig
-
- isLocalTo(ResourceID) - Method in class org.apache.flink.runtime.shuffle.NettyShuffleDescriptor
-
- isMandatory() - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Returns whether this parameter must be resolved for the request.
- isMatching(ResourceProfile) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Check whether required resource profile can be matched.
- isMatchingRequirement(ResourceProfile) - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
-
Check whether required resource profile can be matched by this slot.
- isMaterializing() - Method in enum org.apache.flink.runtime.operators.DamBehavior
-
Checks whether this enumeration represents some form of materialization,
either with a full dam or without.
- isMaterializing() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
-
- isMaxParallelismConfigured() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- isModified(ExecutionVertexVersion) - Method in class org.apache.flink.runtime.scheduler.ExecutionVertexVersioner
-
- isMoreAvailable() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition.BufferAndBacklog
-
- isNetworkDetailedMetrics() - Method in class org.apache.flink.runtime.taskmanager.NettyShuffleEnvironmentConfiguration
-
- isNetworkStrategy() - Method in enum org.apache.flink.runtime.operators.shipping.ShipStrategyType
-
- isNullOrEmpty(ChainedStateHandle<?>) - Static method in class org.apache.flink.runtime.state.ChainedStateHandle
-
- isNumBytesInComplete() - Method in class org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
-
- isNumBytesOutComplete() - Method in class org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
-
- isNumRecordsInComplete() - Method in class org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
-
- isNumRecordsOutComplete() - Method in class org.apache.flink.runtime.rest.handler.util.MutableIOMetrics
-
- isOutputVertex() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- isOwner(T) - Method in class org.apache.flink.runtime.state.heap.StateMapSnapshot
-
Returns true iff the given state map is the owner of this snapshot object.
- isPartitionTracked(ResultPartitionID) - Method in interface org.apache.flink.runtime.io.network.partition.PartitionTracker
-
Returns whether the given partition is being tracked.
- isPartitionTracked(ResultPartitionID) - Method in class org.apache.flink.runtime.io.network.partition.PartitionTrackerImpl
-
- isPeriodicCheckpointingConfigured() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Returns whether periodic checkpointing has been configured.
- 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.
- isPreferCheckpointForRecovery() - Method in class org.apache.flink.runtime.jobgraph.tasks.CheckpointCoordinatorConfiguration
-
- isPreFlight() - Method in enum org.apache.flink.runtime.checkpoint.CheckpointFailureReason
-
- isProducerReadyOrAbortConsumption(PartitionProducerStateProvider.ResponseHandle) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteChannelStateChecker
-
- isQueuedSchedulingAllowed() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- isRecordsReadComplete() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
-
- isRecordsWrittenComplete() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
-
- isRecycled() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Returns whether this buffer has been recycled or not.
- isRecycled() - Method in class org.apache.flink.runtime.io.network.buffer.BufferConsumer
-
- isRecycled() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- isRecycled() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- isRegisteredAsAvailable() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
- isReleased() - Method in class org.apache.flink.runtime.instance.Slot
-
Checks of the slot has been released.
- isReleased() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
- isReleased() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
- isReleased() - Method in class org.apache.flink.runtime.io.network.partition.NoOpResultSubpartitionView
-
- isReleased() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Whether this partition is released.
- isReleased() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
- isReleased() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
-
- isReleasing() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
- isResolved() - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Returns whether this parameter has been resolved.
- isResolved() - Method in class org.apache.flink.runtime.rest.messages.MessageParameters
-
Returns whether all mandatory parameters have been resolved.
- isRestored() - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState
-
Returns true if this was created for a restored operator, false otherwise.
- isRestored() - Method in interface org.apache.flink.runtime.state.ManagedInitializationContext
-
Returns true, if state was restored from the snapshot of a previous execution.
- isRestored() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
-
- isRestSSLAuthenticationEnabled(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
Checks whether mutual SSL authentication for the external REST endpoint is enabled.
- isRestSSLEnabled(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
-
Checks whether SSL for the external REST endpoint is enabled.
- isRootAndEmpty() - Method in class org.apache.flink.runtime.instance.SharedSlot
-
Checks whether this slot is a root slot that has not yet added any child slots.
- isRunning() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
Checks if the mini cluster was started and is running.
- isRunning() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
-
Checks whether this thread is still alive.
- isRunning() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Returns whether the RPC endpoint is started and not stopped or being stopped.
- isRunningInExpectedThread(Thread) - Static method in class org.apache.flink.runtime.rpc.MainThreadValidatorUtil
-
Returns true iff the current thread is equals to the provided expected thread and logs violations.
- isSavepoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
-
Returns whether the checkpoint properties describe a standard savepoint.
- isSavepoint() - Method in enum org.apache.flink.runtime.checkpoint.CheckpointType
-
- isSavepoint() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
-
- isSavepoint() - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointStatistics
-
- isShutdown() - Method in class org.apache.flink.runtime.blob.BlobServer
-
Tests whether the BLOB server has been requested to shut down.
- isShutdown() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- isShutDown() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
-
- isShutdown() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
-
- isShutdown() - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
-
- isShutdown() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Checks whether the MemoryManager has been shut down.
- isShutdown() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
Returns whether this registry has been shutdown.
- isShutdown() - Method in class org.apache.flink.runtime.taskexecutor.KvStateService
-
- isSlotFree(int) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Check whether the task slot with the given index is free.
- isSnapshotCompleted() - Method in class org.apache.flink.runtime.state.SnapshotDirectory
-
Returns true
if the snapshot is marked as completed.
- isSolutionSetUnmanaged() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- isSolutionSetUpdate - Variable in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- isSSLEnabled(Configuration) - Static method in enum org.apache.flink.runtime.webmonitor.history.HistoryServerUtils
-
- isStableVersion() - Method in enum org.apache.flink.runtime.rest.versioning.RestAPIVersion
-
Returns whether this version is considered stable.
- isStarted() - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
Checks whether the service has been started.
- isStillAlive(long, long) - Method in class org.apache.flink.runtime.instance.Instance
-
Checks whether the last heartbeat occurred within the last n
milliseconds
before the given timestamp now
.
- isStoppable() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
-
Returns whether the job for this execution graph is stoppable.
- isStoppable() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
-
- isStoppable() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- isStoppable() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- isStoppable() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
-
- isSuccess() - Method in class org.apache.flink.runtime.jobmaster.JobResult
-
Returns true
if the job finished successfully.
- isSynchronous() - Method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
-
Returns whether the checkpoint properties describe a synchronous savepoint/checkpoint.
- isSynchronous() - Method in enum org.apache.flink.runtime.checkpoint.CheckpointType
-
- isTerminal() - Method in enum org.apache.flink.runtime.execution.ExecutionState
-
- isTerminalState() - Method in enum org.apache.flink.runtime.jobgraph.JobStatus
-
Checks whether this state is locally terminal.
- isTrackingPartitionsFor(ResourceID) - Method in interface org.apache.flink.runtime.io.network.partition.PartitionTracker
-
Returns whether any partition is being tracked for the given task executor ID.
- isTrackingPartitionsFor(ResourceID) - Method in class org.apache.flink.runtime.io.network.partition.PartitionTrackerImpl
-
- isTtlStateSerializer(TypeSerializer<?>) - Static method in class org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
-
- isTupleType() - Method in class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-
- isUnknown() - Method in interface org.apache.flink.runtime.shuffle.ShuffleDescriptor
-
Returns whether the partition is known and registered with the
ShuffleMaster
implementation.
- isUnknown() - Method in class org.apache.flink.runtime.shuffle.UnknownShuffleDescriptor
-
- isUsingAsynchronousSnapshots() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
-
Gets whether the key/value data structures are asynchronously snapshotted.
- isUsingAsynchronousSnapshots() - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
-
Gets whether the key/value data structures are asynchronously snapshotted.
- isUsingKeyGroupCompression() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
-
- isValid(K, UUID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TimerService
-
Check whether the timeout for the given key and ticket is still valid (not yet unregistered
and not yet overwritten).
- isValidTimeout(JobID, UUID) - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
- isValidTimeout(AllocationID, UUID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Check whether the timeout with ticket is valid for the given allocation id.
- isWaitResultConsumedBeforeRelease() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
-
- isWorksetIteration - Variable in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- isWorksetUpdate - Variable in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- isWritable() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- isWritable(int) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- isZkSaslDisable() - Method in class org.apache.flink.runtime.security.SecurityConfiguration
-
- isZooKeeperRecoveryMode(Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
- IterationAggregatorBroker - Class in org.apache.flink.runtime.iterative.concurrent
-
- IterationAggregatorBroker() - Constructor for class org.apache.flink.runtime.iterative.concurrent.IterationAggregatorBroker
-
- IterationEventWithAggregators - Class in org.apache.flink.runtime.iterative.event
-
Base class for iteration
TaskEvent
transmitting operator aggregators.
- IterationEventWithAggregators() - Constructor for class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
-
- IterationEventWithAggregators(String, Value) - Constructor for class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
-
- IterationEventWithAggregators(Map<String, Aggregator<?>>) - Constructor for class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
-
- IterationHeadTask<X,Y,S extends org.apache.flink.api.common.functions.Function,OT> - Class in org.apache.flink.runtime.iterative.task
-
The head is responsible for coordinating an iteration and can run a
Driver
inside.
- IterationHeadTask(Environment) - Constructor for class org.apache.flink.runtime.iterative.task.IterationHeadTask
-
Create an Invokable task and set its environment.
- IterationIntermediateTask<S extends org.apache.flink.api.common.functions.Function,OT> - Class in org.apache.flink.runtime.iterative.task
-
An intermediate iteration task, which runs a
Driver
inside.
- IterationIntermediateTask(Environment) - Constructor for class org.apache.flink.runtime.iterative.task.IterationIntermediateTask
-
Create an Invokable task and set its environment.
- IterationSynchronizationSinkTask - Class in org.apache.flink.runtime.iterative.task
-
The task responsible for synchronizing all iteration heads, implemented as an output task.
- IterationSynchronizationSinkTask(Environment) - Constructor for class org.apache.flink.runtime.iterative.task.IterationSynchronizationSinkTask
-
Create an Invokable task and set its environment.
- IterationTailTask<S extends org.apache.flink.api.common.functions.Function,OT> - Class in org.apache.flink.runtime.iterative.task
-
An iteration tail, which runs a driver inside.
- IterationTailTask(Environment) - Constructor for class org.apache.flink.runtime.iterative.task.IterationTailTask
-
Create an Invokable task and set its environment.
- iterativeBroadcastInputs - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The indices of the iterative broadcast inputs.
- iterativeInputs - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The indices of the iterative inputs.
- iterator() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- iterator() - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.partitionrelease.PipelinedRegion
-
- iterator() - Method in class org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
-
- iterator() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- iterator() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable
-
- iterator() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
-
- iterator - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
The iterator to be returned by the sort-merger.
- iterator() - Method in class org.apache.flink.runtime.operators.util.metrics.CountingIterable
-
- iterator() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
-
Returns an iterator over the elements in this queue.
- iterator() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
- iterator() - Method in class org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
-
- iterator() - Method in class org.apache.flink.runtime.state.heap.NestedStateMap
-
- iterator() - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- iterator() - Method in class org.apache.flink.runtime.state.HeapBroadcastState
-
- iterator() - Method in interface org.apache.flink.runtime.state.InternalPriorityQueue
-
Iterator over all elements, no order guaranteed.
- iterator() - Method in class org.apache.flink.runtime.state.KeyGroupRange
-
- iterator() - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
-
- iterator() - Method in class org.apache.flink.runtime.taskexecutor.SlotReport
-
- iterator() - Method in class org.apache.flink.runtime.util.EmptyIterator
-
- iterator() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
-
- iterator() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator.ValuesIterator
-
- iterator() - Method in class org.apache.flink.runtime.util.NonReusingMutableToRegularIteratorWrapper
-
- iterator() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator.ValuesIterator
-
- iterator() - Method in class org.apache.flink.runtime.util.ReusingMutableToRegularIteratorWrapper
-
- iterator() - Method in class org.apache.flink.runtime.util.SingleElementIterator
-
- iterator1 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- iterator2 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- iteratorException - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
The exception that is set, if the iterator cannot be created.
- iteratorLock - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
The monitor which guards the iterator field.
- RandomAccessInputView - Class in org.apache.flink.runtime.io.disk
-
- RandomAccessInputView(ArrayList<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.RandomAccessInputView
-
- RandomAccessInputView(ArrayList<MemorySegment>, int, int) - Constructor for class org.apache.flink.runtime.io.disk.RandomAccessInputView
-
- RandomAccessOutputView - Class in org.apache.flink.runtime.io.disk
-
- RandomAccessOutputView(MemorySegment[], int) - Constructor for class org.apache.flink.runtime.io.disk.RandomAccessOutputView
-
- RandomAccessOutputView(MemorySegment[], int, int) - Constructor for class org.apache.flink.runtime.io.disk.RandomAccessOutputView
-
- randomEmit(T) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
This is used to send LatencyMarks to a random target channel.
- RangeBoundaryBuilder<T> - Class in org.apache.flink.runtime.operators.udf
-
Build RangeBoundaries with input records.
- RangeBoundaryBuilder(TypeComparatorFactory<T>, int) - Constructor for class org.apache.flink.runtime.operators.udf.RangeBoundaryBuilder
-
- rate - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.MeterDump
-
- RawJsonDeserializer - Class in org.apache.flink.runtime.rest.messages.json
-
Json deserializer which deserializes raw json.
- RawJsonDeserializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.RawJsonDeserializer
-
- read() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileSegmentReader
-
- read() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileSegmentReader
-
- read(DataInputView) - Method in class org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
-
- read(DataInputView) - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
-
- read(DataInputView) - Method in class org.apache.flink.runtime.io.network.api.EndOfPartitionEvent
-
- read(DataInputView) - Method in class org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
-
- read(DataInputView) - Method in class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
-
- read(DataInputView) - Method in class org.apache.flink.runtime.iterative.event.TerminationEvent
-
- read(DataInputView) - Method in class org.apache.flink.runtime.iterative.event.WorkerDoneEvent
-
- read(byte[]) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- read(byte[], int, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- read(DataInputView) - Method in class org.apache.flink.runtime.plugable.NonReusingDeserializationDelegate
-
- read(DataInputView) - Method in class org.apache.flink.runtime.plugable.ReusingDeserializationDelegate
-
- read(DataInputView) - Method in class org.apache.flink.runtime.plugable.SerializationDelegate
-
- read() - Method in class org.apache.flink.runtime.state.BoundedInputStream
-
- read(byte[]) - Method in class org.apache.flink.runtime.state.BoundedInputStream
-
- read(byte[], int, int) - Method in class org.apache.flink.runtime.state.BoundedInputStream
-
- read(DataInputView) - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
-
- read(DataInputView) - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
-
- read() - Method in class org.apache.flink.runtime.util.ForwardingInputStream
-
- read(byte[]) - Method in class org.apache.flink.runtime.util.ForwardingInputStream
-
- read(byte[], int, int) - Method in class org.apache.flink.runtime.util.ForwardingInputStream
-
- readableBytes() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
- 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
-
- readBufferFromFileChannel(Buffer) - Method in class org.apache.flink.runtime.io.disk.iomanager.BufferFileChannelReader
-
Reads data from the object's file channel into the given buffer.
- readByte() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readBytes(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- readChar() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readDouble() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readElement(DataInputView) - Method in interface org.apache.flink.runtime.state.KeyGroupPartitioner.ElementReaderFunction
-
- reader - Variable in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
- Reader<T extends org.apache.flink.core.io.IOReadableWritable> - Interface in org.apache.flink.runtime.io.network.api.reader
-
A record-oriented reader for immutable record types.
- ReaderBase - Interface in org.apache.flink.runtime.io.network.api.reader
-
The basic API for every reader.
- ReaderIterator<T> - Class in org.apache.flink.runtime.operators.util
-
A MutableObjectIterator
that wraps a reader from an input channel and
produces the reader's records.
- ReaderIterator(MutableReader<DeserializationDelegate<T>>, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.operators.util.ReaderIterator
-
Creates a new iterator, wrapping the given reader.
- readFloat() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readFully(byte[]) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readFully(byte[], int, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- ReadingThread(ExceptionHandler<IOException>, MutableObjectIterator<E>, UnilateralSortMerger.CircularQueues<E>, LargeRecordHandler<E>, E, AbstractInvokable, long) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ReadingThread
-
Creates a new reading thread.
- readInt() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readInto(Buffer) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileReader
-
- readInto(Buffer) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileReader
-
- readInto(Buffer) - Method in class org.apache.flink.runtime.io.disk.iomanager.SynchronousBufferFileReader
-
- readLine() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readLong() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readMappingsInKeyGroup(DataInputView, int) - Method in interface org.apache.flink.runtime.state.StateSnapshotKeyGroupReader
-
Read the data for the specified key-group from the input.
- readOnlySlice() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Returns a read-only slice of this buffer's readable bytes, i.e.
- readOnlySlice(int, int) - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Returns a read-only slice of this buffer.
- readOnlySlice() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- readOnlySlice(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- readOnlySlice() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- readOnlySlice(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- ReadOnlySlicedNetworkBuffer - Class in org.apache.flink.runtime.io.network.buffer
-
Minimal best-effort read-only sliced
Buffer
implementation wrapping a
NetworkBuffer
's sub-region based on
io.netty.buffer.SlicedByteBuf and
io.netty.buffer.ReadOnlyByteBuf.
- readPhase - Variable in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
-
- readRecordAt(long, T) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
- readRecordAt(long) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
- readResolve() - Method in class org.apache.flink.runtime.messages.Acknowledge
-
Read resolve to preserve the singleton object property.
- readResolve() - Method in class org.apache.flink.runtime.state.CheckpointStorageLocationReference
-
readResolve() preserves the singleton property of the default value.
- readShort() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readStateMetaInfoSnapshot(DataInputView, ClassLoader) - Method in class org.apache.flink.runtime.state.metainfo.LegacyStateMetaInfoReaders.OperatorBackendStateMetaInfoReaderV1
-
- readStateMetaInfoSnapshot(DataInputView, ClassLoader) - Method in interface org.apache.flink.runtime.state.metainfo.StateMetaInfoReader
-
Reads a snapshot from the given input view.
- readUnsignedByte() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readUnsignedShort() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readUTF() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- readWriteLock - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
-
Lock guarding concurrent file accesses.
- receiveAcknowledgeMessage(AcknowledgeCheckpoint, String) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Receives an AcknowledgeCheckpoint message and returns whether the
message was associated with a pending checkpoint.
- receiveDeclineMessage(DeclineCheckpoint, String) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- receiveHeartbeat(ResourceID, I) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
-
- receiveHeartbeat(ResourceID, I) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatTarget
-
Sends a heartbeat response to the target.
- reconnect(JobID) - Method in class org.apache.flink.runtime.taskexecutor.JobLeaderService
-
Triggers reconnection to the last known leader of the given job.
- RecordDeserializer<T extends org.apache.flink.core.io.IOReadableWritable> - Interface in org.apache.flink.runtime.io.network.api.serialization
-
Interface for turning sequences of memory segments into records.
- RecordDeserializer.DeserializationResult - Enum in org.apache.flink.runtime.io.network.api.serialization
-
Status of the deserialization result.
- recordModification(ExecutionVertexID) - Method in class org.apache.flink.runtime.scheduler.ExecutionVertexVersioner
-
- RecordReader<T extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.reader
-
Record oriented reader for immutable types.
- RecordReader(InputGate, Class<T>, String[]) - Constructor for class org.apache.flink.runtime.io.network.api.reader.RecordReader
-
Creates a new RecordReader that de-serializes records from the given input gate and
can spill partial records to disk, if they grow large.
- RecordSerializer<T extends org.apache.flink.core.io.IOReadableWritable> - Interface in org.apache.flink.runtime.io.network.api.serialization
-
Interface for turning records into sequences of memory segments.
- RecordSerializer.SerializationResult - Enum in org.apache.flink.runtime.io.network.api.serialization
-
Status of the serialization result.
- recordSize() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- recordSize() - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
-
Gets the size of each record, the number of bytes separating the head
of successive records.
- recordSize() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- recordsPerSegment() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- recordsPerSegment() - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
-
Gets the number of elements in each memory segment.
- recordsPerSegment() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- recordVertexModifications(Collection<ExecutionVertexID>) - Method in class org.apache.flink.runtime.scheduler.ExecutionVertexVersioner
-
- RecordWriter<T extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.writer
-
A record-oriented runtime result writer.
- RecordWriterBuilder - Class in org.apache.flink.runtime.io.network.api.writer
-
Utility class to encapsulate the logic of building a
RecordWriter
instance.
- RecordWriterBuilder() - Constructor for class org.apache.flink.runtime.io.network.api.writer.RecordWriterBuilder
-
- 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.dispatcher.SingleJobSubmittedJobGraphStore
-
- 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(MemorySegment) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferRecycler
-
Recycles the
MemorySegment
to its original
BufferPool
instance.
- recycle(MemorySegment) - Method in class org.apache.flink.runtime.io.network.buffer.FreeingBufferRecycler
-
Frees the given memory segment.
- recycle(MemorySegment) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- recycle(MemorySegment) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
Exclusive buffer is recycled to this input channel directly and it may trigger return extra
floating buffer and notify increased credit to the producer.
- recycleBuffer() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Releases this buffer once, i.e.
- recycleBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- recycleBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- recycleMemorySegments(Collection<MemorySegment>) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- RedirectingSslHandler - Class in org.apache.flink.runtime.net
-
SSL handler which automatically redirects Non-SSL requests to SSL address.
- RedirectingSslHandler(String, CompletableFuture<String>, SSLHandlerFactory) - Constructor for class org.apache.flink.runtime.net.RedirectingSslHandler
-
- reDistributePartitionableStates(List<OperatorState>, int, List<OperatorID>, Map<OperatorInstanceID, List<OperatorStateHandle>>, Map<OperatorInstanceID, List<OperatorStateHandle>>) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
-
- ReduceCombineDriver<T> - Class in org.apache.flink.runtime.operators
-
Combine operator for Reduce functions, standalone (not chained).
- ReduceCombineDriver() - Constructor for class org.apache.flink.runtime.operators.ReduceCombineDriver
-
- ReduceDriver<T> - Class in org.apache.flink.runtime.operators
-
Reduce driver which is executed by a Task Manager.
- ReduceDriver() - Constructor for class org.apache.flink.runtime.operators.ReduceDriver
-
- ReduceFacade(ReduceFunction<T>, Collector<T>, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.ReduceFacade
-
- refCnt() - Method in class org.apache.flink.runtime.rest.handler.router.RoutedRequest
-
- refresh() - Method in class org.apache.flink.runtime.security.DynamicConfiguration
-
- RegionPartitionReleaseStrategy - Class in org.apache.flink.runtime.executiongraph.failover.flip1.partitionrelease
-
Releases blocking intermediate result partitions that are incident to a
PipelinedRegion
,
as soon as the region's execution vertices are finished.
- RegionPartitionReleaseStrategy(SchedulingTopology, Set<PipelinedRegion>) - Constructor for class org.apache.flink.runtime.executiongraph.failover.flip1.partitionrelease.RegionPartitionReleaseStrategy
-
- RegionPartitionReleaseStrategy.Factory - Class in org.apache.flink.runtime.executiongraph.failover.flip1.partitionrelease
-
- register(Metric, String, AbstractMetricGroup) - Method in interface org.apache.flink.runtime.metrics.MetricRegistry
-
Registers a new Metric
with this registry.
- register(Metric, String, AbstractMetricGroup) - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
- register(Metric, String, AbstractMetricGroup) - Method in class org.apache.flink.runtime.metrics.NoOpMetricRegistry
-
- register(Logger) - Static method in class org.apache.flink.runtime.util.SignalHandler
-
Register some signal handlers.
- registerAll(Iterable<? extends CompositeStateHandle>) - Method in class org.apache.flink.runtime.state.SharedStateRegistry
-
Register given shared states in the registry.
- registerAllRequestsProcessedListener(NotificationListener) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileWriter
-
- registerAllRequestsProcessedListener(NotificationListener) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
Registers a listener to be notified when all outstanding requests have been processed.
- registerAllRequestsProcessedListener(NotificationListener) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileWriter
-
Registers a listener, which is notified after all outstanding requests have been processed.
- registerChannelToBeRemovedAtShudown(FileIOChannel.ID) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
-
Adds a channel to the list of channels that are to be removed at shutdown.
- registerConsumer() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- RegisteredBroadcastStateBackendMetaInfo<K,V> - Class in org.apache.flink.runtime.state
-
- RegisteredBroadcastStateBackendMetaInfo(String, OperatorStateHandle.Mode, TypeSerializer<K>, TypeSerializer<V>) - Constructor for class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
-
- RegisteredBroadcastStateBackendMetaInfo(RegisteredBroadcastStateBackendMetaInfo<K, V>) - Constructor for class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
-
- RegisteredBroadcastStateBackendMetaInfo(StateMetaInfoSnapshot) - Constructor for class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
-
- RegisteredKeyValueStateBackendMetaInfo<N,S> - Class in org.apache.flink.runtime.state
-
Compound meta information for a registered state in a keyed state backend.
- RegisteredKeyValueStateBackendMetaInfo(StateDescriptor.Type, String, TypeSerializer<N>, TypeSerializer<S>) - Constructor for class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
-
- RegisteredKeyValueStateBackendMetaInfo(StateDescriptor.Type, String, TypeSerializer<N>, TypeSerializer<S>, StateSnapshotTransformer.StateSnapshotTransformFactory<S>) - Constructor for class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
-
- RegisteredKeyValueStateBackendMetaInfo(StateMetaInfoSnapshot) - Constructor for class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
-
- RegisteredOperatorStateBackendMetaInfo<S> - Class in org.apache.flink.runtime.state
-
Compound meta information for a registered state in an operator state backend.
- RegisteredOperatorStateBackendMetaInfo(String, TypeSerializer<S>, OperatorStateHandle.Mode) - Constructor for class org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
-
- RegisteredOperatorStateBackendMetaInfo(StateMetaInfoSnapshot) - Constructor for class org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
-
- RegisteredPriorityQueueStateBackendMetaInfo<T> - Class in org.apache.flink.runtime.state
-
Meta information about a priority queue state in a backend.
- RegisteredPriorityQueueStateBackendMetaInfo(String, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.state.RegisteredPriorityQueueStateBackendMetaInfo
-
- RegisteredPriorityQueueStateBackendMetaInfo(StateMetaInfoSnapshot) - Constructor for class org.apache.flink.runtime.state.RegisteredPriorityQueueStateBackendMetaInfo
-
- RegisteredRpcConnection<F extends Serializable,G extends RpcGateway,S extends RegistrationResponse.Success> - Class in org.apache.flink.runtime.registration
-
This utility class implements the basis of RPC connecting from one component to another component,
for example the RPC connection from TaskExecutor to ResourceManager.
- RegisteredRpcConnection(Logger, String, F, Executor) - Constructor for class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
- RegisteredStateMetaInfoBase - Class in org.apache.flink.runtime.state
-
Base class for all registered state in state backends.
- RegisteredStateMetaInfoBase(String) - Constructor for class org.apache.flink.runtime.state.RegisteredStateMetaInfoBase
-
- registerInputMetrics(boolean, boolean, MetricGroup, SingleInputGate[]) - Static method in class org.apache.flink.runtime.io.network.metrics.NettyShuffleMetricFactory
-
- registerJob(JobID) - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
-
Registers use of job-related BLOBs.
- registerJob(JobID, Collection<PermanentBlobKey>, Collection<URL>) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
-
- registerJob(JobID, Collection<PermanentBlobKey>, Collection<URL>) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
-
Registers a job with its required jar files and classpaths.
- registerJobManager(JobMasterId, ResourceID, String, JobID, Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- registerJobManager(JobMasterId, ResourceID, String, JobID, Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Register a
JobMaster
at the resource manager.
- registerJobStatusListener(JobStatusListener) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- registerJobStatusListener(JobStatusListener) - Method in class org.apache.flink.runtime.scheduler.LegacyScheduler
-
- registerJobStatusListener(JobStatusListener) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
-
- registerKeySelectionListener(KeyedStateBackend.KeySelectionListener<K>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- registerKeySelectionListener(KeyedStateBackend.KeySelectionListener<K>) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
-
- registerKvState(KeyGroupRange, KvStateID, InetSocketAddress) - Method in class org.apache.flink.runtime.query.KvStateLocation
-
Registers a KvState instance for the given key group index.
- registerKvState(JobID, JobVertexID, KeyGroupRange, String, InternalKvState<?, ?, ?>) - Method in class org.apache.flink.runtime.query.KvStateRegistry
-
Registers the KvState instance and returns the assigned ID.
- registerKvState(KeyGroupRange, String, InternalKvState<?, ?, ?>) - Method in class org.apache.flink.runtime.query.TaskKvStateRegistry
-
Registers the KvState instance at the KvStateRegistry.
- registerLegacyNetworkMetrics(boolean, boolean, MetricGroup, ResultPartitionWriter[], InputGate[]) - Static method in class org.apache.flink.runtime.io.network.metrics.NettyShuffleMetricFactory
-
- registerLegacyNetworkMetrics(MetricGroup, ResultPartitionWriter[], InputGate[]) - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
- registerListener(JobID, KvStateRegistryListener) - Method in class org.apache.flink.runtime.query.KvStateRegistry
-
Registers a listener with the registry.
- registerMetrics(MetricGroup) - Method in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategy
-
Tells the FailoverStrategy to register its metrics.
- registerMetrics(MetricGroup) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
-
- registerNewSerializerForRestoredState(TypeSerializer<T>) - Method in class org.apache.flink.runtime.state.StateSerializerProvider
-
For restored state, register a new serializer that potentially has a new serialization schema.
- 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.
- registerOutputMetrics(boolean, MetricGroup, ResultPartition[]) - Static method in class org.apache.flink.runtime.io.network.metrics.NettyShuffleMetricFactory
-
- registerPartition(ResultPartitionID) - Method in class org.apache.flink.runtime.io.network.TaskEventDispatcher
-
- registerPartitionWithProducer(PartitionDescriptor, ProducerDescriptor) - Method in enum org.apache.flink.runtime.shuffle.NettyShuffleMaster
-
- registerPartitionWithProducer(PartitionDescriptor, ProducerDescriptor) - Method in interface org.apache.flink.runtime.shuffle.ShuffleMaster
-
Asynchronously register a partition and its producer with the shuffle service.
- registerQueueLengthMetrics(MetricGroup, SingleInputGate[]) - Static method in class org.apache.flink.runtime.io.network.metrics.InputGateMetrics
-
- registerQueueLengthMetrics(MetricGroup, ResultPartition[]) - Static method in class org.apache.flink.runtime.io.network.metrics.ResultPartitionMetrics
-
- registerReference(SharedStateRegistryKey, StreamStateHandle) - Method in class org.apache.flink.runtime.state.SharedStateRegistry
-
Register a reference to the given shared state in the registry.
- registerResultPartition(ResultPartition) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
-
- registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.checkpoint.OperatorState
-
- registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
-
- registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
-
- registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.checkpoint.TaskState
-
Deprecated.
- registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.checkpoint.TaskStateSnapshot
-
- registerSharedStates(SharedStateRegistry) - Method in interface org.apache.flink.runtime.state.CompositeStateHandle
-
Register both newly created and already referenced shared states in the given
SharedStateRegistry
.
- registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.state.DirectoryKeyedStateHandle
-
- registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.state.IncrementalRemoteKeyedStateHandle
-
- registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
-
- registerSharedStatesAfterRestored(SharedStateRegistry) - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
Register all shared states in the given registry.
- registerShuffleMetrics(MetricGroup, NetworkBufferPool) - Static method in class org.apache.flink.runtime.io.network.metrics.NettyShuffleMetricFactory
-
- registerSlotRequest(SlotRequest) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Requests a slot with the respective resource profile.
- registerSlotRequest(SlotRequest) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
Requests a slot with the respective resource profile.
- registerTask(JobID, ExecutionAttemptID, Collection<PermanentBlobKey>, Collection<URL>) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
-
- registerTask(JobID, ExecutionAttemptID, Collection<PermanentBlobKey>, Collection<URL>) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
-
Registers a job task execution with its required jar files and classpaths.
- registerTaskEventListener(EventListener<TaskEvent>, Class<? extends TaskEvent>) - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
-
- registerTaskEventListener(EventListener<TaskEvent>, Class<? extends TaskEvent>) - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
-
- registerTaskExecutor(String, ResourceID, int, HardwareDescription, Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- registerTaskExecutor(String, ResourceID, int, HardwareDescription, Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
- registerTaskManager(String, TaskManagerLocation, Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- registerTaskManager(String, TaskManagerLocation, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Registers the task manager at the job manager.
- registerTaskManager(ResourceID) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
- registerTaskManager(ResourceID) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
-
Register TaskManager to this pool, only those slots come from registered TaskManager will be considered valid.
- registerTaskManager(TaskExecutorConnection, SlotReport) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Registers a new task manager at the slot manager.
- registerTaskManager(TaskExecutorConnection, SlotReport) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
Registers a new task manager at the slot manager.
- registerTimeout(K, long, TimeUnit) - Method in class org.apache.flink.runtime.taskexecutor.slot.TimerService
-
Register a timeout for the given key which shall occur in the given delay.
- RegistrationConnectionListener<T extends RegisteredRpcConnection<?,?,S>,S extends RegistrationResponse.Success> - Interface in org.apache.flink.runtime.registration
-
Classes which want to be notified about the registration result by the
RegisteredRpcConnection
have to implement this interface.
- RegistrationResponse - Class in org.apache.flink.runtime.registration
-
- RegistrationResponse() - Constructor for class org.apache.flink.runtime.registration.RegistrationResponse
-
- RegistrationResponse.Decline - Class in org.apache.flink.runtime.registration
-
A rejected (declined) registration.
- RegistrationResponse.Success - Class in org.apache.flink.runtime.registration
-
Base class for a successful registration.
- RegistrationTimeoutException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
-
Exception which indicates that the
TaskExecutor
could not register at
the master in time.
- RegistrationTimeoutException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.RegistrationTimeoutException
-
- RegistrationTimeoutException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.RegistrationTimeoutException
-
- RegistrationTimeoutException(Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.RegistrationTimeoutException
-
- registry - Variable in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
The registry that this metrics group belongs to.
- RegularToMutableObjectIterator<T> - Class in org.apache.flink.runtime.util
-
- RegularToMutableObjectIterator(Iterator<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.util.RegularToMutableObjectIterator
-
- relativeTimeMillis() - Method in class org.apache.flink.runtime.util.clock.Clock
-
- relativeTimeMillis() - Method in class org.apache.flink.runtime.util.clock.SystemClock
-
- relativeTimeNanos() - Method in class org.apache.flink.runtime.util.clock.Clock
-
- relativeTimeNanos() - Method in class org.apache.flink.runtime.util.clock.SystemClock
-
- release() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- release(Throwable) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Releases the result partition.
- release() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
- release(Throwable) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.PhysicalSlot.Payload
-
Releases the payload
- release(Throwable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
A release of the payload by the AllocatedSlot
triggers a release of the payload of
the logical slot.
- release(Throwable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.MultiTaskSlot
-
- release(Throwable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.SingleTaskSlot
-
- release(Throwable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotSharingManager.TaskSlot
-
Release the task slot.
- release(MemorySegment) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Tries to release the memory for the specified segment.
- release(Collection<MemorySegment>) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Tries to release many memory segments together.
- release() - Method in class org.apache.flink.runtime.rest.handler.router.RoutedRequest
-
- release(int) - Method in class org.apache.flink.runtime.rest.handler.router.RoutedRequest
-
- release() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMapSnapshot
-
- release() - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueStateSnapshot
-
- release() - Method in class org.apache.flink.runtime.state.heap.StateMapSnapshot
-
Release the snapshot.
- release() - Method in interface org.apache.flink.runtime.state.StateSnapshot
-
Release the snapshot.
- release(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Releases the lock from the node under the given ZooKeeper path.
- releaseAll(Object) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Releases all memory segments for the given owner.
- releaseAll() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Releases all lock nodes of this ZooKeeperStateHandleStore.
- releaseAllReferencesFromTask(BatchTask<?, ?>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableManager
-
- releaseAllResources() - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
- releaseAllResources() - Method in class org.apache.flink.runtime.io.network.partition.NoOpResultSubpartitionView
-
- releaseAllResources() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
-
- releaseAndTryRemove(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Releases the lock for the given state node and tries to remove the state node if it is no longer locked.
- releaseAndTryRemoveAll() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
-
Releases all lock nodes of this ZooKeeperStateHandleStores and tries to remove all state nodes which
are not locked anymore.
- releaseBroadcastVariables(String, int, DistributedRuntimeUDFContext) - Method in class org.apache.flink.runtime.operators.BatchTask
-
- releaseJob(JobID) - Method in class org.apache.flink.runtime.blob.PermanentBlobCache
-
Unregisters use of job-related BLOBs and allow them to be released.
- releaseJob(JobID, ExecutionAttemptID) - Method in class org.apache.flink.runtime.filecache.FileCache
-
- releaseJobGraph(JobID) - Method in class org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
-
- releaseJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
-
- releaseJobGraph(JobID) - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
-
Releases the locks on the specified
JobGraph
.
- releaseJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
-
- releaseLocalStateForAllocationId(AllocationID) - Method in class org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager
-
- releaseMemory(int) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPoolOwner
-
- releaseMemory(int) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Releases buffers held by this result partition.
- ReleaseOnConsumptionResultPartition - Class in org.apache.flink.runtime.io.network.partition
-
ResultPartition that releases itself once all subpartitions have been consumed.
- releasePartition(ResultPartitionID, Throwable) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
-
- releasePartitionExternally(ShuffleDescriptor) - Method in enum org.apache.flink.runtime.shuffle.NettyShuffleMaster
-
- releasePartitionExternally(ShuffleDescriptor) - Method in interface org.apache.flink.runtime.shuffle.ShuffleMaster
-
Release any external resources occupied by the given partition.
- releasePartitions(JobID, Collection<ResultPartitionID>) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Batch release intermediate result partitions.
- releasePartitions(JobID, Collection<ResultPartitionID>) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
-
- releasePartitions(JobID, Collection<ResultPartitionID>) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- releasePartitions(JobID, Collection<ResultPartitionID>) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Batch release intermediate result partitions.
- releasePartitionsLocally(Collection<ResultPartitionID>) - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
- releasePartitionsLocally(Collection<ResultPartitionID>) - Method in interface org.apache.flink.runtime.shuffle.ShuffleEnvironment
-
Release local resources occupied by the given partitions.
- releaseReference(String, int, BatchTask<?, ?>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableManager
-
- releaseReference(BroadcastVariableKey, BatchTask<?, ?>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableManager
-
- releaseResource(InstanceID, Exception) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- releaseResource(InstanceID, Exception) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ResourceActions
-
Releases the resource with the given instance id.
- releaseSlot(Throwable) - Method in class org.apache.flink.runtime.instance.SharedSlot
-
- releaseSlot(Throwable) - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
- releaseSlot(Throwable) - Method in class org.apache.flink.runtime.instance.Slot
-
This method cancels and releases the slot and all its sub-slots.
- releaseSlot() - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
- releaseSlot(Throwable) - Method in interface org.apache.flink.runtime.jobmaster.LogicalSlot
-
Releases this slot.
- releaseSlot(SlotRequestId, Throwable) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.AllocatedSlotActions
-
- releaseSlot(Throwable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- releaseSlot(SlotRequestId, Throwable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
-
- releaseSnapshot(StateMapSnapshot<K, N, S, ? extends StateMap<K, N, S>>) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
- releaseSnapshot(StateMapSnapshot<K, N, S, ? extends StateMap<K, N, S>>) - Method in class org.apache.flink.runtime.state.heap.StateMap
-
- releaseTable() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Releases the table (the array of buckets) and returns the occupied memory segments to the list of free segments.
- releaseTable() - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
-
- releaseTaskManager(ResourceID, Exception) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
- releaseTaskManager(ResourceID, Exception) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
-
Unregister TaskManager from this pool, all the related slots will be released and tasks be canceled.
- remainingCapacity() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
-
Returns the remaining capacity of the backing array.
- RemoteChannelStateChecker - Class in org.apache.flink.runtime.io.network.partition.consumer
-
- RemoteChannelStateChecker(ResultPartitionID, String) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.RemoteChannelStateChecker
-
- RemoteFencedMessage<F extends Serializable,P extends Serializable> - Class in org.apache.flink.runtime.rpc.messages
-
- RemoteFencedMessage(F, P) - Constructor for class org.apache.flink.runtime.rpc.messages.RemoteFencedMessage
-
- RemoteHandshakeMessage - Class in org.apache.flink.runtime.rpc.messages
-
Handshake message between rpc endpoints.
- RemoteHandshakeMessage(Class<?>, int) - Constructor for class org.apache.flink.runtime.rpc.messages.RemoteHandshakeMessage
-
- RemoteInputChannel - Class in org.apache.flink.runtime.io.network.partition.consumer
-
An input channel, which requests a remote partition queue.
- RemoteInputChannel(SingleInputGate, int, ResultPartitionID, ConnectionID, ConnectionManager, int, int, InputChannelMetrics, MemorySegmentProvider) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
- RemoteRpcInvocation - Class in org.apache.flink.runtime.rpc.messages
-
Remote rpc invocation message which is used when the actor communication is remote and, thus, the
message has to be serialized.
- RemoteRpcInvocation(String, Class<?>[], Object[]) - Constructor for class org.apache.flink.runtime.rpc.messages.RemoteRpcInvocation
-
- RemoteTransportException - Exception in org.apache.flink.runtime.io.network.netty.exception
-
- RemoteTransportException(String, SocketAddress) - Constructor for exception org.apache.flink.runtime.io.network.netty.exception.RemoteTransportException
-
- RemoteTransportException(String, SocketAddress, Throwable) - Constructor for exception org.apache.flink.runtime.io.network.netty.exception.RemoteTransportException
-
- remove(Object) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- remove(String) - Method in class org.apache.flink.runtime.iterative.concurrent.Broker
-
Blocking retrieval and removal of the object to share.
- remove(Object) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- remove() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable.SimpleIterator
-
- remove() - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
-
- remove() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
-
- remove() - Method in class org.apache.flink.runtime.operators.util.metrics.CountingIterator
-
- remove(T) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
-
- remove(K, N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
- remove(T) - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueSet
-
In contrast to the superclass and to maintain set semantics, removal here is based on comparing the given element
via
Object.equals(Object)
.
- remove(T) - Method in class org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
-
- remove(K, N) - Method in class org.apache.flink.runtime.state.heap.NestedStateMap
-
- remove(K, N) - Method in class org.apache.flink.runtime.state.heap.StateMap
-
Removes the mapping for the composite of active key and given namespace.
- remove(N) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Removes the mapping for the composite of active key and given namespace.
- remove(K) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
-
- remove(StateEntry<K, N, V>) - Method in interface org.apache.flink.runtime.state.internal.InternalKvState.StateIncrementalVisitor
-
- remove(T) - Method in interface org.apache.flink.runtime.state.InternalPriorityQueue
-
Removes the given element from the set, if is contained in the set.
- remove(JobID) - Method in class org.apache.flink.runtime.taskexecutor.JobManagerTable
-
- remove(ExecutionAttemptID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
-
Remove the task identified by the given execution attempt id.
- remove() - Method in class org.apache.flink.runtime.util.EmptyIterator
-
- remove() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator.ValuesIterator
-
- remove() - Method in class org.apache.flink.runtime.util.NonReusingMutableToRegularIteratorWrapper
-
- remove() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator.ValuesIterator
-
- remove() - Method in class org.apache.flink.runtime.util.ReusingMutableToRegularIteratorWrapper
-
- remove() - Method in class org.apache.flink.runtime.util.SingleElementIterator
-
- removeAll(Collection<?>) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- removeAll(Collection<?>) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- removeAndGetOld(K, N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
- removeAndGetOld(K, N) - Method in class org.apache.flink.runtime.state.heap.NestedStateMap
-
- removeAndGetOld(K, N) - Method in class org.apache.flink.runtime.state.heap.StateMap
-
Removes the mapping for the composite of active key and given namespace, returning the state that was
found under the entry.
- removeAndGetOld(N) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Removes the mapping for the composite of active key and given namespace, returning the state that was
found under the entry.
- removeIf(Predicate<? super T>) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- removeInputChannel(RemoteInputChannel) - Method in interface org.apache.flink.runtime.io.network.NetworkClientHandler
-
- removeInternal(int) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
-
Implements how to remove the element at the given index from the queue.
- removeInternal(int) - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueue
-
- removeJob(JobID) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
-
- removeJob(JobID) - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
Remove the given job from being monitored by the service.
- removeJob(JobID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- removeJob(JobID) - Method in class org.apache.flink.runtime.taskexecutor.JobLeaderService
-
Remove the given job from being monitored by the job leader service.
- removeJobGraph(JobID) - Method in class org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
-
- removeJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
-
- removeJobGraph(JobID) - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
-
- removeJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
-
- removeJobMetricsGroup(JobID, TaskManagerJobMetricGroup) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
-
- removeKeyA(A) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyLinkedMap
-
- removeKeyB(B) - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyLinkedMap
-
- removeLast() - Method in class org.apache.flink.runtime.util.IntArrayList
-
- removeLong(int) - Method in class org.apache.flink.runtime.util.LongArrayList
-
- removeMetric(Metric) - Method in class org.apache.flink.runtime.metrics.dump.MetricQueryService
-
- removePathPattern(String) - Method in class org.apache.flink.runtime.rest.handler.router.Router
-
Removes the route specified by the path pattern.
- RemoveRangeIndex<T> - Class in org.apache.flink.runtime.operators.udf
-
- RemoveRangeIndex() - Constructor for class org.apache.flink.runtime.operators.udf.RemoveRangeIndex
-
- removeSlotListener() - Method in class org.apache.flink.runtime.instance.Instance
-
Removes the listener that receives notifications for slot availability.
- removeTask(ExecutionAttemptID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Remove the task with the given execution attempt id from its task slot.
- removeTaskMetricGroup(AbstractID) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
-
- removeVertexFromGroup(JobVertexID) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
-
- reopen(Iterator<T>) - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
-
- ReOpenableHashPartition<BT,PT> - Class in org.apache.flink.runtime.operators.hash
-
- ReOpenableMutableHashTable<BT,PT> - Class in org.apache.flink.runtime.operators.hash
-
- ReOpenableMutableHashTable(TypeSerializer<BT>, TypeSerializer<PT>, TypeComparator<BT>, TypeComparator<PT>, TypePairComparator<PT, BT>, List<MemorySegment>, IOManager, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
-
- reopenProbe(MutableObjectIterator<V2>) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstReOpenableHashJoinIterator
-
Set new input for probe side
- reopenProbe(MutableObjectIterator<V1>) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondReOpenableHashJoinIterator
-
Set new input for probe side
- reopenProbe(MutableObjectIterator<PT>) - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
-
- reopenProbe(MutableObjectIterator<V2>) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstReOpenableHashJoinIterator
-
Set new input for probe side
- reopenProbe(MutableObjectIterator<V1>) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondReOpenableHashJoinIterator
-
Set new input for probe side
- repartitionState(List<List<OperatorStateHandle>>, int, int) - Method in interface org.apache.flink.runtime.checkpoint.OperatorStateRepartitioner
-
- repartitionState(List<List<OperatorStateHandle>>, int, 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.
- reportAllElementKeyGroups() - Method in class org.apache.flink.runtime.state.KeyGroupPartitioner
-
This method iterates over the input data and reports the key-group for each element.
- reporterIndex - Variable in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
-
- ReporterSetup - Class in org.apache.flink.runtime.metrics
-
Encapsulates everything needed for the instantiation and configuration of a MetricReporter
.
- ReporterSetup(String, MetricConfig, MetricReporter) - Constructor for class org.apache.flink.runtime.metrics.ReporterSetup
-
- reportHeartbeat() - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatMonitor
-
Report heartbeat from the monitored target.
- reportHeartbeat() - Method in class org.apache.flink.runtime.heartbeat.HeartbeatMonitorImpl
-
- reportHeartBeat() - Method in class org.apache.flink.runtime.instance.Instance
-
Updates the time of last received heart beat to the current system time.
- reportKeyGroupOfElementAtIndex(int, int) - Method in class org.apache.flink.runtime.state.KeyGroupPartitioner
-
This method reports in the bookkeeping data that the element at the given index belongs to the given key-group.
- reportPayload(ResourceID, I) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatListener
-
Callback which is called whenever a heartbeat with an associated payload is received.
- reportSlotStatus(InstanceID, SlotReport) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Reports the current slot allocations for a task manager identified by the given instance id.
- reportSlotStatus(InstanceID, SlotReport) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
Reports the current slot allocations for a task manager identified by the given instance id.
- reportTaskStateSnapshots(CheckpointMetaData, CheckpointMetrics, TaskStateSnapshot, TaskStateSnapshot) - Method in interface org.apache.flink.runtime.state.TaskStateManager
-
Report the state snapshots for the operator instances running in the owning task.
- reportTaskStateSnapshots(CheckpointMetaData, CheckpointMetrics, TaskStateSnapshot, TaskStateSnapshot) - Method in class org.apache.flink.runtime.state.TaskStateManagerImpl
-
- RequestBody - Interface in org.apache.flink.runtime.rest.messages
-
Marker interface for all requests of the REST API.
- requestBuffer() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
Returns a
Buffer
instance from the buffer provider, if one is available.
- requestBuffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
Requests buffer from input channel directly for receiving network data.
- requestBufferBlocking() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
Returns a
Buffer
instance from the buffer provider.
- requestBufferBuilderBlocking() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
-
- requestClusterOverview(Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- requestClusterOverview() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- requestClusterOverview(Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Requests the cluster status overview.
- RequestDoneCallback<T> - Interface in org.apache.flink.runtime.io.disk.iomanager
-
Callback to be executed on completion of an asynchronous I/O request.
- requestFailed(T, IOException) - Method in class org.apache.flink.runtime.io.disk.iomanager.QueuingCallback
-
- requestFailed(T, IOException) - Method in interface org.apache.flink.runtime.io.disk.iomanager.RequestDoneCallback
-
- requestFileUpload(ResourceManagerGateway, ResourceID) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.AbstractTaskManagerFileHandler
-
- requestFileUpload(ResourceManagerGateway, ResourceID) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerLogFileHandler
-
- requestFileUpload(ResourceManagerGateway, ResourceID) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.TaskManagerStdoutFileHandler
-
- requestFileUpload(FileType, Time) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- requestFileUpload(FileType, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Requests the file upload of the specified type to the cluster's
BlobServer
.
- requestHeartbeat(ResourceID, I) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
-
- requestHeartbeat(ResourceID, I) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatTarget
-
Requests a heartbeat from the target.
- requestJob(JobID, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- requestJob(JobID, Time) - Method in interface org.apache.flink.runtime.dispatcher.DispatcherGateway
-
- requestJob(Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- requestJob(Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
- requestJob() - Method in class org.apache.flink.runtime.scheduler.LegacyScheduler
-
- requestJob() - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
-
- requestJob(JobID, Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
- requestJobDetails(Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- requestJobDetails(Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Request the details of the executed job.
- RequestJobDetails - Class in org.apache.flink.runtime.messages.webmonitor
-
This message requests an overview of the jobs on the JobManager,
including running jobs and/or finished jobs.
- RequestJobDetails(boolean, boolean) - Constructor for class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
-
- requestJobDetails() - Method in class org.apache.flink.runtime.scheduler.LegacyScheduler
-
- requestJobDetails() - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
-
- requestJobResult(JobID, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- requestJobResult(JobID, Time) - Method in class org.apache.flink.runtime.dispatcher.MiniDispatcher
-
- requestJobResult(JobID) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- requestJobResult(JobID, Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Requests the
JobResult
of a job specified by the given jobId.
- RequestJobsOverview - Class in org.apache.flink.runtime.messages.webmonitor
-
This message requests an overview of how many jobs are in which status.
- requestJobStatus(JobID, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- requestJobStatus(Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- requestJobStatus(Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Requests the current job status.
- requestJobStatus() - Method in class org.apache.flink.runtime.scheduler.LegacyScheduler
-
- requestJobStatus() - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
-
- requestJobStatus(JobID, Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
- RequestJobsWithIDsOverview - Class in org.apache.flink.runtime.messages.webmonitor
-
This message requests an overview of how many jobs are in which status.
- requestKvStateLocation(JobID, String) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- requestKvStateLocation(JobID, String) - Method in interface org.apache.flink.runtime.jobmaster.KvStateLocationOracle
-
- requestKvStateLocation(JobID, String) - Method in class org.apache.flink.runtime.scheduler.LegacyScheduler
-
- requestKvStateLocation(JobID, String) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
-
- requestMemorySegment() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- requestMemorySegments() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
-
- requestMetricQueryServiceAddress(Time) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- requestMetricQueryServiceAddress(Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Returns the gateway of Metric Query Service on the TaskManager.
- requestMetricQueryServiceAddresses(Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- requestMetricQueryServiceAddresses(Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
- requestMultipleJobDetails(Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- requestMultipleJobDetails(Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Requests job details currently being executed on the Flink cluster.
- requestNewAllocatedBatchSlot(SlotRequestId, ResourceProfile) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Requests the allocation of a new batch slot from the resource manager.
- requestNewAllocatedBatchSlot(SlotRequestId, ResourceProfile) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
-
- requestNewAllocatedSlot(SlotRequestId, ResourceProfile, Time) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
Request the allocation of a new slot from the resource manager.
- requestNewAllocatedSlot(SlotRequestId, ResourceProfile, Time) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
-
- requestNextInputSplit(JobVertexID, ExecutionAttemptID) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- requestNextInputSplit(JobVertexID, ExecutionAttemptID) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
- requestNextInputSplit(JobVertexID, ExecutionAttemptID) - Method in class org.apache.flink.runtime.scheduler.LegacyScheduler
-
- requestNextInputSplit(JobVertexID, ExecutionAttemptID) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
-
- requestOperatorBackPressureStats(JobID, JobVertexID) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- requestOperatorBackPressureStats(JobVertexID) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- requestOperatorBackPressureStats(JobVertexID) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Requests the statistics on operator back pressure.
- requestOperatorBackPressureStats(JobVertexID) - Method in class org.apache.flink.runtime.scheduler.LegacyScheduler
-
- requestOperatorBackPressureStats(JobVertexID) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
-
- requestOperatorBackPressureStats(JobID, JobVertexID) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Requests the statistics on operator back pressure.
- requestPartitionProducerState(IntermediateDataSetID, ResultPartitionID, Consumer<? super PartitionProducerStateProvider.ResponseHandle>) - Method in interface org.apache.flink.runtime.io.network.partition.PartitionProducerStateProvider
-
Trigger the producer execution state request.
- requestPartitionProducerState(JobID, IntermediateDataSetID, ResultPartitionID) - Method in interface org.apache.flink.runtime.taskexecutor.PartitionProducerStateChecker
-
Requests the execution state of the execution producing a result partition.
- requestPartitionProducerState(JobID, IntermediateDataSetID, ResultPartitionID) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcPartitionStateChecker
-
- requestPartitionProducerState(IntermediateDataSetID, ResultPartitionID, Consumer<? super PartitionProducerStateProvider.ResponseHandle>) - Method in class org.apache.flink.runtime.taskmanager.Task
-
- requestPartitionState(IntermediateDataSetID, ResultPartitionID) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- requestPartitionState(IntermediateDataSetID, ResultPartitionID) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Requests the current state of the partition.
- requestPartitionState(IntermediateDataSetID, ResultPartitionID) - Method in class org.apache.flink.runtime.scheduler.LegacyScheduler
-
- requestPartitionState(IntermediateDataSetID, ResultPartitionID) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
-
- 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
-
- requestResourceOverview(Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- requestResourceOverview(Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Requests the resource overview.
- requestSlot(JobMasterId, SlotRequest, Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- requestSlot(JobMasterId, SlotRequest, Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Requests a slot from the resource manager.
- requestSlot(SlotID, JobID, AllocationID, String, ResourceManagerId, Time) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- requestSlot(SlotID, JobID, AllocationID, String, ResourceManagerId, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
Requests a slot from the TaskManager.
- requestsNotReturned - Variable in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
An atomic integer that counts the number of requests that we still wait for to return.
- 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 interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Request a stack trace sample from the given task.
- requestStackTraceSample(ExecutionAttemptID, int, int, Time, int, Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
-
- requestStackTraceSample(ExecutionAttemptID, int, int, Time, int, Time) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- requestStackTraceSample(ExecutionAttemptID, int, int, Time, int, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
- RequestStatusOverview - Class in org.apache.flink.runtime.messages.webmonitor
-
This message requests an overview of the status, such as how many TaskManagers
are currently connected, how many slots are available, how many are free, ...
- requestSubpartition(ResultPartitionID, int, RemoteInputChannel, int) - Method in class org.apache.flink.runtime.io.network.netty.NettyPartitionRequestClient
-
Requests a remote intermediate result partition queue.
- requestSubpartition(int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
-
Requests a remote subpartition.
- requestSubpartition(ResultPartitionID, int, RemoteInputChannel, int) - Method in interface org.apache.flink.runtime.io.network.PartitionRequestClient
-
Requests a remote sub partition.
- requestSubpartitionView(ResultPartitionProvider, ResultPartitionID, int) - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
- requestSuccessful(T) - Method in class org.apache.flink.runtime.io.disk.iomanager.QueuingCallback
-
- requestSuccessful(T) - Method in interface org.apache.flink.runtime.io.disk.iomanager.RequestDoneCallback
-
- requestTaskManagerFileUpload(ResourceID, FileType, Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- requestTaskManagerFileUpload(ResourceID, FileType, Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
- requestTaskManagerInfo(Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- requestTaskManagerInfo(ResourceID, Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- requestTaskManagerInfo(Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
- requestTaskManagerInfo(ResourceID, Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
- requestTaskManagerMetricQueryServiceAddresses(Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- requestTaskManagerMetricQueryServiceAddresses(Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- requestTaskManagerMetricQueryServiceAddresses(Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
- requestTaskManagerMetricQueryServiceAddresses(Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
- requestTermination() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- requestTermination() - Method in class org.apache.flink.runtime.iterative.task.IterationSynchronizationSinkTask
-
- requestTermination() - Method in interface org.apache.flink.runtime.iterative.task.Terminable
-
- requiresComparator() - Method in enum org.apache.flink.runtime.operators.shipping.ShipStrategyType
-
- requiresComparator() - Method in enum org.apache.flink.runtime.operators.util.LocalStrategy
-
- requiresExternalizedCheckpoints() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
-
This method returns whether the completed checkpoint store requires checkpoints to be
externalized.
- requiresExternalizedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
-
- requiresExternalizedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
-
- requiresLegacySynchronousTimerSnapshots() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- requiresPreviousExecutionGraphAllocations() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.Scheduler
-
Returns true, iff the scheduling strategy of the scheduler requires to know about previous allocations.
- requiresPreviousExecutionGraphAllocations() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl
-
- RescalingHandlers - Class in org.apache.flink.runtime.rest.handler.job.rescaling
-
Rest handler to trigger and poll the rescaling of a running job.
- RescalingHandlers() - Constructor for class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers
-
- RescalingHandlers.RescalingStatusHandler - Class in org.apache.flink.runtime.rest.handler.job.rescaling
-
Handler which reports the status of the rescaling operation.
- RescalingHandlers.RescalingTriggerHandler - Class in org.apache.flink.runtime.rest.handler.job.rescaling
-
Handler which triggers the rescaling of the specified job.
- rescalingParallelismQueryParameter - Variable in class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerMessageParameters
-
- RescalingParallelismQueryParameter - Class in org.apache.flink.runtime.rest.messages
-
- RescalingParallelismQueryParameter() - Constructor for class org.apache.flink.runtime.rest.messages.RescalingParallelismQueryParameter
-
- RescalingStatusHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingStatusHandler
-
- RescalingStatusHeaders - Class in org.apache.flink.runtime.rest.handler.job.rescaling
-
Message headers for polling the status of an ongoing rescaling operation.
- RescalingStatusMessageParameters - Class in org.apache.flink.runtime.rest.handler.job.rescaling
-
- RescalingStatusMessageParameters() - Constructor for class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingStatusMessageParameters
-
- RescalingTriggerHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingHandlers.RescalingTriggerHandler
-
- RescalingTriggerHeaders - Class in org.apache.flink.runtime.rest.handler.job.rescaling
-
Message headers for triggering the rescaling of a job.
- RescalingTriggerMessageParameters - Class in org.apache.flink.runtime.rest.handler.job.rescaling
-
- RescalingTriggerMessageParameters() - Constructor for class org.apache.flink.runtime.rest.handler.job.rescaling.RescalingTriggerMessageParameters
-
- reset(Collection<MasterTriggerRestoreHook<?>>, Logger) - Static method in class org.apache.flink.runtime.checkpoint.hooks.MasterHooks
-
Resets the master hooks.
- reset() - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
-
This method is called by the checkpoint coordinator to reset the hook when
execution is restarted in the absence of any checkpoint state.
- reset() - Method in class org.apache.flink.runtime.io.disk.SimpleCollectingOutputView
-
- reset() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
-
Supports copying an intermediate data serialization buffer to multiple target buffers
by resetting its initial position before each copying.
- reset() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
-
- reset() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
-
- reset() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- reset() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- reset() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.HashBucketIterator
-
- reset() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
-
- reset() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
-
- reset() - Method in class org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
-
- reset() - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
-
- reset() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
-
- reset() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
-
- reset() - Method in interface org.apache.flink.runtime.operators.ResettableDriver
-
- reset() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
Resets the sort buffer back to the state where it is empty.
- reset() - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
-
Resets the sort buffer back to the state where it is empty.
- reset() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
Resets the sort buffer back to the state where it is empty.
- reset() - Method in class org.apache.flink.runtime.operators.util.BloomFilter
-
- reset() - Method in class org.apache.flink.runtime.state.BoundedInputStream
-
- reset() - Method in class org.apache.flink.runtime.util.ForwardingInputStream
-
- reset() - Method in interface org.apache.flink.runtime.util.ResettableIterator
-
Resets the iterator.
- reset() - Method in interface org.apache.flink.runtime.util.ResettableMutableObjectIterator
-
Resets the iterator.
- resetAllInputs() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- resetConstraints() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
-
- resetEndOfSuperstep() - Method in class org.apache.flink.runtime.iterative.task.SyncEventHandler
-
- resetForNewExecution(long, long) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- resetForNewExecution(long, long) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
Archives the current Execution and creates a new Execution for this vertex.
- resetIsAvailable() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
- resetOverflowBuckets() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
resets overflow bucket counters and returns freed memory and should only be used for resizing
- resetRecordCounter() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
sets record counter to zero and should only be used on compaction partition
- resetRWViews() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
resets read and write views and should only be used on compaction partition
- ResettableDriver<S extends org.apache.flink.api.common.functions.Function,OT> - Interface in org.apache.flink.runtime.operators
-
This interface marks a Driver
as resettable, meaning that will reset part of their internal state but
otherwise reuse existing data structures.
- resettableInputs - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The resettable inputs in the case where no temp barrier is needed.
- ResettableIterator<E> - Interface in org.apache.flink.runtime.util
-
The resettable iterator is a specialization of the iterator, allowing to reset the iterator and re-retrieve elements.
- ResettableMutableObjectIterator<E> - Interface in org.apache.flink.runtime.util
-
The resettable iterator is a specialization of the iterator, allowing to reset the iterator and re-retrieve elements.
- resizeForBulkLoad(int) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
-
- resizeQueueArray(int, int) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
-
- resolve(RestartStrategies.RestartStrategyConfiguration, RestartStrategyFactory, boolean) - Static method in class org.apache.flink.runtime.executiongraph.restart.RestartStrategyResolving
-
- resolve(X) - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Resolves this parameter for the given value.
- resolveCheckpoint(String) - Method in interface org.apache.flink.runtime.state.CheckpointStorageCoordinatorView
-
Resolves the given pointer to a checkpoint/savepoint into a checkpoint location.
- resolveCheckpoint(String) - Method in class org.apache.flink.runtime.state.filesystem.AbstractFileStateBackend
-
- resolveCheckpoint(String) - Method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
-
- resolveCheckpoint(String) - Method in interface org.apache.flink.runtime.state.StateBackend
-
Resolves the given pointer to a checkpoint/savepoint into a checkpoint location.
- resolveCheckpointPointer(String) - Static method in class org.apache.flink.runtime.state.filesystem.AbstractFsCheckpointStorage
-
Takes the given string (representing a pointer to a checkpoint) and resolves it to a file
status for the checkpoint's metadata file.
- resolveCheckpointStorageLocation(long, CheckpointStorageLocationReference) - Method in interface org.apache.flink.runtime.state.CheckpointStorageWorkerView
-
Resolves a storage location reference into a CheckpointStreamFactory.
- resolveCheckpointStorageLocation(long, CheckpointStorageLocationReference) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
-
- resolveCheckpointStorageLocation(long, CheckpointStorageLocationReference) - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
-
- resolveFromString(String) - Method in class org.apache.flink.runtime.rest.messages.MessageParameter
-
Resolves this parameter for the given string value representation.
- resolvePrioritizedAlternatives(StateObjectCollection<T>, List<StateObjectCollection<T>>, BiFunction<T, T, Boolean>) - Method in class org.apache.flink.runtime.checkpoint.PrioritizedOperatorSubtaskState.Builder
-
This helper method resolves the dependencies between the ground truth of the operator state obtained from the
job manager and potential alternatives for recovery, e.g.
- resolveSchemaCompatibilityViaRedirectingToNewSnapshotClass(TypeSerializerConfigSnapshot<ArrayList<T>>) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
We need to implement this method as a TypeSerializerConfigSnapshot.SelfResolvingTypeSerializer
because this serializer was previously returning a shared CollectionSerializerConfigSnapshot
as its snapshot.
- resolveSchemaCompatibilityViaRedirectingToNewSnapshotClass(TypeSerializerConfigSnapshot<TtlValue<T>>) - Method in class org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
-
- resolveUrl(String, MessageParameters) - Static method in class org.apache.flink.runtime.rest.messages.MessageParameters
-
Resolves the given URL (e.g "jobs/:jobid") using the given path/query parameters.
- resource() - Method in class org.apache.flink.runtime.rest.handler.async.AsynchronousOperationResult
-
- resource() - Method in class org.apache.flink.runtime.rest.messages.job.JobExecutionResultResponseBody
-
- resource() - Method in interface org.apache.flink.runtime.rest.messages.queue.AsynchronouslyCreatedResource
-
Returns the resource if it is available, null
otherwise.
- RESOURCE_MANAGER_NAME - Static variable in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- ResourceActions - Interface in org.apache.flink.runtime.resourcemanager.slotmanager
-
Resource related actions which the
SlotManager
can perform.
- ResourceID - Class in org.apache.flink.runtime.clusterframework.types
-
Class for Resource Ids identifying Flink's distributed components.
- ResourceID(String) - Constructor for class org.apache.flink.runtime.clusterframework.types.ResourceID
-
- ResourceIDDeserializer - Class in org.apache.flink.runtime.rest.messages.json
-
- ResourceIDDeserializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.ResourceIDDeserializer
-
- ResourceIDRetrievable - Interface in org.apache.flink.runtime.clusterframework.types
-
An interface to retrieve the ResourceID of an object.
- ResourceIDSerializer - Class in org.apache.flink.runtime.rest.messages.json
-
- ResourceIDSerializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.ResourceIDSerializer
-
- ResourceManager<WorkerType extends ResourceIDRetrievable> - Class in org.apache.flink.runtime.resourcemanager
-
ResourceManager implementation.
- ResourceManager(RpcService, String, ResourceID, HighAvailabilityServices, HeartbeatServices, SlotManager, MetricRegistry, JobLeaderIdService, ClusterInformation, FatalErrorHandler, JobManagerMetricGroup) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- ResourceManagerAddress - Class in org.apache.flink.runtime.jobmaster
-
Current address and fencing token of the leading ResourceManager.
- ResourceManagerAddress(String, ResourceManagerId) - Constructor for class org.apache.flink.runtime.jobmaster.ResourceManagerAddress
-
- ResourceManagerException - Exception in org.apache.flink.runtime.resourcemanager.exceptions
-
- ResourceManagerException(String) - Constructor for exception org.apache.flink.runtime.resourcemanager.exceptions.ResourceManagerException
-
- ResourceManagerException(String, Throwable) - Constructor for exception org.apache.flink.runtime.resourcemanager.exceptions.ResourceManagerException
-
- ResourceManagerException(Throwable) - Constructor for exception org.apache.flink.runtime.resourcemanager.exceptions.ResourceManagerException
-
- ResourceManagerFactory<T extends ResourceIDRetrievable> - Interface in org.apache.flink.runtime.resourcemanager
-
- ResourceManagerGateway - Interface in org.apache.flink.runtime.resourcemanager
-
- ResourceManagerId - Class in org.apache.flink.runtime.resourcemanager
-
- ResourceManagerRuntimeServices - Class in org.apache.flink.runtime.resourcemanager
-
- ResourceManagerRuntimeServices(SlotManager, JobLeaderIdService) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
-
- ResourceManagerRuntimeServicesConfiguration - Class in org.apache.flink.runtime.resourcemanager
-
- ResourceManagerRuntimeServicesConfiguration(Time, SlotManagerConfiguration) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
-
- ResourceManagerServices - Interface in org.apache.flink.runtime.resourcemanager
-
Interface which provides access to services of the ResourceManager.
- ResourceOverview - Class in org.apache.flink.runtime.resourcemanager
-
Class containing information about the available cluster resources.
- ResourceOverview(int, int, int) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceOverview
-
- ResourceProfile - Class in org.apache.flink.runtime.clusterframework.types
-
Describe the immutable resource profile of the slot, either when requiring or offering it.
- ResourceProfile(double, int, int, int, int, int, Map<String, Resource>) - Constructor for class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Creates a new ResourceProfile.
- ResourceProfile(double, int) - Constructor for class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Creates a new simple ResourceProfile used for testing.
- ResourceProfile(ResourceProfile) - Constructor for class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Creates a copy of the given ResourceProfile.
- respondAsLeader(ChannelHandlerContext, RoutedRequest, T) - Method in class org.apache.flink.runtime.rest.handler.AbstractHandler
-
- respondAsLeader(ChannelHandlerContext, RoutedRequest, T) - Method in class org.apache.flink.runtime.rest.handler.LeaderRetrievalHandler
-
- respondAsLeader(ChannelHandlerContext, RoutedRequest, T) - Method in class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
-
- respondToRequest(ChannelHandlerContext, HttpRequest, HandlerRequest<R, M>, T) - Method in class org.apache.flink.runtime.rest.handler.AbstractHandler
-
- respondToRequest(ChannelHandlerContext, HttpRequest, HandlerRequest<R, M>, T) - Method in class org.apache.flink.runtime.rest.handler.AbstractRestHandler
-
- respondToRequest(ChannelHandlerContext, HttpRequest, HandlerRequest<EmptyRequestBody, M>, RestfulGateway) - Method in class org.apache.flink.runtime.rest.handler.taskmanager.AbstractTaskManagerFileHandler
-
- ResponseBody - Interface in org.apache.flink.runtime.rest.messages
-
Marker interface for all responses of the REST API.
- responseHeaders - Variable in class org.apache.flink.runtime.rest.handler.LeaderRetrievalHandler
-
- responseHeaders - Variable in class org.apache.flink.runtime.rest.RestServerEndpoint
-
- REST_CONTENT_TYPE - Static variable in enum org.apache.flink.runtime.rest.util.RestConstants
-
- REST_PORT_OPTION - Static variable in class org.apache.flink.runtime.entrypoint.parser.CommandLineOptions
-
- RestAPIVersion - Enum in org.apache.flink.runtime.rest.versioning
-
An enum for all versions of the REST API.
- RestAPIVersion.RestAPIVersionComparator - Class in org.apache.flink.runtime.rest.versioning
-
Comparator for
RestAPIVersion
that sorts versions based on their version number, i.e.
- RestAPIVersionComparator() - Constructor for class org.apache.flink.runtime.rest.versioning.RestAPIVersion.RestAPIVersionComparator
-
- restart(long) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- restart(RestartCallback, ScheduledExecutor) - Method in class org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy
-
- restart(RestartCallback, ScheduledExecutor) - Method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
-
- restart(RestartCallback, ScheduledExecutor) - Method in class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
-
- restart(RestartCallback, ScheduledExecutor) - Method in interface org.apache.flink.runtime.executiongraph.restart.RestartStrategy
-
Called by the ExecutionGraph to eventually trigger a full recovery.
- restart(RestartCallback, ScheduledExecutor) - Method in class org.apache.flink.runtime.executiongraph.restart.ThrowingRestartStrategy
-
- restartable(Set<ExecutionVertexID>, long) - Static method in class org.apache.flink.runtime.executiongraph.failover.flip1.FailureHandlingResult
-
Creates a result of a set of tasks to restart to recover from the failure.
- RestartAllStrategy - Class in org.apache.flink.runtime.executiongraph.failover
-
- RestartAllStrategy(ExecutionGraph) - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy
-
Creates a new failover strategy that recovers from failures by restarting all tasks
of the execution graph.
- RestartAllStrategy.Factory - Class in org.apache.flink.runtime.executiongraph.failover
-
Factory that instantiates the RestartAllStrategy.
- RestartBackoffTimeStrategy - Interface in org.apache.flink.runtime.executiongraph.failover.flip1
-
Strategy to decide whether to restart failed tasks and the delay to do the restarting.
- RestartBackoffTimeStrategy.Factory - Interface in org.apache.flink.runtime.executiongraph.failover.flip1
-
- RestartCallback - Interface in org.apache.flink.runtime.executiongraph.restart
-
A callback to trigger restarts, passed to the
RestartStrategy
to
trigger recovery on the ExecutionGraph.
- RestartIndividualStrategy - Class in org.apache.flink.runtime.executiongraph.failover
-
Simple failover strategy that restarts each task individually.
- RestartIndividualStrategy(ExecutionGraph) - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
-
Creates a new failover strategy that recovers from failures by restarting only the failed task
of the execution graph.
- RestartIndividualStrategy.Factory - Class in org.apache.flink.runtime.executiongraph.failover
-
Factory that instantiates the RestartAllStrategy.
- RestartPipelinedRegionStrategy - Class in org.apache.flink.runtime.executiongraph.failover.flip1
-
A failover strategy that proposes to restart involved regions when a vertex fails.
- RestartPipelinedRegionStrategy(FailoverTopology) - Constructor for class org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy
-
Creates a new failover strategy to restart pipelined regions that works on the given topology.
- RestartPipelinedRegionStrategy(FailoverTopology, ResultPartitionAvailabilityChecker) - Constructor for class org.apache.flink.runtime.executiongraph.failover.flip1.RestartPipelinedRegionStrategy
-
Creates a new failover strategy to restart pipelined regions that works on the given topology.
- RestartPipelinedRegionStrategy - Class in org.apache.flink.runtime.executiongraph.failover
-
A failover strategy that restarts regions of the ExecutionGraph with state.
- RestartPipelinedRegionStrategy(ExecutionGraph) - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
-
Creates a new failover strategy to restart pipelined regions that works on the given
execution graph.
- RestartPipelinedRegionStrategy.Factory - Class in org.apache.flink.runtime.executiongraph.failover
-
Factory that instantiates the RestartPipelinedRegionStrategy.
- 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
-
- RestartStrategyResolving - Class in org.apache.flink.runtime.executiongraph.restart
-
- restartTasks(Set<ExecutionVertexID>) - Method in class org.apache.flink.runtime.executiongraph.failover.AdaptedRestartPipelinedRegionStrategyNG
-
- restartTasks(Set<ExecutionVertexID>) - Method in class org.apache.flink.runtime.scheduler.strategy.EagerSchedulingStrategy
-
- restartTasks(Set<ExecutionVertexID>) - Method in class org.apache.flink.runtime.scheduler.strategy.LazyFromSourcesSchedulingStrategy
-
- restartTasks(Set<ExecutionVertexID>) - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingStrategy
-
Called whenever vertices need to be restarted (due to task failure).
- RestartTimeGauge - Class in org.apache.flink.runtime.executiongraph.metrics
-
Gauge which returns the last restarting time.
- RestartTimeGauge(ExecutionGraph) - Constructor for class org.apache.flink.runtime.executiongraph.metrics.RestartTimeGauge
-
- RestClient - Class in org.apache.flink.runtime.rest
-
- RestClient(RestClientConfiguration, Executor) - Constructor for class org.apache.flink.runtime.rest.RestClient
-
- RestClientConfiguration - Class in org.apache.flink.runtime.rest
-
- RestClientException - Exception in org.apache.flink.runtime.rest.util
-
An exception that is thrown if the failure of a REST operation was detected on the client.
- RestClientException(String, HttpResponseStatus) - Constructor for exception org.apache.flink.runtime.rest.util.RestClientException
-
- RestClientException(String, Throwable, HttpResponseStatus) - Constructor for exception org.apache.flink.runtime.rest.util.RestClientException
-
- restConfiguration - Variable in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
-
- RestConstants - Enum in org.apache.flink.runtime.rest.util
-
This class contains constants to be used by rest components.
- RestEndpointFactory<T extends RestfulGateway> - Interface in org.apache.flink.runtime.rest
-
- RestfulGateway - Interface in org.apache.flink.runtime.webmonitor
-
Gateway for restful endpoints.
- RestHandlerConfiguration - Class in org.apache.flink.runtime.rest.handler
-
Configuration object containing values for the rest handler configuration.
- RestHandlerConfiguration(long, int, Time, File) - Constructor for class org.apache.flink.runtime.rest.handler.RestHandlerConfiguration
-
- RestHandlerException - Exception in org.apache.flink.runtime.rest.handler
-
An exception that is thrown if the failure of a REST operation was detected by a handler.
- RestHandlerException(String, HttpResponseStatus) - Constructor for exception org.apache.flink.runtime.rest.handler.RestHandlerException
-
- RestHandlerException(String, HttpResponseStatus, Throwable) - Constructor for exception org.apache.flink.runtime.rest.handler.RestHandlerException
-
- RestHandlerSpecification - Interface in org.apache.flink.runtime.rest.handler
-
Rest handler interface which all rest handler implementation have to implement.
- RestHandlerUrlComparator() - Constructor for class org.apache.flink.runtime.rest.RestServerEndpoint.RestHandlerUrlComparator
-
- RestMapperUtils - Class in org.apache.flink.runtime.rest.util
-
This class contains utilities for mapping requests and responses to/from JSON.
- RestMapperUtils() - Constructor for class org.apache.flink.runtime.rest.util.RestMapperUtils
-
- restore() - Method in class org.apache.flink.runtime.state.heap.HeapRestoreOperation
-
- restore() - Method in class org.apache.flink.runtime.state.OperatorStateRestoreOperation
-
- restore() - Method in interface org.apache.flink.runtime.state.RestoreOperation
-
Restores state that was previously snapshot-ed from the provided state handles.
- restoreCheckpoint(long, T) - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
-
This method is called by the checkpoint coordinator prior to restoring the state of a checkpoint.
- RestoredCheckpointStatistics(long, long, boolean, String) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.RestoredCheckpointStatistics
-
- RestoredCheckpointStats - Class in org.apache.flink.runtime.checkpoint
-
Statistics for a restored checkpoint.
- restoreLatestCheckpointedState(Map<JobVertexID, ExecutionJobVertex>, boolean, boolean) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Restores the latest checkpointed state.
- restoreMasterHooks(Map<String, MasterTriggerRestoreHook<?>>, Collection<MasterState>, long, boolean, Logger) - Static method in class org.apache.flink.runtime.checkpoint.hooks.MasterHooks
-
Calls the restore method given checkpoint master hooks and passes the given master
state to them where state with a matching name is found.
- RestoreOperation<R> - Interface in org.apache.flink.runtime.state
-
Interface for restore operation.
- restoreSavepoint(String, boolean, Map<JobVertexID, ExecutionJobVertex>, ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Restore the state with given savepoint.
- restoreSavepoint() - Method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
-
Returns whether to restore from savepoint.
- restoreStateHandles - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
-
- restoreStateHandles - Variable in class org.apache.flink.runtime.state.DefaultOperatorStateBackendBuilder
-
State handles for restore.
- RestServerEndpoint - Class in org.apache.flink.runtime.rest
-
An abstract class for netty-based REST server endpoints.
- RestServerEndpoint(RestServerEndpointConfiguration) - Constructor for class org.apache.flink.runtime.rest.RestServerEndpoint
-
- RestServerEndpoint.RestHandlerUrlComparator - Class in org.apache.flink.runtime.rest
-
Comparator for Rest URLs.
- RestServerEndpoint.RestHandlerUrlComparator.CaseInsensitiveOrderComparator - Class in org.apache.flink.runtime.rest
-
Comparator for Rest URLs.
- RestServerEndpointConfiguration - Class in org.apache.flink.runtime.rest
-
- Result(StreamStateHandle, int) - Constructor for class org.apache.flink.runtime.state.SharedStateRegistry.Result
-
- resultHandler - Variable in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
-
Handler for completed requests
- ResultPartition - Class in org.apache.flink.runtime.io.network.partition
-
A result partition for data produced by a single task.
- ResultPartition(String, ResultPartitionID, ResultPartitionType, ResultSubpartition[], int, ResultPartitionManager, FunctionWithException<BufferPoolOwner, BufferPool, IOException>) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultPartition
-
- ResultPartitionAvailabilityChecker - Interface in org.apache.flink.runtime.executiongraph.failover.flip1
-
This checker helps to query result partition availability.
- ResultPartitionConsumableNotifier - Interface in org.apache.flink.runtime.io.network.partition
-
Interface for notifications about consumable partitions.
- ResultPartitionDeploymentDescriptor - Class in org.apache.flink.runtime.deployment
-
Deployment descriptor for a result partition.
- ResultPartitionDeploymentDescriptor(PartitionDescriptor, ShuffleDescriptor, int, boolean) - Constructor for class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- ResultPartitionFactory - Class in org.apache.flink.runtime.io.network.partition
-
- ResultPartitionFactory(ResultPartitionManager, FileChannelManager, BufferPoolFactory, BoundedBlockingSubpartitionType, int, int, int, boolean) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultPartitionFactory
-
- 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
-
- ResultPartitionManager - Class in org.apache.flink.runtime.io.network.partition
-
The result partition manager keeps track of all currently produced/consumed partitions of a
task manager.
- ResultPartitionManager() - Constructor for class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
-
- ResultPartitionMetrics - Class in org.apache.flink.runtime.io.network.metrics
-
Collects metrics of a result partition.
- ResultPartitionProvider - Interface in org.apache.flink.runtime.io.network.partition
-
Interface for creating result partitions.
- ResultPartitionType - Enum in org.apache.flink.runtime.io.network.partition
-
Type of a result partition.
- ResultPartitionWriter - Interface in org.apache.flink.runtime.io.network.api.writer
-
A buffer-oriented runtime result writer API for producing results.
- ResultSubpartition - Class in org.apache.flink.runtime.io.network.partition
-
- ResultSubpartition(int, ResultPartition) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultSubpartition
-
- ResultSubpartition.BufferAndBacklog - Class in org.apache.flink.runtime.io.network.partition
-
A combination of a
Buffer
and the backlog length indicating
how many non-event buffers are available in the subpartition.
- ResultSubpartitionView - Interface in org.apache.flink.runtime.io.network.partition
-
- retain() - Method in class org.apache.flink.runtime.rest.handler.router.RoutedRequest
-
- retain(int) - Method in class org.apache.flink.runtime.rest.handler.router.RoutedRequest
-
- retainAll(Collection<?>) - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- retainAll(Collection<?>) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- retainBuffer() - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Retains this buffer for further use, increasing the reference counter by 1.
- retainBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- retainBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- RetrievableStateHandle<T extends Serializable> - Interface in org.apache.flink.runtime.state
-
- 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
-
- retrieveJobGraph(Configuration) - Method in class org.apache.flink.runtime.entrypoint.component.FileJobGraphRetriever
-
- retrieveJobGraph(Configuration) - Method in interface org.apache.flink.runtime.entrypoint.component.JobGraphRetriever
-
- retrieveLeaderConnectionInfo(LeaderRetrievalService, Time) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
-
Retrieves the leader akka url and the current leader session ID.
- retrieveLeaderConnectionInfo(LeaderRetrievalService, FiniteDuration) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
-
Retrieves the leader akka url and the current leader session ID.
- retrieveLocalState(long) - Method in class org.apache.flink.runtime.state.NoOpTaskLocalStateStoreImpl
-
- retrieveLocalState(long) - Method in interface org.apache.flink.runtime.state.TaskLocalStateStore
-
Returns the local state that is stored under the given checkpoint id or null if nothing was stored under the id.
- retrieveLocalState(long) - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
- retrievePayload(ResourceID) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatListener
-
Retrieves the payload value for the next heartbeat message.
- retrieveService(String) - Method in class org.apache.flink.runtime.webmonitor.retriever.impl.RpcMetricQueryServiceRetriever
-
- retrieveService(String) - Method in interface org.apache.flink.runtime.webmonitor.retriever.MetricQueryServiceRetriever
-
- retrieveState() - Method in interface org.apache.flink.runtime.state.RetrievableStateHandle
-
Retrieves the object that was previously written to state.
- retrieveState() - Method in class org.apache.flink.runtime.state.RetrievableStreamStateHandle
-
- retriggerPartitionRequest(IntermediateResultPartitionID) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
Retriggers a partition request.
- retry(Supplier<CompletableFuture<T>>, int, Executor) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Retry the given operation the given number of times in case of a failure.
- RetryException(String) - Constructor for exception org.apache.flink.runtime.concurrent.FutureUtils.RetryException
-
- RetryException(String, Throwable) - Constructor for exception org.apache.flink.runtime.concurrent.FutureUtils.RetryException
-
- RetryException(Throwable) - Constructor for exception org.apache.flink.runtime.concurrent.FutureUtils.RetryException
-
- RetryingRegistration<F extends Serializable,G extends RpcGateway,S extends RegistrationResponse.Success> - Class in org.apache.flink.runtime.registration
-
This utility class implements the basis of registering one component at another component,
for example registering the TaskExecutor at the ResourceManager.
- RetryingRegistration(Logger, RpcService, String, Class<G>, String, F, RetryingRegistrationConfiguration) - Constructor for class org.apache.flink.runtime.registration.RetryingRegistration
-
- RetryingRegistrationConfiguration - Class in org.apache.flink.runtime.registration
-
Configuration for the cluster components.
- RetryingRegistrationConfiguration(long, long, long, long) - Constructor for class org.apache.flink.runtime.registration.RetryingRegistrationConfiguration
-
- retrySuccessfulWithDelay(Supplier<CompletableFuture<T>>, Time, Deadline, Predicate<T>, ScheduledExecutor) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Retry the given operation with the given delay in between successful completions where the
result does not match a given predicate.
- retryWithDelay(Supplier<CompletableFuture<T>>, int, Time, Predicate<Throwable>, ScheduledExecutor) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Retry the given operation with the given delay in between failures.
- retryWithDelay(Supplier<CompletableFuture<T>>, int, Time, ScheduledExecutor) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Retry the given operation with the given delay in between failures.
- returnLogicalSlot(LogicalSlot) - Method in class org.apache.flink.runtime.instance.Instance
-
Returns a slot that has been allocated from this instance.
- returnLogicalSlot(LogicalSlot) - Method in interface org.apache.flink.runtime.jobmaster.SlotOwner
-
Return the given slot to the slot owner.
- returnLogicalSlot(LogicalSlot) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl
-
- 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
-
This class wraps a
MutableObjectIterator
into a regular
Iterator
.
- ReusingMutableToRegularIteratorWrapper(MutableObjectIterator<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.util.ReusingMutableToRegularIteratorWrapper
-
- ReusingSortMergeCoGroupIterator<T1,T2> - Class in org.apache.flink.runtime.operators.sort
-
- ReusingSortMergeCoGroupIterator(MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>) - Constructor for class org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
-
- RevisionInformation(String, String) - Constructor for class org.apache.flink.runtime.util.EnvironmentInformation.RevisionInformation
-
- revokeLeadership() - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
Callback method when current resourceManager loses leadership.
- revokeLeadership() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
-
- revokeLeadership() - Method in interface org.apache.flink.runtime.leaderelection.LeaderContender
-
Callback method which is called by the
LeaderElectionService
upon revoking the
leadership of a former leader.
- revokeLeadership() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
Callback method when current resourceManager loses leadership.
- revokeLeadership() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
-
- RightOuterJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
-
The right outer join driver implements the logic of an outer join operator at runtime.
- RightOuterJoinDriver() - Constructor for class org.apache.flink.runtime.operators.RightOuterJoinDriver
-
- ROCKSDB_STATE_BACKEND_NAME - Static variable in class org.apache.flink.runtime.state.StateBackendLoader
-
The shortcut configuration name for the RocksDB State Backend
- roundDownToPageSizeMultiple(long) - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Rounds the given value down to a multiple of the memory manager's page size.
- RoundRobinChannelSelector<T extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.writer
-
- RoundRobinChannelSelector() - Constructor for class org.apache.flink.runtime.io.network.api.writer.RoundRobinChannelSelector
-
- RoundRobinOperatorStateRepartitioner - Class in org.apache.flink.runtime.checkpoint
-
- RoundRobinOperatorStateRepartitioner() - Constructor for class org.apache.flink.runtime.checkpoint.RoundRobinOperatorStateRepartitioner
-
- route(HttpMethod, String) - Method in class org.apache.flink.runtime.rest.handler.router.Router
-
If there's no match, returns the result with
notFound
as the target if it is set, otherwise returns
null
.
- route(HttpMethod, String, Map<String, List<String>>) - Method in class org.apache.flink.runtime.rest.handler.router.Router
-
- RoutedRequest<T> - Class in org.apache.flink.runtime.rest.handler.router
-
Class for handling
HttpRequest
with associated
RouteResult
.
- RoutedRequest(RouteResult<T>, HttpRequest) - Constructor for class org.apache.flink.runtime.rest.handler.router.RoutedRequest
-
- Router<T> - Class in org.apache.flink.runtime.rest.handler.router
-
This is adopted and simplified code from tv.cntt:netty-router library.
- Router() - Constructor for class org.apache.flink.runtime.rest.handler.router.Router
-
- RouteResult<T> - Class in org.apache.flink.runtime.rest.handler.router
-
This is adopted and simplified code from tv.cntt:netty-router library.
- RouteResult(String, String, Map<String, String>, Map<String, List<String>>, T) - Constructor for class org.apache.flink.runtime.rest.handler.router.RouteResult
-
The maps will be wrapped in Collections.unmodifiableMap.
- RouterHandler - Class in org.apache.flink.runtime.rest.handler.router
-
Inbound handler that converts HttpRequest to Routed and passes Routed to the matched handler.
- RouterHandler(Router, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.router.RouterHandler
-
- RpcCheckpointResponder - Class in org.apache.flink.runtime.taskexecutor.rpc
-
- RpcCheckpointResponder(CheckpointCoordinatorGateway) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcCheckpointResponder
-
- RpcConnectionException - Exception in org.apache.flink.runtime.rpc.exceptions
-
Exception class which is thrown if a rpc connection failed.
- RpcConnectionException(String) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcConnectionException
-
- RpcConnectionException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcConnectionException
-
- RpcConnectionException(Throwable) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcConnectionException
-
- RpcEndpoint - Class in org.apache.flink.runtime.rpc
-
Base class for RPC endpoints.
- RpcEndpoint(RpcService, String) - Constructor for class org.apache.flink.runtime.rpc.RpcEndpoint
-
Initializes the RPC endpoint.
- RpcEndpoint(RpcService) - Constructor for class org.apache.flink.runtime.rpc.RpcEndpoint
-
Initializes the RPC endpoint with a random endpoint id.
- RpcEndpoint.MainThreadExecutor - Class in org.apache.flink.runtime.rpc
-
Executor which executes runnables in the main thread context.
- RpcException - Exception in org.apache.flink.runtime.rpc.exceptions
-
Base class for RPC related exceptions.
- RpcException(String) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcException
-
- RpcException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcException
-
- RpcException(Throwable) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcException
-
- RpcGateway - Interface in org.apache.flink.runtime.rpc
-
Rpc gateway interface which has to be implemented by Rpc gateways.
- RpcGatewayRetriever<F extends Serializable,T extends FencedRpcGateway<F>> - Class in org.apache.flink.runtime.webmonitor.retriever.impl
-
- RpcGatewayRetriever(RpcService, Class<T>, Function<UUID, F>, int, Time) - Constructor for class org.apache.flink.runtime.webmonitor.retriever.impl.RpcGatewayRetriever
-
- RpcGlobalAggregateManager - Class in org.apache.flink.runtime.taskexecutor.rpc
-
- RpcGlobalAggregateManager(JobMasterGateway) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcGlobalAggregateManager
-
- RpcInputSplitProvider - Class in org.apache.flink.runtime.taskexecutor.rpc
-
- RpcInputSplitProvider(JobMasterGateway, JobVertexID, ExecutionAttemptID, Time) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcInputSplitProvider
-
- RpcInvocation - Interface in org.apache.flink.runtime.rpc.messages
-
Interface for rpc invocation messages.
- RpcKvStateRegistryListener - Class in org.apache.flink.runtime.taskexecutor.rpc
-
- RpcKvStateRegistryListener(KvStateRegistryGateway, InetSocketAddress) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcKvStateRegistryListener
-
- RpcMetricQueryServiceRetriever - Class in org.apache.flink.runtime.webmonitor.retriever.impl
-
- RpcMetricQueryServiceRetriever(RpcService) - Constructor for class org.apache.flink.runtime.webmonitor.retriever.impl.RpcMetricQueryServiceRetriever
-
- RpcPartitionStateChecker - Class in org.apache.flink.runtime.taskexecutor.rpc
-
- RpcPartitionStateChecker(JobMasterGateway) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcPartitionStateChecker
-
- RpcResultPartitionConsumableNotifier - Class in org.apache.flink.runtime.taskexecutor.rpc
-
- RpcResultPartitionConsumableNotifier(JobMasterGateway, Executor, Time) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcResultPartitionConsumableNotifier
-
- rpcServer - Variable in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Interface to access the underlying rpc server.
- RpcServer - Interface in org.apache.flink.runtime.rpc
-
Interface for self gateways.
- RpcService - Interface in org.apache.flink.runtime.rpc
-
Interface for rpc services.
- RpcServiceSharing - Enum in org.apache.flink.runtime.minicluster
-
Enum which defines whether the mini cluster components use a shared RpcService
or whether every component gets its own dedicated RpcService started.
- RpcTaskManagerGateway - Class in org.apache.flink.runtime.jobmaster
-
- RpcTaskManagerGateway(TaskExecutorGateway, JobMasterId) - Constructor for class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
-
- RpcTimeout - Annotation Type in org.apache.flink.runtime.rpc
-
Annotation for
RpcGateway
methods to specify an additional timeout parameter for the
returned future to be completed.
- RpcUtils - Class in org.apache.flink.runtime.rpc
-
Utility functions for Flink's RPC implementation.
- run() - Method in class org.apache.flink.runtime.blob.BlobServer
-
- run() - Method in class org.apache.flink.runtime.heartbeat.HeartbeatManagerSenderImpl
-
- run() - Method in class org.apache.flink.runtime.heartbeat.HeartbeatMonitorImpl
-
- run() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- run() - Method in class org.apache.flink.runtime.iterative.task.IterationHeadTask
-
- run() - Method in class org.apache.flink.runtime.iterative.task.IterationIntermediateTask
-
- run() - Method in class org.apache.flink.runtime.iterative.task.IterationTailTask
-
- run() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
-
- run() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
-
- run() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
-
- run() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
-
- run() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
-
- run() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
-
- run() - Method in class org.apache.flink.runtime.operators.BatchTask
-
- run() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
-
- run() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
-
- run() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- run() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- run() - Method in class org.apache.flink.runtime.operators.CrossDriver
-
- run() - Method in interface org.apache.flink.runtime.operators.Driver
-
The main operation method of the task.
- run() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
-
- run() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
-
- run() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
-
- run() - Method in class org.apache.flink.runtime.operators.JoinDriver
-
- run() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
-
- run() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
-
- run() - Method in class org.apache.flink.runtime.operators.MapDriver
-
- run() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
-
- run() - Method in class org.apache.flink.runtime.operators.NoOpDriver
-
- run() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
-
- run() - Method in class org.apache.flink.runtime.operators.ReduceDriver
-
- run() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
-
Implements exception handling and delegates to go().
- run() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
-
- run() - Method in class org.apache.flink.runtime.state.DoneFuture
-
- run() - Method in class org.apache.flink.runtime.taskmanager.MemoryLogger
-
- run() - Method in class org.apache.flink.runtime.taskmanager.Task
-
The core work method that bootstraps the task and executes its code.
- run() - Method in class org.apache.flink.runtime.util.JvmShutdownSafeguard
-
- run() - Method in class org.apache.flink.runtime.util.ProcessShutDownThread
-
- runAfterwards(CompletableFuture<?>, RunnableWithException) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Run the given action after the completion of the given future.
- runAfterwardsAsync(CompletableFuture<?>, RunnableWithException) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Run the given action after the completion of the given future.
- runAfterwardsAsync(CompletableFuture<?>, RunnableWithException, Executor) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Run the given action after the completion of the given future.
- runAsync(Runnable) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
-
Execute the runnable in the main thread of the underlying RPC endpoint.
- runAsync(Runnable) - Method in interface org.apache.flink.runtime.rpc.MainThreadExecutable
-
Execute the runnable in the main thread of the underlying RPC endpoint.
- RunAsync - Class in org.apache.flink.runtime.rpc.messages
-
Message for asynchronous runnable invocations
- RunAsync(Runnable, long) - Constructor for class org.apache.flink.runtime.rpc.messages.RunAsync
-
Creates a new RunAsync
message.
- runAsync(Runnable) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint.MainThreadExecutor
-
- runAsync(Runnable) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Execute the runnable in the main thread of the underlying RPC endpoint.
- runAsyncWithoutFencing(Runnable) - Method in class org.apache.flink.runtime.rpc.akka.FencedAkkaInvocationHandler
-
- runAsyncWithoutFencing(Runnable) - Method in interface org.apache.flink.runtime.rpc.FencedMainThreadExecutable
-
Run the given runnable in the main thread without attaching a fencing token.
- runAsyncWithoutFencing(Runnable) - Method in class org.apache.flink.runtime.rpc.FencedRpcEndpoint
-
Run the given runnable in the main thread of the RpcEndpoint without checking the fencing
token.
- runClusterEntrypoint(ClusterEntrypoint) - Static method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- runDetached(JobGraph) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
This method executes a job in detached mode.
- runFlinkZkQuorumPeer(String, int) - Static method in class org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
-
Runs a ZooKeeper QuorumPeer
if further peers are configured or a single
ZooKeeperServer
if no further peers are configured.
- runIfNotDoneAndGet(RunnableFuture<T>) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Run the given RunnableFuture
if it is not done, and then retrieves its result.
- running - Variable in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
-
- running - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The flag that tags the task as still running.
- running - Variable in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
-
- running - Variable in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
-
- running - Variable in class org.apache.flink.runtime.operators.JoinDriver
-
- running - Variable in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
-
- running - Variable in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
-
- RunningJobsRegistry - Interface in org.apache.flink.runtime.highavailability
-
A simple registry that tracks if a certain job is pending execution, running, or completed.
- RunningJobsRegistry.JobSchedulingStatus - Enum in org.apache.flink.runtime.highavailability
-
The scheduling status of a job, as maintained by the RunningJobsRegistry
.
- runSecured(Callable<T>) - Method in interface org.apache.flink.runtime.security.SecurityContext
-
- runTaskManager(Configuration, ResourceID) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
-
- RUNTIME_FAILURE_RETURN_CODE - Static variable in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- RUNTIME_FAILURE_RETURN_CODE - Static variable in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
-
- 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, TaskStateManager, GlobalAggregateManager, AccumulatorRegistry, TaskKvStateRegistry, InputSplitProvider, Map<String, Future<Path>>, ResultPartitionWriter[], InputGate[], TaskEventDispatcher, CheckpointResponder, TaskManagerRuntimeInfo, TaskMetricGroup, Task) - Constructor for class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
-
- RuntimeEvent - Class in org.apache.flink.runtime.event
-
Subclasses of this event are recognized as events exchanged by the core runtime.
- RuntimeEvent() - Constructor for class org.apache.flink.runtime.event.RuntimeEvent
-
- runtimeUdfContext - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The udf's runtime context.
- Savepoint - Interface in org.apache.flink.runtime.checkpoint.savepoint
-
Savepoints are manually-triggered snapshots from which a program can be
resumed on submission.
- SavepointDisposalHandlers - Class in org.apache.flink.runtime.rest.handler.job.savepoints
-
Handlers to trigger the disposal of a savepoint.
- SavepointDisposalHandlers() - Constructor for class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers
-
- SavepointDisposalHandlers.SavepointDisposalStatusHandler - Class in org.apache.flink.runtime.rest.handler.job.savepoints
-
StatusHandler
implementation for the savepoint disposal operation.
- SavepointDisposalHandlers.SavepointDisposalTriggerHandler - Class in org.apache.flink.runtime.rest.handler.job.savepoints
-
TriggerHandler
implementation for the savepoint disposal operation.
- SavepointDisposalRequest - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
Request body for a savepoint disposal call.
- SavepointDisposalRequest(String) - Constructor for class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalRequest
-
- SavepointDisposalStatusHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalStatusHandler
-
- SavepointDisposalStatusHeaders - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
- SavepointDisposalStatusMessageParameters - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
- SavepointDisposalStatusMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointDisposalStatusMessageParameters
-
- SavepointDisposalTriggerHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointDisposalHandlers.SavepointDisposalTriggerHandler
-
- SavepointDisposalTriggerHeaders - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
- SavepointHandlers - Class in org.apache.flink.runtime.rest.handler.job.savepoints
-
HTTP handlers for asynchronous triggering of savepoints.
- SavepointHandlers(String) - Constructor for class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers
-
- SavepointHandlers.SavepointStatusHandler - Class in org.apache.flink.runtime.rest.handler.job.savepoints
-
HTTP handler to query for the status of the savepoint.
- SavepointHandlers.SavepointTriggerHandler - Class in org.apache.flink.runtime.rest.handler.job.savepoints
-
HTTP handler to trigger savepoints.
- SavepointHandlers.StopWithSavepointHandler - Class in org.apache.flink.runtime.rest.handler.job.savepoints
-
HTTP handler to stop a job with a savepoint.
- SavepointInfo - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
Represents information about a finished savepoint.
- SavepointInfo(String, SerializedThrowable) - Constructor for class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointInfo
-
- 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
-
- SavepointStatusHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointStatusHandler
-
- SavepointStatusHeaders - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
These headers define the protocol for triggering a savepoint.
- SavepointStatusMessageParameters - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
The parameters for triggering a savepoint.
- SavepointStatusMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointStatusMessageParameters
-
- SavepointTriggerHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.SavepointTriggerHandler
-
- SavepointTriggerHeaders - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
These headers define the protocol for triggering a savepoint.
- SavepointTriggerMessageParameters - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
The parameters for triggering a savepoint.
- SavepointTriggerMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerMessageParameters
-
- SavepointTriggerRequestBody - Class in org.apache.flink.runtime.rest.messages.job.savepoints
-
- SavepointTriggerRequestBody(String, boolean) - Constructor for class org.apache.flink.runtime.rest.messages.job.savepoints.SavepointTriggerRequestBody
-
- SavepointV1 - Class in org.apache.flink.runtime.checkpoint.savepoint
-
Savepoint version 0.
- SavepointV1(long, Collection<TaskState>) - Constructor for class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
-
- SavepointV1Serializer - Class in org.apache.flink.runtime.checkpoint.savepoint
-
Deserializer for checkpoints written in format 1
(Flink 1.2.x format)
- SavepointV2 - Class in org.apache.flink.runtime.checkpoint.savepoint
-
The persistent checkpoint metadata, format version 2.
- SavepointV2(long, Collection<TaskState>) - Constructor for class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
-
- SavepointV2(long, Collection<OperatorState>, Collection<MasterState>) - Constructor for class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
-
- SavepointV2Serializer - Class in org.apache.flink.runtime.checkpoint.savepoint
-
(De)serializer for checkpoint metadata format version 2.
- ScalaUtils - Class in org.apache.flink.runtime.util
-
Utilities to convert Scala types into Java types.
- schedule(Runnable, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.akka.ActorSystemScheduledExecutorAdapter
-
- schedule(Callable<V>, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.akka.ActorSystemScheduledExecutorAdapter
-
- schedule(Runnable, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor.DummyComponentMainThreadExecutor
-
- schedule(Callable<V>, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor.DummyComponentMainThreadExecutor
-
- schedule(Runnable, long, TimeUnit) - Method in interface org.apache.flink.runtime.concurrent.ScheduledExecutor
-
Executes the given command after the given delay.
- schedule(Callable<V>, long, TimeUnit) - Method in interface org.apache.flink.runtime.concurrent.ScheduledExecutor
-
Executes the given callable after the given delay.
- schedule(Runnable, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
-
- schedule(Callable<V>, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
-
- schedule(ScheduleMode, Iterable<ExecutionVertex>, ExecutionGraph) - Static method in class org.apache.flink.runtime.executiongraph.SchedulingUtils
-
- schedule(Runnable, long, TimeUnit) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint.MainThreadExecutor
-
- schedule(Callable<V>, long, TimeUnit) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint.MainThreadExecutor
-
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.akka.ActorSystemScheduledExecutorAdapter
-
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor.DummyComponentMainThreadExecutor
-
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface org.apache.flink.runtime.concurrent.ScheduledExecutor
-
Executes the given command periodically.
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
-
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint.MainThreadExecutor
-
- ScheduledExecutor - Interface in org.apache.flink.runtime.concurrent
-
Extension for the
Executor
interface which is enriched by method for scheduling tasks
in the future.
- ScheduledExecutorServiceAdapter - Class in org.apache.flink.runtime.concurrent
-
- ScheduledExecutorServiceAdapter(ScheduledExecutorService) - Constructor for class org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
-
- ScheduledFutureAdapter<V> - Class in org.apache.flink.runtime.concurrent
-
- ScheduledFutureAdapter(Future<V>, long, TimeUnit) - Constructor for class org.apache.flink.runtime.concurrent.ScheduledFutureAdapter
-
- ScheduledUnit - Class in org.apache.flink.runtime.jobmanager.scheduler
-
ScheduledUnit contains the information necessary to allocate a slot for the given
JobVertexID
.
- ScheduledUnit(Execution) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- ScheduledUnit(Execution, SlotSharingGroupId) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- ScheduledUnit(Execution, SlotSharingGroupId, CoLocationConstraint) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- ScheduledUnit(JobVertexID, SlotSharingGroupId, CoLocationConstraint) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- ScheduledUnit(Execution, JobVertexID, SlotSharingGroupId, CoLocationConstraint) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
-
- scheduleEager(Iterable<ExecutionVertex>, ExecutionGraph) - Static method in class org.apache.flink.runtime.executiongraph.SchedulingUtils
-
Schedule vertices eagerly.
- scheduleForExecution() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- scheduleForExecution(SlotProviderStrategy, LocationPreferenceConstraint, Set<AllocationID>) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
NOTE: This method only throws exceptions if it is in an illegal state to be scheduled, or if the tasks needs
to be scheduled immediately and no resource is available.
- scheduleForExecution() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- scheduleForExecution(SlotProviderStrategy, LocationPreferenceConstraint, Set<AllocationID>) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
Schedules the current execution of this ExecutionVertex.
- scheduleLazy(Iterable<ExecutionVertex>, ExecutionGraph) - Static method in class org.apache.flink.runtime.executiongraph.SchedulingUtils
-
Schedule vertices lazy.
- ScheduleMode - Enum in org.apache.flink.runtime.jobgraph
-
The ScheduleMode decides how tasks of an execution graph are started.
- scheduleOrUpdateConsumers(ResultPartitionID) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Schedule or updates consumers of the given result partition.
- scheduleOrUpdateConsumers(ResultPartitionID, Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- scheduleOrUpdateConsumers(ResultPartitionID, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Notifies the JobManager about available data for a produced partition.
- scheduleOrUpdateConsumers(ResultPartitionID) - Method in class org.apache.flink.runtime.scheduler.LegacyScheduler
-
- scheduleOrUpdateConsumers(ResultPartitionID) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
-
- Scheduler - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
- SchedulerFactory - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
- SchedulerImpl - Class in org.apache.flink.runtime.jobmaster.slotpool
-
Scheduler that assigns tasks to slots.
- SchedulerImpl(SlotSelectionStrategy, SlotPool) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl
-
- SchedulerImpl(SlotSelectionStrategy, SlotPool, Map<SlotSharingGroupId, SlotSharingManager>) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl
-
- SchedulerNG - Interface in org.apache.flink.runtime.scheduler
-
Interface for scheduling Flink jobs.
- SchedulerNGFactory - Interface in org.apache.flink.runtime.scheduler
-
- SchedulerOperations - Interface in org.apache.flink.runtime.scheduler
-
- scheduleRunAsync(Runnable, Time) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
-
Execute the runnable in the main thread of the underlying RPC endpoint, with
a delay of the given number of milliseconds.
- scheduleRunAsync(Runnable, long, TimeUnit) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
-
Execute the runnable in the main thread of the underlying RPC endpoint, with
a delay of the given number of milliseconds.
- scheduleRunAsync(Runnable, long) - Method in interface org.apache.flink.runtime.rpc.MainThreadExecutable
-
Execute the runnable in the main thread of the underlying RPC endpoint, with
a delay of the given number of milliseconds.
- scheduleRunAsync(Runnable, long) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint.MainThreadExecutor
-
- scheduleRunAsync(Runnable, Time) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Execute the runnable in the main thread of the underlying RPC endpoint, with
a delay of the given number of milliseconds.
- scheduleRunAsync(Runnable, long, TimeUnit) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Execute the runnable in the main thread of the underlying RPC endpoint, with
a delay of the given number of milliseconds.
- scheduleRunnable(Runnable, long, TimeUnit) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- scheduleRunnable(Runnable, long, TimeUnit) - Method in interface org.apache.flink.runtime.rpc.RpcService
-
Execute the runnable in the execution context of this RPC Service, as returned by
RpcService.getExecutor()
, after a scheduled delay.
- scheduleWithDelay(Runnable, Time, ScheduledExecutor) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Schedule the operation with the given delay.
- scheduleWithDelay(Supplier<T>, Time, ScheduledExecutor) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Schedule the operation with the given delay.
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.akka.ActorSystemScheduledExecutorAdapter
-
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor.DummyComponentMainThreadExecutor
-
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface org.apache.flink.runtime.concurrent.ScheduledExecutor
-
Executed the given command repeatedly with the given delay between the end of an execution
and the start of the next execution.
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
-
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint.MainThreadExecutor
-
- SchedulingExecutionVertex - Interface in org.apache.flink.runtime.scheduler.strategy
-
- SchedulingResultPartition - Interface in org.apache.flink.runtime.scheduler.strategy
-
- SchedulingResultPartition.ResultPartitionState - Enum in org.apache.flink.runtime.scheduler.strategy
-
State of the result partition.
- SchedulingStrategy - Interface in org.apache.flink.runtime.scheduler.strategy
-
Component which encapsulates the scheduling logic.
- SchedulingStrategyFactory - Interface in org.apache.flink.runtime.scheduler.strategy
-
- SchedulingTopology - Interface in org.apache.flink.runtime.scheduler.strategy
-
- SchedulingUtils - Class in org.apache.flink.runtime.executiongraph
-
This class contains scheduling logic for EAGER and LAZY_FROM_SOURCES.
- SchedulingUtils() - Constructor for class org.apache.flink.runtime.executiongraph.SchedulingUtils
-
- scope - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
-
The remaining scope not covered by specific fields.
- SCOPE_HOST - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- SCOPE_INHERIT_PARENT - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
If the scope format starts with this character, then the parent components scope
format will be used as a prefix.
- SCOPE_JOB_ID - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- SCOPE_JOB_NAME - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- SCOPE_OPERATOR_ID - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- SCOPE_OPERATOR_NAME - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- SCOPE_SEPARATOR - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- SCOPE_TASK_ATTEMPT_ID - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- SCOPE_TASK_ATTEMPT_NUM - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- SCOPE_TASK_NAME - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- SCOPE_TASK_SUBTASK_INDEX - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- SCOPE_TASK_VERTEX_ID - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- SCOPE_TASKMANAGER_ID - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- ScopeFormat - Class in org.apache.flink.runtime.metrics.scope
-
This class represents the format after which the "scope" (or namespace) of the various
component metric groups is built.
- ScopeFormat(String, ScopeFormat, String[]) - Constructor for class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- ScopeFormats - Class in org.apache.flink.runtime.metrics.scope
-
A container for component scope formats.
- scopeInfo - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump
-
The scope information for the stored metric.
- secondDam() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
-
- SecureAclProvider() - Constructor for class org.apache.flink.runtime.util.ZooKeeperUtils.SecureAclProvider
-
- SecurityConfiguration - Class in org.apache.flink.runtime.security
-
The global security configuration.
- SecurityConfiguration(Configuration) - Constructor for class org.apache.flink.runtime.security.SecurityConfiguration
-
Create a security configuration from the global configuration.
- SecurityConfiguration(Configuration, List<SecurityModuleFactory>) - Constructor for class org.apache.flink.runtime.security.SecurityConfiguration
-
Create a security configuration from the global configuration.
- SecurityContext - Interface in org.apache.flink.runtime.security
-
A security context with may be required to run a Callable.
- SecurityInstallException(String) - Constructor for exception org.apache.flink.runtime.security.modules.SecurityModule.SecurityInstallException
-
- SecurityInstallException(String, Throwable) - Constructor for exception org.apache.flink.runtime.security.modules.SecurityModule.SecurityInstallException
-
- SecurityModule - Interface in org.apache.flink.runtime.security.modules
-
An installable security module.
- SecurityModule.SecurityInstallException - Exception in org.apache.flink.runtime.security.modules
-
Indicates a problem with installing or uninstalling a security module.
- SecurityModuleFactory - Interface in org.apache.flink.runtime.security.modules
-
- SecurityUtils - Class in org.apache.flink.runtime.security
-
Utils for configuring security.
- seek(long) - Method in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
-
- SeekableFileChannelInputView - Class in org.apache.flink.runtime.io.disk
-
A
DataInputView
that is backed by a
BlockChannelReader
,
making it effectively a data input stream.
- SeekableFileChannelInputView(IOManager, FileIOChannel.ID, MemoryManager, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
-
- seekInput(MemorySegment, int, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
Sets the internal state of the view such that the next bytes will be read from the given memory segment,
starting at the given position.
- seekOutput(MemorySegment, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
Sets the internal state to the given memory segment and the given position within the segment.
- seekTo(long) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileSegmentReader
-
- seekTo(long) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileSegmentReader
-
- seekToPosition(long) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockReader
-
- seekToPosition(long) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileReader
-
- seekToPosition(long) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelReader
-
- seekToPosition(long) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileReader
-
- seekToPosition(long) - Method in class org.apache.flink.runtime.io.disk.iomanager.SynchronousBufferFileReader
-
- segmentSize - Variable in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
- segmentSize - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
The size of the segments used by the hash join buckets.
- select(ExecutionMode, ShipStrategyType, boolean) - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
-
Computes the mode of data exchange to be used for a given execution mode and ship strategy.
- selectAllocationBaseDirectory(int) - Method in interface org.apache.flink.runtime.state.LocalRecoveryDirectoryProvider
-
Returns a specific allocation base directory.
- selectAllocationBaseDirectory(int) - Method in class org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
-
- selectBestSlotForProfile(Collection<SlotSelectionStrategy.SlotInfoAndResources>, SlotProfile) - Method in enum org.apache.flink.runtime.jobmaster.slotpool.LocationPreferenceSlotSelectionStrategy
-
- selectBestSlotForProfile(Collection<SlotSelectionStrategy.SlotInfoAndResources>, SlotProfile) - Method in enum org.apache.flink.runtime.jobmaster.slotpool.PreviousAllocationSlotSelectionStrategy
-
- selectBestSlotForProfile(Collection<SlotSelectionStrategy.SlotInfoAndResources>, SlotProfile) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotSelectionStrategy
-
- selectChannel(T) - Method in interface org.apache.flink.runtime.io.network.api.writer.ChannelSelector
-
Returns the logical channel index, to which the given record should be written.
- selectChannel(T) - Method in class org.apache.flink.runtime.io.network.api.writer.RoundRobinChannelSelector
-
- selectChannel(SerializationDelegate<T>) - Method in class org.apache.flink.runtime.operators.shipping.OutputEmitter
-
- selectSubtaskBaseDirectory(int) - Method in interface org.apache.flink.runtime.state.LocalRecoveryDirectoryProvider
-
Returns a specific subtask base directory.
- selectSubtaskBaseDirectory(int) - Method in class org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
-
- sendErrorResponse(ChannelHandlerContext, HttpRequest, ErrorResponseBody, HttpResponseStatus, Map<String, String>) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerUtils
-
Sends the given error response and status code to the given channel.
- sendErrorResponse(ChannelHandlerContext, boolean, ErrorResponseBody, HttpResponseStatus, Map<String, String>) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerUtils
-
Sends the given error response and status code to the given channel.
- sendNotModified(ChannelHandlerContext) - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
-
Send the "304 Not Modified" response.
- sendReadRequest(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
-
Sends a new read requests, if further requests remain.
- sendRequest(String, int, M) - Method in class org.apache.flink.runtime.rest.RestClient
-
- sendRequest(String, int, M, U, R) - Method in class org.apache.flink.runtime.rest.RestClient
-
- sendRequest(String, int, M, U, R, Collection<FileUpload>) - Method in class org.apache.flink.runtime.rest.RestClient
-
- sendRequest(String, int, M, U, R, Collection<FileUpload>, RestAPIVersion) - Method in class org.apache.flink.runtime.rest.RestClient
-
- sendResponse(ChannelHandlerContext, HttpRequest, P, HttpResponseStatus, Map<String, String>) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerUtils
-
Sends the given response and status code to the given channel.
- sendResponse(ChannelHandlerContext, HttpRequest, String, HttpResponseStatus, Map<String, String>) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerUtils
-
Sends the given response and status code to the given channel.
- sendResponse(ChannelHandlerContext, boolean, String, HttpResponseStatus, Map<String, String>) - Static method in class org.apache.flink.runtime.rest.handler.util.HandlerUtils
-
Sends the given response and status code to the given channel.
- sendScheduleOrUpdateConsumerMessage() - Method in class org.apache.flink.runtime.scheduler.DeploymentOption
-
- sendScheduleOrUpdateConsumersMessage() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
-
- sendSlotReport(ResourceID, InstanceID, SlotReport, Time) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- sendSlotReport(ResourceID, InstanceID, SlotReport, Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
-
Sends the given
SlotReport
to the ResourceManager.
- sendTaskEvent(TaskEvent) - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
-
- sendTaskEvent(TaskEvent) - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
-
- sendTaskEvent(ResultPartitionID, TaskEvent, RemoteInputChannel) - Method in class org.apache.flink.runtime.io.network.netty.NettyPartitionRequestClient
-
Sends a task event backwards to an intermediate result partition producer.
- sendTaskEvent(TaskEvent) - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
- sendTaskEvent(TaskEvent) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- sendTaskEvent(TaskEvent) - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
-
- sendTaskEvent(ResultPartitionID, TaskEvent, RemoteInputChannel) - Method in interface org.apache.flink.runtime.io.network.PartitionRequestClient
-
Sends a task event backwards to an intermediate result partition.
- sendTaskEvent(TaskEvent) - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
-
- SerializationDelegate<T> - Class in org.apache.flink.runtime.plugable
-
The serialization delegate exposes an arbitrary element as a IOReadableWritable
for
serialization, with the help of a type serializer.
- SerializationDelegate(TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.plugable.SerializationDelegate
-
- serialize(T, DataOutputStream) - Method in interface org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializer
-
Serializes a savepoint to an output stream.
- serialize(SavepointV2, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
-
- serialize(SavepointV2, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2Serializer
-
- serialize(JobDetails, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails.JobDetailsSerializer
-
- serialize(Map<Counter, Tuple2<QueryScopeInfo, String>>, Map<Gauge<?>, Tuple2<QueryScopeInfo, String>>, Map<Histogram, Tuple2<QueryScopeInfo, String>>, Map<Meter, Tuple2<QueryScopeInfo, String>>) - Method in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricDumpSerializer
-
Serializes the given metrics and returns the resulting byte array.
- serialize(CheckpointConfigInfo.ProcessingMode, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingModeSerializer
-
- serialize(AggregatedMetricsResponseBody, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetricsResponseBody.Serializer
-
- serialize(MetricCollectionResponseBody, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.MetricCollectionResponseBody.Serializer
-
- serialize(JobConfigInfo, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.JobConfigInfo.Serializer
-
- serialize(JobPlanInfo.RawJson, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson.Serializer
-
- serialize(JobID, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.JobIDSerializer
-
- serialize(JobResult, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.JobResultSerializer
-
- serialize(JobVertexID, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.JobVertexIDKeySerializer
-
- serialize(JobVertexID, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.JobVertexIDSerializer
-
- serialize(ResourceID, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.ResourceIDSerializer
-
- serialize(SerializedThrowable, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.SerializedThrowableSerializer
-
- serialize(SerializedValue<?>, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.SerializedValueSerializer
-
- serialize(TriggerId, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.TriggerId.TriggerIdSerializer
-
- serialize(ArrayList<T>, DataOutputView) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- serialize(VoidNamespace, DataOutputView) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- serializeAndTryOffload(T, JobID, BlobWriter) - Static method in interface org.apache.flink.runtime.blob.BlobWriter
-
Serializes the given value and offloads it to the BlobServer if its size exceeds the minimum
offloading size of the BlobServer.
- serializedCounters - Variable in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
-
- serializedGauges - Variable in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
-
- serializedHistograms - Variable in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
-
- SerializedInputSplit - Class in org.apache.flink.runtime.jobmaster
-
- SerializedInputSplit(byte[]) - Constructor for class org.apache.flink.runtime.jobmaster.SerializedInputSplit
-
- SerializedJobExecutionResult - Class in org.apache.flink.runtime.client
-
A variant of the JobExecutionResult
that holds
its accumulator data in serialized form.
- SerializedJobExecutionResult(JobID, long, Map<String, SerializedValue<OptionalFailure<Object>>>) - Constructor for class org.apache.flink.runtime.client.SerializedJobExecutionResult
-
Creates a new SerializedJobExecutionResult.
- serializedMeters - Variable in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
-
- serializedThrowable(SerializedThrowable) - Method in class org.apache.flink.runtime.jobmaster.JobResult.Builder
-
- SerializedThrowableDeserializer - Class in org.apache.flink.runtime.rest.messages.json
-
JSON deserializer for SerializedThrowable
.
- SerializedThrowableDeserializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.SerializedThrowableDeserializer
-
- SerializedThrowableSerializer - Class in org.apache.flink.runtime.rest.messages.json
-
JSON serializer for SerializedThrowable
.
- SerializedThrowableSerializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.SerializedThrowableSerializer
-
- SerializedUpdateBuffer - Class in org.apache.flink.runtime.iterative.io
-
- SerializedUpdateBuffer() - Constructor for class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
-
- SerializedUpdateBuffer(List<MemorySegment>, int, IOManager) - Constructor for class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
-
- serializedValue - Variable in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.NonOffloaded
-
The serialized value.
- SerializedValueDeserializer - Class in org.apache.flink.runtime.rest.messages.json
-
JSON deserializer for SerializedValue
.
- SerializedValueDeserializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.SerializedValueDeserializer
-
- SerializedValueDeserializer(JavaType) - Constructor for class org.apache.flink.runtime.rest.messages.json.SerializedValueDeserializer
-
- serializedValueKey - Variable in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor.Offloaded
-
The key of the offloaded value BLOB.
- SerializedValueSerializer - Class in org.apache.flink.runtime.rest.messages.json
-
JSON serializer for SerializedValue
.
- SerializedValueSerializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.SerializedValueSerializer
-
- SerializedValueSerializer(JavaType) - Constructor for class org.apache.flink.runtime.rest.messages.json.SerializedValueSerializer
-
- serializeKeyedStateHandle(KeyedStateHandle, DataOutputStream) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
-
- serializeKeyedStateHandle(KeyedStateHandle, DataOutputStream) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2Serializer
-
- serializeOld(SavepointV1, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
-
- serializeOperatorStateHandle(OperatorStateHandle, DataOutputStream) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
-
- serializeOperatorStateHandle(OperatorStateHandle, DataOutputStream) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2Serializer
-
- serializer - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
-
- serializer - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
-
- serializer - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
-
- Serializer() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetricsResponseBody.Serializer
-
- Serializer() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.MetricCollectionResponseBody.Serializer
-
- Serializer() - Constructor for class org.apache.flink.runtime.rest.messages.JobConfigInfo.Serializer
-
- Serializer() - Constructor for class org.apache.flink.runtime.rest.messages.JobPlanInfo.RawJson.Serializer
-
- serializer1 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- serializer2 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- serializeRecord(T) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
-
Starts serializing the given record to an intermediate data buffer.
- serializeRecord(T) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
-
Serializes the complete record to an intermediate data serialization buffer.
- serializeStreamStateHandle(StreamStateHandle, DataOutputStream) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
-
- serializeStreamStateHandle(StreamStateHandle, DataOutputStream) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2Serializer
-
- serverAddress - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
-
- ServicesThreadFactory - Class in org.apache.flink.runtime.highavailability
-
- ServicesThreadFactory() - Constructor for class org.apache.flink.runtime.highavailability.ServicesThreadFactory
-
- SessionClusterEntrypoint - Class in org.apache.flink.runtime.entrypoint
-
Base class for session cluster entry points.
- SessionClusterEntrypoint(Configuration) - Constructor for class org.apache.flink.runtime.entrypoint.SessionClusterEntrypoint
-
- SessionDispatcherFactory - Enum in org.apache.flink.runtime.dispatcher
-
- SessionDispatcherResourceManagerComponentFactory - Class in org.apache.flink.runtime.entrypoint.component
-
- SessionDispatcherResourceManagerComponentFactory(ResourceManagerFactory<?>) - Constructor for class org.apache.flink.runtime.entrypoint.component.SessionDispatcherResourceManagerComponentFactory
-
- SessionDispatcherResourceManagerComponentFactory(DispatcherFactory<Dispatcher>, ResourceManagerFactory<?>) - Constructor for class org.apache.flink.runtime.entrypoint.component.SessionDispatcherResourceManagerComponentFactory
-
- SessionRestEndpointFactory - Enum in org.apache.flink.runtime.rest
-
- set(int) - Method in class org.apache.flink.runtime.operators.util.BitSet
-
Sets the bit at specified index.
- set(int, T) - Method in class org.apache.flink.runtime.util.EvictingBoundedList
-
- set(E) - Method in class org.apache.flink.runtime.util.SingleElementIterator
-
Resets the element.
- setAccumulators(Map<String, Accumulator<?, ?>>) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Update accumulators (discarded when the Execution has already been terminated).
- setAlignmentDurationNanos(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- setAllocator(ByteBufAllocator) - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Sets the buffer allocator for use in netty.
- setAllocator(ByteBufAllocator) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- setAllocator(ByteBufAllocator) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- setAllowQueuedScheduling(boolean) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- setAsyncDurationMillis(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- setBitsLocation(MemorySegment, int) - Method in class org.apache.flink.runtime.operators.util.BloomFilter
-
- setBlobServerAddress(InetSocketAddress) - Method in class org.apache.flink.runtime.blob.AbstractBlobCache
-
- setBlobServerAddress(InetSocketAddress) - Method in class org.apache.flink.runtime.blob.BlobCacheService
-
- setBroadcastGateIterativeWithNumberOfEventsUntilInterrupt(int, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setBroadcastInputName(String, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setBroadcastInputSerializer(TypeSerializerFactory<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setBroadcastVariable(String, BroadcastVariableMaterialization<?, ?>) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
-
- setBufferPool(BufferPool) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- setBytes(int, ByteBuf, int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- setBytes(int, byte[], int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- setBytes(int, ByteBuffer) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- setBytes(int, InputStream, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- setBytes(int, ScatteringByteChannel, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- setBytes(int, FileChannel, long, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- setBytesBufferedInAlignment(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- setCachable(boolean) - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
-
- setCancellerHandle(ScheduledFuture<?>) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
-
Sets the handle for the canceller to this pending checkpoint.
- setChannelIndex(int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
-
- setChannelSelector(ChannelSelector) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriterBuilder
-
- setCheckpointStatsTracker(CheckpointStatsTracker) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
Sets the checkpoint stats tracker.
- setClasspaths(List<URL>) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Sets the classpaths required to run the job on a task manager.
- setCommonBindAddress(String) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
-
- setConfigDir(String) - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- setConfigDir(String) - Method in class org.apache.flink.runtime.taskmanager.TaskManagerCliOptions
-
- setConfiguration(Configuration) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
-
- setContentTypeHeader(HttpResponse, File) - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
-
Sets the content type header for the HTTP Response.
- setConvergenceCriterion(String, ConvergenceCriterion<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setCount(long) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
-
Sets the current checkpoint ID.
- setCount(long) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
-
- setCount(long) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
-
- setCurrentKey(K) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- setCurrentKey(K) - Method in interface org.apache.flink.runtime.state.heap.InternalKeyContext
-
Set current key of the context.
- setCurrentKey(K) - Method in class org.apache.flink.runtime.state.heap.InternalKeyContextImpl
-
- setCurrentKey(K) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
-
Sets the current key that is used for partitioned state.
- setCurrentKeyGroupIndex(int) - Method in interface org.apache.flink.runtime.state.heap.InternalKeyContext
-
Set current key group index of the context.
- setCurrentKeyGroupIndex(int) - Method in class org.apache.flink.runtime.state.heap.InternalKeyContextImpl
-
- setCurrentNamespace(N) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
- setCurrentNamespace(N) - Method in interface org.apache.flink.runtime.state.internal.InternalKvState
-
Sets the current namespace, which will be used when using the state access methods.
- setDateAndCacheHeaders(HttpResponse, File) - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
-
Sets the "date" and "cache" headers for the HTTP Response.
- setDateHeader(FullHttpResponse) - Static method in class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
-
Sets the "date" header for the HTTP response.
- setDest(Path) - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
-
- setDriver(Class<? extends Driver>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setDriverComparator(TypeComparatorFactory<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setDriverPairComparator(TypePairComparatorFactory<?, ?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setDriverStrategy(DriverStrategy) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setEndOffsetExclusive(long) - Method in class org.apache.flink.runtime.state.BoundedInputStream
-
- setError(Throwable) - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
-
Atomically sets an error for this channel and notifies the input gate about available data to
trigger querying this channel by the task thread.
- setExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.flink.runtime.util.ExecutorThreadFactory.Builder
-
- setExecutable(boolean) - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
-
- setExecutionConfig(ExecutionConfig) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Sets the execution config.
- setExtract(boolean) - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
-
- setFailUnfulfillableRequest(boolean) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
Set
SlotManager
whether to fail unfulfillable slot requests.
- setFailUnfulfillableRequest(boolean) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
- setFailUnfulfillableRequest(boolean) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
- setFailWhenLegacyStateDetected(boolean) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializers
-
This is only visible as a temporary solution to keep the stateful job migration it cases working from binary
savepoints that still contain legacy state (<= Flink 1.1).
- setFencingToken(F) - Method in class org.apache.flink.runtime.rpc.FencedRpcEndpoint
-
- setField(TtlValue<T>, int, Object) - Method in class org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
-
- setFilehandlesDriver(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setFilehandlesInput(int, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setFormatDescription(OperatorID, String) - Method in class org.apache.flink.runtime.jobgraph.InputOutputFormatVertex
-
- setFurtherPatitioning(boolean) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- setGateIterativeWithNumberOfEventsUntilInterrupt(int, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setHost(String) - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- setImplicitConvergenceCriterion(String, ConvergenceCriterion<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
Sets the default convergence criterion of a DeltaIteration
- setInitialState(JobManagerTaskRestore) - Method in class org.apache.flink.runtime.executiongraph.Execution
-
Sets the initial state for the execution.
- setInputAsynchronouslyMaterialized(int, boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setInputCached(int, boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setInputChannel(IntermediateResultPartitionID, InputChannel) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- setInputComparator(TypeComparatorFactory<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setInputDependencyConstraint(InputDependencyConstraint) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- 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
-
- setInternalIndex(int) - Method in interface org.apache.flink.runtime.state.heap.HeapPriorityQueueElement
-
- setInvokableClass(Class<? extends AbstractInvokable>) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- setIsCompacted(boolean) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
sets compaction status (should only be set true
directly after compaction and false
when garbage was created)
- setIsSolutionSetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setIsSolutionSetUpdateWithoutReprobe() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setIsWorksetIteration() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setIsWorksetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setIterationHeadFinalOutputConfig(TaskConfig) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setIterationHeadIndexOfSyncOutput(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setIterationHeadPartialSolutionOrWorksetInputIndex(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setIterationHeadSolutionSetInputIndex(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setIterationId(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setIterativeReader() - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
-
- setIterativeReader() - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
-
- setJobFinished(JobID) - Method in class org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
-
- setJobFinished(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
-
- setJobFinished(JobID) - Method in interface org.apache.flink.runtime.highavailability.RunningJobsRegistry
-
Marks a job as completed.
- setJobFinished(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperRunningJobsRegistry
-
- setJobManagerMode(String) - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
-
- setJobRunning(JobID) - Method in class org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
-
- setJobRunning(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
-
- setJobRunning(JobID) - Method in interface org.apache.flink.runtime.highavailability.RunningJobsRegistry
-
Marks a job as running.
- setJobRunning(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperRunningJobsRegistry
-
- setJsonPlan(String) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- setKeyGroupOffset(int, long) - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
-
Sets the offset for the given key-group.
- setLastOutputCollector(Collector<OT>) - Method in class org.apache.flink.runtime.operators.BatchTask
-
Sets the last output
Collector
of the collector chain of this
BatchTask
.
- setLocality(Locality) - Method in class org.apache.flink.runtime.instance.SimpleSlot
-
Attached locality information to this slot.
- setMainThreadExecutor(ComponentMainThreadExecutor) - Method in class org.apache.flink.runtime.scheduler.LegacyScheduler
-
- setMainThreadExecutor(ComponentMainThreadExecutor) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
-
- 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
-
- setMetaInfo(RegisteredKeyValueStateBackendMetaInfo<N, S>) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- setMetricGroup(TaskIOMetricGroup) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
-
Sets the metric group for this RecordWriter.
- setMoreAvailable(boolean) - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
-
- setMutableObjectMode(boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setName(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Sets the name of the vertex
- setNextBuffer(Buffer) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
-
- setNextBuffer(Buffer) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
-
- setNumberOfIterations(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setNumBuffers(int) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
-
Sets the current size of this buffer pool.
- setNumSlotsPerTaskManager(int) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
-
- setNumTaskManagers(int) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
-
- setOperatorDescription(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- setOperatorLevelCachingDescription(String) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Sets the operator-level caching description for this input.
- setOperatorName(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- setOperatorPrettyName(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- setOutputCollector(Collector<?>) - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
-
- setOutputComparator(TypeComparatorFactory<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setOutputDataDistribution(DataDistribution, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setOutputPartitioner(Partitioner<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setOutputSerializer(TypeSerializerFactory<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setParallelism(int) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Sets the parallelism for the task.
- setPartition(int, IntermediateResultPartition) - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
-
- setPartitionNumber(int) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
-
overwrites partition number and should only be used on compaction partition
- setPoolName(String) - Method in class org.apache.flink.runtime.util.ExecutorThreadFactory.Builder
-
- setPreProcessingOperationName(String) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Sets the name of the pre-processing operation for this input.
- setPreviousSerializerSnapshotForRestoredState(TypeSerializerSnapshot<T>) - Method in class org.apache.flink.runtime.state.StateSerializerProvider
-
For restored state, set the state's previous serializer's snapshot.
- 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
-
- setReaderIndex(int) - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Sets the reader index of this buffer.
- setReaderIndex(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- setReaderIndex(int) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- setReadPosition(long) - Method in class org.apache.flink.runtime.io.disk.RandomAccessInputView
-
- setReadPosition(long) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
- setRegisteredAsAvailable(boolean) - Method in interface org.apache.flink.runtime.io.network.NetworkSequenceViewReader
-
Updates the value to indicate whether the reader is enqueued in the pipeline or not.
- setRelativeBackChannelMemory(double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setRelativeInputMaterializationMemory(int, double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setRelativeMemoryDriver(double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setRelativeMemoryInput(int, double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setRelativeSolutionSetMemory(double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setRequestFuture(CompletableFuture<Acknowledge>) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
-
- setResources(ResourceSpec, ResourceSpec) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Sets the minimum and preferred resources for the task.
- setResultIterator(MutableObjectIterator<E>) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
Sets the result iterator.
- setResultIteratorException(IOException) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
Reports an exception to all threads that are waiting for the result iterator.
- setResultOptimizerProperties(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
- setRpcServiceSharing(RpcServiceSharing) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration.Builder
-
- setSavepointRestoreSettings(SavepointRestoreSettings) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Sets the savepoint restore settings.
- setScheduleMode(ScheduleMode) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- setSessionTimeout(long) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Sets the timeout of the session in seconds.
- setSharedSlot(SharedSlot) - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
-
Assigns a new shared slot to this co-location constraint.
- setShipStrategyName(String) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
-
Sets the name of the ship strategy for the represented input.
- setShouldInterruptOnCancel(boolean) - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
- setSize(int) - Method in interface org.apache.flink.runtime.io.network.buffer.Buffer
-
Sets the size of the written data, i.e.
- setSize(int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBuffer
-
- setSize(int) - Method in class org.apache.flink.runtime.io.network.buffer.ReadOnlySlicedNetworkBuffer
-
- setSlotAvailabilityListener(SlotAvailabilityListener) - Method in class org.apache.flink.runtime.instance.Instance
-
Sets the listener that receives notifications for slot availability.
- setSlotRequestId(SlotRequestId) - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
-
Sets the slot request id of the currently assigned slot to the co-location constraint.
- setSlotSharingGroup(SlotSharingGroup) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Associates this vertex with a slot sharing group for scheduling.
- setSnapshotSettings(JobCheckpointingSettings) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
Sets the settings for asynchronous snapshots.
- setSolutionSetComparator(TypeComparatorFactory<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setSolutionSetSerializer(TypeSerializerFactory<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setSolutionSetUnmanaged(boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setSource(Path) - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
-
- setSpillingThresholdDriver(float) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setSpillingThresholdInput(int, float) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setState(S, int) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap.StateMapEntry
-
- setStateMetaInfo(RegisteredBroadcastStateBackendMetaInfo<K, V>) - Method in interface org.apache.flink.runtime.state.BackendWritableBroadcastState
-
- setStateMetaInfo(RegisteredBroadcastStateBackendMetaInfo<K, V>) - Method in class org.apache.flink.runtime.state.HeapBroadcastState
-
- setStateMetaInfo(RegisteredOperatorStateBackendMetaInfo<S>) - Method in class org.apache.flink.runtime.state.PartitionableListState
-
- setStrictlyCoLocatedWith(JobVertex) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
-
Tells this vertex to strictly co locate its subtasks with the subtasks of the given vertex.
- setStubParameter(String, String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setStubParameters(Configuration) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setStubWrapper(UserCodeWrapper<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setSyncDurationMillis(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
-
- SettableLeaderRetrievalService - Class in org.apache.flink.runtime.leaderretrieval
-
- SettableLeaderRetrievalService() - Constructor for class org.apache.flink.runtime.leaderretrieval.SettableLeaderRetrievalService
-
- SettableLeaderRetrievalService(String, UUID) - Constructor for class org.apache.flink.runtime.leaderretrieval.SettableLeaderRetrievalService
-
- setTaskName(String) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriterBuilder
-
- setTaskName(String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setThreadPriority(int) - Method in class org.apache.flink.runtime.util.ExecutorThreadFactory.Builder
-
- setTimeout(long) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriterBuilder
-
- setUdfConfiguration(Configuration) - Method in class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger
-
- setup(int) - Method in interface org.apache.flink.runtime.io.network.api.writer.ChannelSelector
-
Initializes the channel selector with the number of output channels.
- setup() - Method in interface org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
-
Setup partition, potentially heavy-weight, blocking operation comparing to just creation.
- setup(int) - Method in class org.apache.flink.runtime.io.network.api.writer.RoundRobinChannelSelector
-
- setup() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputGate
-
Setup gate, potentially heavy-weight, blocking operation comparing to just creation.
- setup() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- setup() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
-
- setup() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
Registers a buffer pool with this result partition.
- setup() - Method in class org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrier
-
- setup() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
-
Setup the barrier, has to be called at the beginning of each superstep.
- setup(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(int) - Method in class org.apache.flink.runtime.operators.shipping.OutputEmitter
-
- setup(TaskContext<Function, T>) - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
-
- setup() - Method in class org.apache.flink.runtime.taskmanager.ConsumableNotifyingResultPartitionWriterDecorator
-
- setup() - Method in class org.apache.flink.runtime.taskmanager.InputGateWithMetrics
-
- setupPartitionsAndGates(ResultPartitionWriter[], InputGate[]) - Static method in class org.apache.flink.runtime.taskmanager.Task
-
- setUseLargeRecordHandler(boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
-
- setUserArtifactBlobKey(String, PermanentBlobKey) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
-
- 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
-
- setWritePosition(long) - Method in class org.apache.flink.runtime.io.disk.RandomAccessOutputView
-
- SharedSlot - Class in org.apache.flink.runtime.instance
-
This class represents a shared slot.
- SharedSlot(SlotOwner, TaskManagerLocation, int, TaskManagerGateway, SlotSharingGroupAssignment) - Constructor for class org.apache.flink.runtime.instance.SharedSlot
-
Creates a new shared slot that has no parent (is a root slot) and does not belong to any task group.
- SharedSlot(SlotOwner, TaskManagerLocation, int, TaskManagerGateway, SlotSharingGroupAssignment, SharedSlot, AbstractID) - Constructor for class org.apache.flink.runtime.instance.SharedSlot
-
Creates a new shared slot that has is a sub-slot of the given parent shared slot, and that belongs
to the given task group.
- SharedSlot(SlotContext, SlotOwner, SlotSharingGroupAssignment) - Constructor for class org.apache.flink.runtime.instance.SharedSlot
-
Creates a new shared slot that has no parent (is a root slot) and does not belong to any task group.
- SharedStateRegistry - Class in org.apache.flink.runtime.state
-
This registry manages state that is shared across (incremental) checkpoints, and is responsible
for deleting shared state that is no longer used in any valid checkpoint.
- SharedStateRegistry() - Constructor for class org.apache.flink.runtime.state.SharedStateRegistry
-
Default uses direct executor to delete unreferenced state
- SharedStateRegistry(Executor) - Constructor for class org.apache.flink.runtime.state.SharedStateRegistry
-
- SharedStateRegistry.Result - Class in org.apache.flink.runtime.state
-
The result of an attempt to (un)/reference state
- SharedStateRegistryFactory - Interface in org.apache.flink.runtime.state
-
- SharedStateRegistryKey - Class in org.apache.flink.runtime.state
-
This class represents a key that uniquely identifies (on a logical level) state handles for
registration in the
SharedStateRegistry
.
- SharedStateRegistryKey(String, StateHandleID) - Constructor for class org.apache.flink.runtime.state.SharedStateRegistryKey
-
- SharedStateRegistryKey(String) - Constructor for class org.apache.flink.runtime.state.SharedStateRegistryKey
-
- ShipStrategyType - Enum in org.apache.flink.runtime.operators.shipping
-
Enumeration defining the different shipping types of the output, such as local forward, re-partitioning by hash,
or re-partitioning by range.
- shouldDrain() - Method in class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointRequestBody
-
- shouldExitJvmOnOutOfMemoryError() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
-
- shouldExitJvmOnOutOfMemoryError() - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
-
Checks whether the TaskManager should exit the JVM when the task thread throws
an OutOfMemoryError.
- shouldIncludeFinished() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
-
- shouldIncludeRunning() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
-
- shouldInterruptOnCancel() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
-
Checks whether the task should be interrupted during cancellation.
- SHUFFLE_SERVICE_FACTORY_CLASS - Static variable in class org.apache.flink.runtime.shuffle.ShuffleServiceOptions
-
The full class name of the shuffle service factory implementation to be used by the cluster.
- ShuffleDescriptor - Interface in org.apache.flink.runtime.shuffle
-
Interface for shuffle deployment descriptor of result partition resource.
- ShuffleEnvironment<P extends ResultPartitionWriter,G extends InputGate> - Interface in org.apache.flink.runtime.shuffle
-
Interface for the implementation of shuffle service local environment.
- ShuffleEnvironmentContext - Class in org.apache.flink.runtime.shuffle
-
- ShuffleEnvironmentContext(Configuration, ResourceID, long, boolean, InetAddress, TaskEventPublisher, MetricGroup) - Constructor for class org.apache.flink.runtime.shuffle.ShuffleEnvironmentContext
-
- ShuffleIOOwnerContext - Class in org.apache.flink.runtime.shuffle
-
Context of shuffle input/output owner used to create partitions or gates belonging to the owner.
- ShuffleIOOwnerContext(String, ExecutionAttemptID, MetricGroup, MetricGroup, MetricGroup) - Constructor for class org.apache.flink.runtime.shuffle.ShuffleIOOwnerContext
-
- ShuffleMaster<T extends ShuffleDescriptor> - Interface in org.apache.flink.runtime.shuffle
-
Intermediate result partition registry to use in
JobMaster
.
- ShuffleServiceFactory<SD extends ShuffleDescriptor,P extends ResultPartitionWriter,G extends InputGate> - Interface in org.apache.flink.runtime.shuffle
-
Interface for shuffle service factory implementations.
- ShuffleServiceLoader - Enum in org.apache.flink.runtime.shuffle
-
- ShuffleServiceOptions - Class in org.apache.flink.runtime.shuffle
-
Options to configure shuffle service.
- ShuffleUtils - Class in org.apache.flink.runtime.shuffle
-
Common utility methods for shuffle service.
- shutdown(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 interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
-
Shutdown method which may release created class loaders.
- shutdown() - Method in class org.apache.flink.runtime.filecache.FileCache
-
Shuts down the file cache by cancelling all.
- shutdown() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
-
Shuts down this leader election service.
- shutdown() - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
-
- shutdown() - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
-
- shutdown() - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
-
- shutdown() - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
-
- shutdown() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
-
- shutdown() - Method in class org.apache.flink.runtime.jobmaster.JobManagerSharedServices
-
- shutdown() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Shuts the memory manager down, trying to release all the memory it managed.
- shutdown() - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
Shuts down this registry and the associated MetricReporter
.
- shutdown() - Method in class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
-
- shutdown() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
-
Forces an immediate shutdown of the thread.
- shutdown() - Method in interface org.apache.flink.runtime.query.KvStateServer
-
Shuts down the server and all related thread pools.
- shutDown() - Method in interface org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTracker
-
Shuts the BackPressureStatsTracker down.
- shutDown() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.BackPressureStatsTrackerImpl
-
Shuts down the stats tracker.
- shutDown() - Method in class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator
-
Shuts down the coordinator.
- shutdown(Time) - Method in class org.apache.flink.runtime.rest.RestClient
-
- shutdown() - Method in class org.apache.flink.runtime.state.TaskExecutorLocalStateStoresManager
-
- shutdown() - Method in class org.apache.flink.runtime.taskexecutor.KvStateService
-
- shutDown() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
-
- shutdown() - Method in class org.apache.flink.runtime.taskmanager.MemoryLogger
-
- shutDownCluster() - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- shutDownCluster() - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
- ShutdownHandler - Class in org.apache.flink.runtime.rest.handler.cluster
-
REST handler which allows to shut down the cluster.
- ShutdownHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, EmptyResponseBody, EmptyMessageParameters>) - Constructor for class org.apache.flink.runtime.rest.handler.cluster.ShutdownHandler
-
- ShutdownHeaders - Class in org.apache.flink.runtime.rest.messages.cluster
-
- ShutdownHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.cluster.ShutdownHeaders
-
- shutdownHook - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
-
Shutdown hook thread to ensure deletion of the local storage directory.
- shutDownInternal() - Method in class org.apache.flink.runtime.dispatcher.DispatcherRestEndpoint
-
- shutDownInternal() - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
-
Stops this REST server endpoint.
- shutDownInternal() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
-
- shutdownRequested - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
-
- SignalHandler - Class in org.apache.flink.runtime.util
-
This signal handler / signal logger is based on Apache Hadoop's org.apache.hadoop.util.SignalLogger.
- SignalHandler() - Constructor for class org.apache.flink.runtime.util.SignalHandler
-
- signalTermination() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
-
- SimpleCloseableInputProvider<E> - Class in org.apache.flink.runtime.operators.util
-
A simple iterator provider that returns a supplied iterator and does nothing when closed.
- SimpleCloseableInputProvider(MutableObjectIterator<E>) - Constructor for class org.apache.flink.runtime.operators.util.SimpleCloseableInputProvider
-
Creates a new simple input provider that will return the given iterator.
- SimpleCollectingOutputView - Class in org.apache.flink.runtime.io.disk
-
The list with the full segments contains at any point all completely full segments, plus the segment that is
currently filled.
- SimpleCollectingOutputView(List<MemorySegment>, MemorySegmentSource, int) - Constructor for class org.apache.flink.runtime.io.disk.SimpleCollectingOutputView
-
- SimpleIterable(IN, MutableObjectIterator<IN>) - Constructor for class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable
-
- SimpleIterator(IN, MutableObjectIterator<IN>) - Constructor for class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable.SimpleIterator
-
- SimpleSlot - Class in org.apache.flink.runtime.instance
-
A SimpleSlot represents a single slot on a TaskManager instance, or a slot within a shared slot.
- SimpleSlot(SlotOwner, TaskManagerLocation, int, TaskManagerGateway) - Constructor for class org.apache.flink.runtime.instance.SimpleSlot
-
Creates a new simple slot that stands alone and does not belong to shared slot.
- SimpleSlot(SlotOwner, TaskManagerLocation, int, TaskManagerGateway, SharedSlot, AbstractID) - Constructor for class org.apache.flink.runtime.instance.SimpleSlot
-
Creates a new simple slot that belongs to the given shared slot and
is identified by the given ID.
- SimpleSlot(SlotContext, SlotOwner, int) - Constructor for class org.apache.flink.runtime.instance.SimpleSlot
-
Creates a new simple slot that stands alone and does not belong to shared slot.
- SimpleSlot(SharedSlot, SlotOwner, int, AbstractID) - Constructor for class org.apache.flink.runtime.instance.SimpleSlot
-
Creates a new simple slot that belongs to the given shared slot and
is identified by the given ID..
- SimpleSlotContext - Class in org.apache.flink.runtime.instance
-
Simple implementation of the
SlotContext
interface for the legacy code.
- SimpleSlotContext(AllocationID, TaskManagerLocation, int, TaskManagerGateway) - Constructor for class org.apache.flink.runtime.instance.SimpleSlotContext
-
- SimpleSlotContext(AllocationID, TaskManagerLocation, int, TaskManagerGateway, ResourceProfile) - Constructor for class org.apache.flink.runtime.instance.SimpleSlotContext
-
- SimpleStateEntry(K, N, S) - Constructor for class org.apache.flink.runtime.state.StateEntry.SimpleStateEntry
-
- 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, IntermediateDataSetID, ResultPartitionType, int, int, PartitionProducerStateProvider, boolean, SupplierWithException<BufferPool, IOException>) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
-
- SingleInputGateFactory - Class in org.apache.flink.runtime.io.network.partition.consumer
-
- SingleInputGateFactory(ResourceID, NettyShuffleEnvironmentConfiguration, ConnectionManager, ResultPartitionManager, TaskEventPublisher, NetworkBufferPool) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGateFactory
-
- SingleJobSubmittedJobGraphStore - Class in org.apache.flink.runtime.dispatcher
-
- SingleJobSubmittedJobGraphStore(JobGraph) - Constructor for class org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
-
- SingleLeaderElectionService - Class in org.apache.flink.runtime.highavailability.nonha.leaderelection
-
- SingleLeaderElectionService(Executor, UUID) - Constructor for class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
-
Creates a new leader election service.
- SingleLogicalSlot - Class in org.apache.flink.runtime.jobmaster.slotpool
-
- SingleLogicalSlot(SlotRequestId, SlotContext, SlotSharingGroupId, Locality, SlotOwner) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.SingleLogicalSlot
-
- singleton(T) - Static method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- SIZE - Static variable in class org.apache.flink.runtime.blob.BlobKey
-
Size of the internal BLOB key in bytes.
- size() - Method in class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
- size() - Method in interface org.apache.flink.runtime.dispatcher.ArchivedExecutionGraphStore
-
- size() - Method in class org.apache.flink.runtime.dispatcher.FileArchivedExecutionGraphStore
-
- size() - Method in class org.apache.flink.runtime.dispatcher.MemoryArchivedExecutionGraphStore
-
- size() - Method in class org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
-
- size() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
-
- size() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyLinkedMap
-
- size() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl.AvailableSlots
-
- size() - Method in class org.apache.flink.runtime.metrics.DescriptiveStatisticsHistogramStatistics
-
- size() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- size() - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
-
Gets the number of elements in the sortable.
- size() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- size() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
-
Returns the number of elements currently stored in the PriorityQueue.
- size() - Method in class org.apache.flink.runtime.rest.handler.legacy.ExecutionGraphCache
-
Gets the number of cache entries.
- size() - Method in class org.apache.flink.runtime.rest.handler.router.Router
-
Returns the number of routes in this router.
- size - Variable in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
-
The current size of the priority queue.
- size() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapPriorityQueue
-
- size() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
- size() - Method in class org.apache.flink.runtime.state.heap.KeyGroupPartitionedPriorityQueue
-
- size() - Method in class org.apache.flink.runtime.state.heap.NestedStateMap
-
- size() - Method in class org.apache.flink.runtime.state.heap.StateMap
-
Returns the total number of entries in this
StateMap
.
- size() - Method in class org.apache.flink.runtime.state.heap.StateTable
-
Returns the total number of entries in this
StateTable
.
- size() - Method in interface org.apache.flink.runtime.state.InternalPriorityQueue
-
Returns the number of elements in this set.
- size() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
-
- size() - Method in class org.apache.flink.runtime.util.IntArrayList
-
- size() - Method in class org.apache.flink.runtime.util.LongArrayList
-
- sizeOfNamespace(Object) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
- sizeOfNamespace(Object) - Method in class org.apache.flink.runtime.state.heap.NestedStateMap
-
- sizeOfNamespace(Object) - Method in class org.apache.flink.runtime.state.heap.StateMap
-
- sizeOfNamespace(Object) - Method in class org.apache.flink.runtime.state.heap.StateTable
-
- skip(long) - Method in class org.apache.flink.runtime.state.BoundedInputStream
-
- skip(long) - Method in class org.apache.flink.runtime.util.ForwardingInputStream
-
- skipBytes(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- skipBytesToRead(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
-
- skipBytesToWrite(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
-
- Slot - Class in org.apache.flink.runtime.instance
-
Base class for slots that the Scheduler / ExecutionGraph take from the SlotPool and use to place
tasks to execute into.
- Slot(SlotOwner, TaskManagerLocation, int, TaskManagerGateway, SharedSlot, AbstractID) - Constructor for class org.apache.flink.runtime.instance.Slot
-
Base constructor for slots.
- Slot(SlotContext, SlotOwner, int, SharedSlot, AbstractID) - Constructor for class org.apache.flink.runtime.instance.Slot
-
Base constructor for slots.
- SlotActions - Interface in org.apache.flink.runtime.taskexecutor.slot
-
- SlotAllocationException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
-
Exception indicating that the slot allocation on the task manager failed.
- SlotAllocationException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.SlotAllocationException
-
- SlotAllocationException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.SlotAllocationException
-
- SlotAllocationException(Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.SlotAllocationException
-
- SlotAndLocality - Class in org.apache.flink.runtime.jobmaster.slotpool
-
A combination of a
AllocatedSlot
and a
Locality
.
- SlotAndLocality(PhysicalSlot, Locality) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.SlotAndLocality
-
- SlotAvailabilityListener - Interface in org.apache.flink.runtime.jobmanager.scheduler
-
A SlotAvailabilityListener can be notified when new
Slot
s become available on an
Instance
.
- SlotContext - Interface in org.apache.flink.runtime.jobmaster
-
- SlotExecutionVertexAssignment - Class in org.apache.flink.runtime.scheduler
-
- SlotExecutionVertexAssignment(ExecutionVertexID, CompletableFuture<LogicalSlot>) - Constructor for class org.apache.flink.runtime.scheduler.SlotExecutionVertexAssignment
-
- SlotID - Class in org.apache.flink.runtime.clusterframework.types
-
Unique identifier for a slot on a TaskManager.
- SlotID(ResourceID, int) - Constructor for class org.apache.flink.runtime.clusterframework.types.SlotID
-
- SlotInfo - Interface in org.apache.flink.runtime.jobmaster
-
Interface that provides basic information in the context of a slot.
- SlotInfoAndResources(SlotInfo) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.SlotSelectionStrategy.SlotInfoAndResources
-
- SlotInfoAndResources(SlotInfo, ResourceProfile) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.SlotSelectionStrategy.SlotInfoAndResources
-
- SlotManager - Interface in org.apache.flink.runtime.resourcemanager.slotmanager
-
The slot manager is responsible for maintaining a view on all registered task manager slots,
their allocation and all pending slot requests.
- SlotManagerConfiguration - Class in org.apache.flink.runtime.resourcemanager.slotmanager
-
- SlotManagerConfiguration(Time, Time, Time, boolean) - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
-
- SlotManagerException - Exception in org.apache.flink.runtime.resourcemanager.slotmanager
-
- SlotManagerException(String) - Constructor for exception org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerException
-
- SlotManagerException(String, Throwable) - Constructor for exception org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerException
-
- SlotManagerException(Throwable) - Constructor for exception org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerException
-
- SlotManagerImpl - Class in org.apache.flink.runtime.resourcemanager.slotmanager
-
- SlotManagerImpl(ScheduledExecutor, Time, Time, Time, boolean) - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
- SlotNotActiveException - Exception in org.apache.flink.runtime.taskexecutor.slot
-
Exception indicating that the given
TaskSlot
was not in state active.
- SlotNotActiveException(JobID, AllocationID) - Constructor for exception org.apache.flink.runtime.taskexecutor.slot.SlotNotActiveException
-
- SlotNotFoundException - Exception in org.apache.flink.runtime.taskexecutor.slot
-
Exception indicating that a
TaskSlot
could not be found.
- SlotNotFoundException(AllocationID) - Constructor for exception org.apache.flink.runtime.taskexecutor.slot.SlotNotFoundException
-
- SlotNotFoundException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.slot.SlotNotFoundException
-
- SlotOccupiedException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
-
Exception which signals that a slot is already occupied by the given
AllocationID
.
- SlotOccupiedException(String, AllocationID, JobID) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.SlotOccupiedException
-
- SlotOffer - Class in org.apache.flink.runtime.taskexecutor.slot
-
Describe the slot offering to job manager provided by task manager.
- SlotOffer(AllocationID, int, ResourceProfile) - Constructor for class org.apache.flink.runtime.taskexecutor.slot.SlotOffer
-
- SlotOwner - Interface in org.apache.flink.runtime.jobmaster
-
Interface for components that hold slots and to which slots get released / recycled.
- SlotPool - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
The Interface of a slot pool that manages slots.
- SlotPoolFactory - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
- SlotPoolImpl - Class in org.apache.flink.runtime.jobmaster.slotpool
-
- SlotPoolImpl(JobID, Clock, Time, Time, Time) - Constructor for class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
-
- SlotPoolImpl.AvailableSlots - Class in org.apache.flink.runtime.jobmaster.slotpool
-
Organize all available slots from different points of view.
- SlotPoolImpl.PendingRequest - Class in org.apache.flink.runtime.jobmaster.slotpool
-
A pending request for a slot.
- SlotProfile - Class in org.apache.flink.runtime.clusterframework.types
-
A slot profile describes the profile of a slot into which a task wants to be scheduled.
- SlotProfile(ResourceProfile, Collection<TaskManagerLocation>, Collection<AllocationID>) - Constructor for class org.apache.flink.runtime.clusterframework.types.SlotProfile
-
- SlotProfile(ResourceProfile, Collection<TaskManagerLocation>, Collection<AllocationID>, Set<AllocationID>) - Constructor for class org.apache.flink.runtime.clusterframework.types.SlotProfile
-
- SlotProvider - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
The slot provider is responsible for preparing slots for ready-to-run tasks.
- SlotReport - Class in org.apache.flink.runtime.taskexecutor
-
A report about the current status of all slots of the TaskExecutor, describing
which slots are available and allocated, and what jobs (JobManagers) the allocated slots
have been allocated to.
- SlotReport() - Constructor for class org.apache.flink.runtime.taskexecutor.SlotReport
-
- SlotReport(SlotStatus) - Constructor for class org.apache.flink.runtime.taskexecutor.SlotReport
-
- SlotReport(Collection<SlotStatus>) - Constructor for class org.apache.flink.runtime.taskexecutor.SlotReport
-
- SlotRequest - Class in org.apache.flink.runtime.resourcemanager
-
This describes the requirement of the slot, mainly used by JobManager requesting slot from ResourceManager.
- SlotRequest(JobID, AllocationID, ResourceProfile, String) - Constructor for class org.apache.flink.runtime.resourcemanager.SlotRequest
-
- SlotRequestId - Class in org.apache.flink.runtime.jobmaster
-
This ID identifies the request for a logical slot from the Execution to the
SlotPool
oe
SlotProvider
.
- SlotRequestId(long, long) - Constructor for class org.apache.flink.runtime.jobmaster.SlotRequestId
-
- SlotRequestId() - Constructor for class org.apache.flink.runtime.jobmaster.SlotRequestId
-
- SlotSelectionStrategy - Interface in org.apache.flink.runtime.jobmaster.slotpool
-
Interface for slot selection strategies to be used in the
Scheduler
.
- SlotSelectionStrategy.SlotInfoAndLocality - Class in org.apache.flink.runtime.jobmaster.slotpool
-
- SlotSelectionStrategy.SlotInfoAndResources - Class in org.apache.flink.runtime.jobmaster.slotpool
-
- SlotSharingGroup - Class in org.apache.flink.runtime.jobmanager.scheduler
-
A slot sharing units defines which different task (from different job vertices) can be
deployed together within a slot.
- SlotSharingGroup() - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
-
- SlotSharingGroup(JobVertexID...) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
-
- SlotSharingGroupAssignment - Class in org.apache.flink.runtime.instance
-
The SlotSharingGroupAssignment manages a set of shared slots, which are shared between
tasks of a
SlotSharingGroup
.
- SlotSharingGroupAssignment() - Constructor for class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
-
- SlotSharingGroupId - Class in org.apache.flink.runtime.instance
-
- SlotSharingGroupId(long, long) - Constructor for class org.apache.flink.runtime.instance.SlotSharingGroupId
-
- SlotSharingGroupId() - Constructor for class org.apache.flink.runtime.instance.SlotSharingGroupId
-
- SlotSharingManager - Class in org.apache.flink.runtime.jobmaster.slotpool
-
Manager which is responsible for slot sharing.
- SlotSharingManager.MultiTaskSlot - Class in org.apache.flink.runtime.jobmaster.slotpool
-
- SlotSharingManager.SingleTaskSlot - Class in org.apache.flink.runtime.jobmaster.slotpool
-
- SlotSharingManager.TaskSlot - Class in org.apache.flink.runtime.jobmaster.slotpool
-
Base class for all task slots.
- SlotStatus - Class in org.apache.flink.runtime.taskexecutor
-
This describes the slot current status which located in TaskManager.
- SlotStatus(SlotID, ResourceProfile) - Constructor for class org.apache.flink.runtime.taskexecutor.SlotStatus
-
- SlotStatus(SlotID, ResourceProfile, JobID, AllocationID) - Constructor for class org.apache.flink.runtime.taskexecutor.SlotStatus
-
- SnappyStreamCompressionDecorator - Class in org.apache.flink.runtime.state
-
This implementation decorates the stream with snappy compression.
- SnappyStreamCompressionDecorator() - Constructor for class org.apache.flink.runtime.state.SnappyStreamCompressionDecorator
-
- snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
-
- snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- snapshot() - Method in class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo
-
- snapshot() - Method in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo
-
- snapshot() - Method in class org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo
-
- snapshot() - Method in class org.apache.flink.runtime.state.RegisteredPriorityQueueStateBackendMetaInfo
-
- snapshot() - Method in class org.apache.flink.runtime.state.RegisteredStateMetaInfoBase
-
- snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - Method in interface org.apache.flink.runtime.state.SnapshotStrategy
-
- snapshotCloseableRegistry - Variable in class org.apache.flink.runtime.state.AsyncSnapshotCallable
-
Registers streams that can block in I/O during snapshot.
- snapshotConfiguration() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.runtime.state.ttl.TtlStateFactory.TtlSerializer
-
- snapshotConfiguration() - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- SnapshotDirectory - Class in org.apache.flink.runtime.state
-
This class represents a directory that is the target for a state snapshot.
- SnapshotResult<T extends StateObject> - Class in org.apache.flink.runtime.state
-
This class contains the combined results from the snapshot of a state backend:
A state object representing the state that will be reported to the Job Manager to acknowledge the checkpoint.
A state object that represents the state for the
TaskLocalStateStoreImpl
.
Both state objects are optional and can be null, e.g.
- SnapshotStrategy<S extends StateObject> - Interface in org.apache.flink.runtime.state
-
Interface for different snapshot approaches in state backends.
- SolutionSetBroker - Class in org.apache.flink.runtime.iterative.concurrent
-
Used to hand over the hash-join from the iteration head to the solution-set match.
- SolutionSetFastUpdateOutputCollector<T> - Class in org.apache.flink.runtime.iterative.io
-
A Collector
to update the solution set of a workset iteration.
- SolutionSetFastUpdateOutputCollector(CompactingHashTable<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetFastUpdateOutputCollector
-
- SolutionSetFastUpdateOutputCollector(CompactingHashTable<T>, Collector<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetFastUpdateOutputCollector
-
- SolutionSetObjectsUpdateOutputCollector<T> - Class in org.apache.flink.runtime.iterative.io
-
A Collector
to update the solution set of a workset iteration.
- SolutionSetObjectsUpdateOutputCollector(JoinHashMap<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetObjectsUpdateOutputCollector
-
- SolutionSetObjectsUpdateOutputCollector(JoinHashMap<T>, Collector<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetObjectsUpdateOutputCollector
-
- SolutionSetUpdateBarrier - Class in org.apache.flink.runtime.iterative.concurrent
-
- SolutionSetUpdateBarrier() - Constructor for class org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrier
-
- SolutionSetUpdateBarrierBroker - Class in org.apache.flink.runtime.iterative.concurrent
-
- SolutionSetUpdateOutputCollector<T> - Class in org.apache.flink.runtime.iterative.io
-
A Collector
to update the solution set of a workset iteration.
- SolutionSetUpdateOutputCollector(CompactingHashTable<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetUpdateOutputCollector
-
- SolutionSetUpdateOutputCollector(CompactingHashTable<T>, Collector<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetUpdateOutputCollector
-
- sort(IndexedSortable, int, int) - Method in class org.apache.flink.runtime.operators.sort.HeapSort
-
- sort(IndexedSortable) - Method in class org.apache.flink.runtime.operators.sort.HeapSort
-
- sort(IndexedSortable, int, int) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSorter
-
Sort the items accessed through the given IndexedSortable over the given
range of logical indices.
- sort(IndexedSortable) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSorter
-
- sort(IndexedSortable, int, int) - Method in class org.apache.flink.runtime.operators.sort.QuickSort
-
Sort the given range of items using quick sort.
- sort(IndexedSortable) - Method in class org.apache.flink.runtime.operators.sort.QuickSort
-
- Sorter<E> - Interface in org.apache.flink.runtime.operators.sort
-
The SortMerger interface representing the public interface to all specific Sort-Merge implementations.
- SortingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SortingThread
-
Creates a new sorting thread.
- sortReadMemory - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
The memory segments used first for sorting and later for reading/pre-fetching
during the external merge.
- source - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
-
- source - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
-
- SpanningRecordSerializer<T extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.serialization
-
- SpanningRecordSerializer() - Constructor for class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
-
- spillHeadCopy - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
-
- SpillingAdaptiveSpanningRecordDeserializer<T extends org.apache.flink.core.io.IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.serialization
-
- SpillingAdaptiveSpanningRecordDeserializer(String[]) - Constructor for class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
-
- SpillingBuffer - Class in org.apache.flink.runtime.io.disk
-
An output view that buffers written data in memory pages and spills them when they are full.
- SpillingBuffer(IOManager, MemorySegmentSource, int) - Constructor for class org.apache.flink.runtime.io.disk.SpillingBuffer
-
- spillingMarker() - Static method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
-
Gets the element that is passed as marker for signal beginning of spilling.
- SpillingResettableIterator<T> - Class in org.apache.flink.runtime.operators.resettable
-
Implementation of a resettable iterator.
- SpillingResettableIterator(Iterator<T>, TypeSerializer<T>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
-
- SpillingResettableIterator(Iterator<T>, TypeSerializer<T>, MemoryManager, IOManager, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
-
- SpillingResettableMutableObjectIterator<T> - Class in org.apache.flink.runtime.operators.resettable
-
Implementation of a resettable iterator.
- SpillingResettableMutableObjectIterator(MutableObjectIterator<T>, TypeSerializer<T>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
-
- SpillingResettableMutableObjectIterator(MutableObjectIterator<T>, TypeSerializer<T>, MemoryManager, IOManager, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
-
- SpillingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable, MemoryManager, IOManager, TypeSerializer<E>, TypeComparator<E>, List<MemorySegment>, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
-
Creates the spilling thread.
- spillPartition(List<MemorySegment>, IOManager, FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
-
Spills this partition to disk and sets it up such that it continues spilling records that are added to
it.
- spillPartition() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
-
Selects a partition and spills it.
- SSLHandlerFactory - Class in org.apache.flink.runtime.io.network.netty
-
Creates and configures SslHandler
instances.
- SSLHandlerFactory(SslContext, int, int) - Constructor for class org.apache.flink.runtime.io.network.netty.SSLHandlerFactory
-
Create a new SslHandler
factory.
- 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
-
- 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
-
- StackTraceSample - Class in org.apache.flink.runtime.rest.handler.legacy.backpressure
-
A sample of stack traces for one or more tasks.
- StackTraceSample(int, long, long, Map<ExecutionAttemptID, List<StackTraceElement[]>>) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSample
-
Creates a stack trace sample.
- StackTraceSampleCoordinator - Class in org.apache.flink.runtime.rest.handler.legacy.backpressure
-
A coordinator for triggering and collecting stack traces of running tasks.
- StackTraceSampleCoordinator(Executor, long) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.backpressure.StackTraceSampleCoordinator
-
Creates a new coordinator for the job.
- StackTraceSampleResponse - Class in org.apache.flink.runtime.messages
-
Response to the TriggerStackTraceSample message.
- StackTraceSampleResponse(int, ExecutionAttemptID, List<StackTraceElement[]>) - Constructor for class org.apache.flink.runtime.messages.StackTraceSampleResponse
-
- StandaloneCheckpointIDCounter - Class in org.apache.flink.runtime.checkpoint
-
- StandaloneCheckpointIDCounter() - Constructor for class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
-
- StandaloneCheckpointRecoveryFactory - Class in org.apache.flink.runtime.checkpoint
-
- StandaloneCheckpointRecoveryFactory() - Constructor for class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
-
- StandaloneCompletedCheckpointStore - Class in org.apache.flink.runtime.checkpoint
-
- StandaloneCompletedCheckpointStore(int) - Constructor for class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
-
- StandaloneDispatcher - Class in org.apache.flink.runtime.dispatcher
-
Dispatcher implementation which spawns a
JobMaster
for each
submitted
JobGraph
within in the same process.
- StandaloneDispatcher(RpcService, String, Configuration, HighAvailabilityServices, GatewayRetriever<ResourceManagerGateway>, BlobServer, HeartbeatServices, JobManagerMetricGroup, String, ArchivedExecutionGraphStore, JobManagerRunnerFactory, FatalErrorHandler, HistoryServerArchivist) - Constructor for class org.apache.flink.runtime.dispatcher.StandaloneDispatcher
-
- StandaloneHaServices - Class in org.apache.flink.runtime.highavailability.nonha.standalone
-
- StandaloneHaServices(String, String, String, String) - Constructor for class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
-
Creates a new services class for the fix pre-defined leaders.
- StandaloneLeaderElectionService - Class in org.apache.flink.runtime.leaderelection
-
- 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
-
- StandaloneLeaderRetrievalService(String, UUID) - Constructor for class org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
-
Creates a StandaloneLeaderRetrievalService with the given leader address.
- StandaloneResourceManager - Class in org.apache.flink.runtime.resourcemanager
-
A standalone implementation of the resource manager.
- StandaloneResourceManager(RpcService, String, ResourceID, HighAvailabilityServices, HeartbeatServices, SlotManager, MetricRegistry, JobLeaderIdService, ClusterInformation, FatalErrorHandler, JobManagerMetricGroup, Time) - Constructor for class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
-
- StandaloneResourceManagerFactory - Enum in org.apache.flink.runtime.resourcemanager
-
- StandaloneRunningJobsRegistry - Class in org.apache.flink.runtime.highavailability.nonha.standalone
-
A registry for running jobs, not-highly available.
- StandaloneRunningJobsRegistry() - Constructor for class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
-
- StandaloneSessionClusterEntrypoint - Class in org.apache.flink.runtime.entrypoint
-
Entry point for the standalone session cluster.
- StandaloneSessionClusterEntrypoint(Configuration) - Constructor for class org.apache.flink.runtime.entrypoint.StandaloneSessionClusterEntrypoint
-
- StandaloneSubmittedJobGraphStore - Class in org.apache.flink.runtime.jobmanager
-
- 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 class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
-
- start() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
-
- start(SubmittedJobGraphStore.SubmittedJobGraphListener) - Method in class org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
-
- start(ComponentMainThreadExecutor) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
- start(LeaderContender) - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
-
- start() - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
-
Starts the internal related components for network connection and communication.
- start() - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
-
- start() - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
-
- start() - Method in class org.apache.flink.runtime.io.network.NettyShuffleEnvironment
-
- start(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() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
-
- start(JobMasterId) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
Start the rpc service and begin to run the job.
- start(JobMasterId) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterService
-
Start the JobMaster service with the given
JobMasterId
.
- start(ComponentMainThreadExecutor) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.Scheduler
-
Start the scheduler by initializing the main thread executor.
- start(ComponentMainThreadExecutor) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SchedulerImpl
-
- start(JobMasterId, String, ComponentMainThreadExecutor) - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
- start(JobMasterId, String, ComponentMainThreadExecutor) - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
-
Start the slot pool to accept RPC calls.
- start(LeaderContender) - Method in interface org.apache.flink.runtime.leaderelection.LeaderElectionService
-
Starts the leader election service.
- start(LeaderContender) - Method in class org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
-
- start(LeaderContender) - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
-
- start(LeaderRetrievalListener) - Method in interface org.apache.flink.runtime.leaderretrieval.LeaderRetrievalService
-
Starts the leader retrieval service with the given listener to listen for new leaders.
- start(LeaderRetrievalListener) - Method in class org.apache.flink.runtime.leaderretrieval.SettableLeaderRetrievalService
-
- start(LeaderRetrievalListener) - Method in class org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
-
- start(LeaderRetrievalListener) - Method in class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
-
- start() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
Starts the mini cluster, based on the configured properties.
- start() - Method in interface org.apache.flink.runtime.query.KvStateServer
-
Starts the server.
- start() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
-
- start(JobLeaderIdActions) - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
Start the service with the given job leader actions.
- start(ResourceManagerId, Executor, ResourceActions) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Starts the slot manager with the given leader id and resource manager actions.
- start(ResourceManagerId, Executor, ResourceActions) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
Starts the slot manager with the given leader id and resource manager actions.
- start() - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
-
Starts this REST server endpoint.
- start() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Triggers start of the rpc endpoint.
- start() - Method in interface org.apache.flink.runtime.rpc.StartStoppable
-
Starts the processing of remote procedure calls.
- start() - Method in interface org.apache.flink.runtime.shuffle.ShuffleEnvironment
-
Start the internal related services before using the shuffle service environment.
- start(String, RpcService, HighAvailabilityServices, JobLeaderListener) - Method in class org.apache.flink.runtime.taskexecutor.JobLeaderService
-
Start the job leader service with the given services.
- start() - Method in class org.apache.flink.runtime.taskexecutor.KvStateService
-
- start(SlotActions) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Start the task slot table with the given slot actions.
- start(TimeoutListener<K>) - Method in class org.apache.flink.runtime.taskexecutor.slot.TimerService
-
- start() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
-
- start() - Method in interface org.apache.flink.runtime.webmonitor.WebMonitor
-
Starts the web monitor.
- start() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
-
- start() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
-
- startActorSystem(Configuration, String, String, Logger) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Starts an ActorSystem with the given configuration listening at the address/ports.
- startActorSystem(Configuration, String, String, Logger, BootstrapTools.ActorSystemExecutorConfiguration) - 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, String, String, Logger, BootstrapTools.ActorSystemExecutorConfiguration) - 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.
- startActorSystem(Configuration, String, int, Logger, BootstrapTools.ActorSystemExecutorConfiguration) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Starts an Actor System at a specific port.
- startActorSystem(Configuration, String, String, int, Logger, BootstrapTools.ActorSystemExecutorConfiguration) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Starts an Actor System at a specific port.
- startCheckpointScheduler() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- startCluster() - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- startCuratorFramework(Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
-
Starts a CuratorFramework
instance and connects it to the given ZooKeeper
quorum.
- startIfConfigured(Logger, Configuration, CompletableFuture<Void>) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
-
- startInternal() - Method in class org.apache.flink.runtime.rest.RestServerEndpoint
-
Hook to start sub class specific services.
- startInternal() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorEndpoint
-
- startMetricsRpcService(Configuration, String) - Static method in class org.apache.flink.runtime.metrics.util.MetricUtils
-
- startNewKeyGroup(int) - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
-
User code can call this method to signal that it begins to write a new key group with the given key group id.
- startNewPartition() - Method in class org.apache.flink.runtime.state.OperatorStateCheckpointOutputStream
-
User code can call this method to signal that it begins to write a new partition of operator state.
- startNewWorker(ResourceProfile) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
Allocates a resource using the resource profile.
- startNewWorker(ResourceProfile) - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
-
- startNextSuperstep() - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
-
- startNextSuperstep() - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
-
- startQueryService(RpcService, ResourceID) - Method in class org.apache.flink.runtime.metrics.MetricRegistryImpl
-
Initializes the MetricQueryService.
- startReading() - Method in class org.apache.flink.runtime.operators.TempBarrier
-
- startRegistration() - Method in class org.apache.flink.runtime.registration.RetryingRegistration
-
This method resolves the target address to a callable gateway and starts the
registration after that.
- startScheduling() - Method in class org.apache.flink.runtime.scheduler.DefaultScheduler
-
- startScheduling() - Method in class org.apache.flink.runtime.scheduler.LegacyScheduler
-
- startScheduling() - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
-
- startScheduling() - Method in class org.apache.flink.runtime.scheduler.strategy.EagerSchedulingStrategy
-
- startScheduling() - Method in class org.apache.flink.runtime.scheduler.strategy.LazyFromSourcesSchedulingStrategy
-
- startScheduling() - Method in interface org.apache.flink.runtime.scheduler.strategy.SchedulingStrategy
-
Called when the scheduling is started (initial scheduling operation).
- startServer(C) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- startServer(C) - Method in interface org.apache.flink.runtime.rpc.RpcService
-
Start a rpc server which forwards the remote procedure calls to the provided rpc endpoint.
- startServicesOnLeadership() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
- startServicesOnLeadership() - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
-
- StartStoppable - Interface in org.apache.flink.runtime.rpc
-
Interface to start and stop the processing of rpc calls in the rpc server.
- startTaskManager(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, BlobCacheService, boolean, FatalErrorHandler) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
-
- 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.
- startTrackingPartition(ResourceID, ResultPartitionDeploymentDescriptor) - Method in interface org.apache.flink.runtime.io.network.partition.PartitionTracker
-
Starts the tracking of the given partition for the given task executor ID.
- startTrackingPartition(ResourceID, ResultPartitionDeploymentDescriptor) - Method in class org.apache.flink.runtime.io.network.partition.PartitionTrackerImpl
-
- startTrackingPartitions(K, Collection<ResultPartitionID>) - Method in class org.apache.flink.runtime.taskexecutor.partition.PartitionTable
-
Starts the tracking of the given partition for the given key.
- STARTUP_FAILURE_RETURN_CODE - Static variable in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- state - Variable in class org.apache.flink.runtime.state.SnapshotDirectory
-
This reference tracks the lifecycle state of the snapshot directory.
- StateAssignmentOperation - Class in org.apache.flink.runtime.checkpoint
-
This class encapsulates the operation of assigning restored state when restoring from a checkpoint.
- StateAssignmentOperation(long, Map<JobVertexID, ExecutionJobVertex>, Map<OperatorID, OperatorState>, boolean) - Constructor for class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
-
- StateBackend - Interface in org.apache.flink.runtime.state
-
A State Backend defines how the state of a streaming application is stored and
checkpointed.
- StateBackendBuilder<T,E extends Throwable> - Interface in org.apache.flink.runtime.state
-
A mutable builder to build a state backend instance.
- StateBackendFactory<T extends StateBackend> - Interface in org.apache.flink.runtime.state
-
A factory to create a specific state backend.
- StateBackendLoader - Class in org.apache.flink.runtime.state
-
This class contains utility methods to load state backends from configurations.
- StateEntry<K,N,S> - Interface in org.apache.flink.runtime.state
-
Interface of entries in a state backend.
- StateEntry.SimpleStateEntry<K,N,S> - Class in org.apache.flink.runtime.state
-
- StateHandleID - Class in org.apache.flink.runtime.state
-
Unique ID that allows for logical comparison between state handles.
- StateHandleID(String) - Constructor for class org.apache.flink.runtime.state.StateHandleID
-
- StateInitializationContext - Interface in org.apache.flink.runtime.state
-
This interface provides a context in which operators can initialize by registering to managed state (i.e.
- StateInitializationContextImpl - Class in org.apache.flink.runtime.state
-
- StateInitializationContextImpl(boolean, OperatorStateStore, KeyedStateStore, Iterable<KeyGroupStatePartitionStreamProvider>, Iterable<StatePartitionStreamProvider>) - Constructor for class org.apache.flink.runtime.state.StateInitializationContextImpl
-
- stateLock - Variable in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
-
The lock to synchronize state changes (open / close) on
- StateMap<K,N,S> - Class in org.apache.flink.runtime.state.heap
-
Base class for state maps.
- StateMap() - Constructor for class org.apache.flink.runtime.state.heap.StateMap
-
- StateMapSnapshot<K,N,S,T extends StateMap<K,N,S>> - Class in org.apache.flink.runtime.state.heap
-
- StateMapSnapshot(T) - Constructor for class org.apache.flink.runtime.state.heap.StateMapSnapshot
-
- StateMetaInfo(long[], OperatorStateHandle.Mode) - Constructor for class org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
-
- StateMetaInfoReader - Interface in org.apache.flink.runtime.state.metainfo
-
- StateMetaInfoSnapshot - Class in org.apache.flink.runtime.state.metainfo
-
Generalized snapshot for meta information about one state in a state backend
(e.g.
- StateMetaInfoSnapshot(String, StateMetaInfoSnapshot.BackendStateType, Map<String, String>, Map<String, TypeSerializerSnapshot<?>>) - Constructor for class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
-
- StateMetaInfoSnapshot(String, StateMetaInfoSnapshot.BackendStateType, Map<String, String>, Map<String, TypeSerializerSnapshot<?>>, Map<String, TypeSerializer<?>>) - Constructor for class org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot
-
- StateMetaInfoSnapshot.BackendStateType - Enum in org.apache.flink.runtime.state.metainfo
-
Enum that defines the different types of state that live in Flink backends.
- StateMetaInfoSnapshot.CommonOptionsKeys - Enum in org.apache.flink.runtime.state.metainfo
-
Predefined keys for the most common options in the meta info.
- StateMetaInfoSnapshot.CommonSerializerKeys - Enum in org.apache.flink.runtime.state.metainfo
-
Predefined keys for the most common serializer types in the meta info.
- StateMetaInfoSnapshotReadersWriters - Class in org.apache.flink.runtime.state.metainfo
-
- StateMetaInfoSnapshotReadersWriters.StateTypeHint - Enum in org.apache.flink.runtime.state.metainfo
-
Enum for backwards compatibility.
- StateMetaInfoWriter - Interface in org.apache.flink.runtime.state.metainfo
-
- StateObject - Interface in org.apache.flink.runtime.state
-
Base of all handles that represent checkpointed state in some form.
- StateObjectCollection<T extends StateObject> - Class in org.apache.flink.runtime.checkpoint
-
This class represents a generic collection for
StateObject
s.
- StateObjectCollection() - Constructor for class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
Creates a new StateObjectCollection that is backed by an
ArrayList
.
- StateObjectCollection(Collection<T>) - Constructor for class org.apache.flink.runtime.checkpoint.StateObjectCollection
-
Creates a new StateObjectCollection wraps the given collection and delegates to it.
- StatePartitionStreamProvider - Class in org.apache.flink.runtime.state
-
This class provides access to input streams that contain data of one state partition of a partitionable state.
- StatePartitionStreamProvider(IOException) - Constructor for class org.apache.flink.runtime.state.StatePartitionStreamProvider
-
- StatePartitionStreamProvider(InputStream) - Constructor for class org.apache.flink.runtime.state.StatePartitionStreamProvider
-
- stateSerializer - Variable in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
The serializer of the state.
- StateSerializerProvider<T> - Class in org.apache.flink.runtime.state
-
A
StateSerializerProvider
wraps logic on how to obtain serializers for registered state,
either with the previous schema of state in checkpoints or the current schema of state.
- stateSnapshot() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateMap
-
- stateSnapshot() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
-
- stateSnapshot() - Method in class org.apache.flink.runtime.state.heap.HeapPriorityQueueSnapshotRestoreWrapper
-
- stateSnapshot() - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
-
- stateSnapshot() - Method in class org.apache.flink.runtime.state.heap.NestedStateMap
-
- stateSnapshot() - Method in class org.apache.flink.runtime.state.heap.StateMap
-
Creates a snapshot of this
StateMap
, to be written in checkpointing.
- StateSnapshot - Interface in org.apache.flink.runtime.state
-
General interface for state snapshots that should be written partitioned by key-groups.
- stateSnapshot() - Method in interface org.apache.flink.runtime.state.StateSnapshotRestore
-
Returns a snapshot of the state.
- StateSnapshot.StateKeyGroupWriter - Interface in org.apache.flink.runtime.state
-
Interface for writing a snapshot that is partitioned into key-groups.
- StateSnapshotContext - Interface in org.apache.flink.runtime.state
-
This interface provides a context in which operators that use managed (i.e.
- StateSnapshotContextSynchronousImpl - Class in org.apache.flink.runtime.state
-
This class is a default implementation for StateSnapshotContext.
- StateSnapshotContextSynchronousImpl(long, long) - Constructor for class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
-
- StateSnapshotContextSynchronousImpl(long, long, CheckpointStreamFactory, KeyGroupRange, CloseableRegistry) - Constructor for class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
-
- StateSnapshotKeyGroupReader - Interface in org.apache.flink.runtime.state
-
Interface for state de-serialization into
StateTable
s by key-group.
- StateSnapshotRestore - Interface in org.apache.flink.runtime.state
-
Interface to deal with state snapshot and restore of state.
- StateSnapshotTransformer<T> - Interface in org.apache.flink.runtime.state
-
Transformer of state values which are included or skipped in the snapshot.
- StateSnapshotTransformer.CollectionStateSnapshotTransformer<T> - Interface in org.apache.flink.runtime.state
-
Collection state specific transformer which says how to transform entries of the collection.
- StateSnapshotTransformer.CollectionStateSnapshotTransformer.TransformStrategy - Enum in org.apache.flink.runtime.state
-
- StateSnapshotTransformer.StateSnapshotTransformFactory<T> - Interface in org.apache.flink.runtime.state
-
This factory creates state transformers depending on the form of values to transform.
- StateSnapshotTransformers - Class in org.apache.flink.runtime.state
-
Collection of common state snapshot transformers and their factories.
- StateSnapshotTransformers() - Constructor for class org.apache.flink.runtime.state.StateSnapshotTransformers
-
- StateSnapshotTransformers.ListStateSnapshotTransformer<T> - Class in org.apache.flink.runtime.state
-
General implementation of list state transformer.
- StateSnapshotTransformers.ListStateSnapshotTransformFactory<T> - Class in org.apache.flink.runtime.state
-
- StateSnapshotTransformers.MapStateSnapshotTransformer<K,V> - Class in org.apache.flink.runtime.state
-
General implementation of map state transformer.
- StateSnapshotTransformers.MapStateSnapshotTransformFactory<K,V> - Class in org.apache.flink.runtime.state
-
- StateSnapshotTransformers.StateSnapshotTransformFactoryWrapAdaptor<S,T> - Class in org.apache.flink.runtime.state
-
- stateTable - Variable in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
Map containing the actual key/value pairs.
- StateTable<K,N,S> - Class in org.apache.flink.runtime.state.heap
-
Base class for state tables.
- StateTable(InternalKeyContext<K>, RegisteredKeyValueStateBackendMetaInfo<N, S>, TypeSerializer<K>) - Constructor for class org.apache.flink.runtime.state.heap.StateTable
-
- StateTransformationFunction<S,T> - Interface in org.apache.flink.runtime.state
-
Interface for a binary function that is used for push-down of state transformation into state backends.
- StateUtil - Class in org.apache.flink.runtime.state
-
- StaticFileServerHandler<T extends RestfulGateway> - Class in org.apache.flink.runtime.rest.handler.legacy.files
-
Simple file server handler that serves requests to web frontend's static files, such as
HTML, CSS, or JS files.
- StaticFileServerHandler(GatewayRetriever<? extends T>, Time, File) - Constructor for class org.apache.flink.runtime.rest.handler.legacy.files.StaticFileServerHandler
-
- StatusHandler(GatewayRetriever<? extends T>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, AsynchronousOperationResult<V>, M>) - Constructor for class org.apache.flink.runtime.rest.handler.async.AbstractAsynchronousOperationHandlers.StatusHandler
-
- stddev - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
-
- stdOutFile - Variable in class org.apache.flink.runtime.webmonitor.WebMonitorUtils.LogFileLocation
-
- StdoutFileHandlerSpecification - Class in org.apache.flink.runtime.rest.handler.legacy.files
-
Rest handler specification for the stdout file of the main cluster component.
- stop() - Method in class org.apache.flink.runtime.dispatcher.SingleJobSubmittedJobGraphStore
-
- stop() - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatManager
-
Stops the heartbeat manager.
- stop() - Method in class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
-
- stop() - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
-
- 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.SettableLeaderRetrievalService
-
- stop() - Method in class org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
-
- stop() - Method in class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
-
- stop() - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
-
Stop the service.
- stop() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Triggers stop of the rpc endpoint.
- stop() - Method in interface org.apache.flink.runtime.rpc.StartStoppable
-
Stops the processing of remote procedure calls.
- stop() - Method in class org.apache.flink.runtime.scheduler.DefaultExecutionSlotAllocator
-
- stop() - Method in interface org.apache.flink.runtime.scheduler.ExecutionSlotAllocator
-
Stop the allocator.
- stop() - Method in class org.apache.flink.runtime.taskexecutor.JobLeaderService
-
Stop the job leader services.
- stop() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
-
Stop the task slot table.
- stop() - Method in class org.apache.flink.runtime.taskexecutor.slot.TimerService
-
- stop() - Method in interface org.apache.flink.runtime.webmonitor.WebMonitor
-
Stops the web server.
- stopCheckpointScheduler() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
-
- stopClusterServices(boolean) - Method in class org.apache.flink.runtime.entrypoint.ClusterEntrypoint
-
- stopped - Variable in class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
-
Running state of the heartbeat manager.
- StoppingSupervisorWithoutLoggingActorKilledExceptionStrategy - Class in org.apache.flink.runtime.akka
-
Stopping supervisor strategy which logs ActorKilledException
only on debug log level.
- StoppingSupervisorWithoutLoggingActorKilledExceptionStrategy() - Constructor for class org.apache.flink.runtime.akka.StoppingSupervisorWithoutLoggingActorKilledExceptionStrategy
-
- stopServer(RpcServer) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- stopServer(RpcServer) - Method in interface org.apache.flink.runtime.rpc.RpcService
-
Stop the underlying rpc server of the provided self gateway.
- stopService() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
-
- stopService() - Method in interface org.apache.flink.runtime.rpc.RpcService
-
Trigger the asynchronous stopping of the
RpcService
.
- stopTrackingAndReleasePartitions(Collection<ResultPartitionID>) - Method in interface org.apache.flink.runtime.io.network.partition.PartitionTracker
-
Releases the given partitions and stop the tracking of partitions that were released.
- stopTrackingAndReleasePartitions(Collection<ResultPartitionID>) - Method in class org.apache.flink.runtime.io.network.partition.PartitionTrackerImpl
-
- stopTrackingAndReleasePartitionsFor(ResourceID) - Method in interface org.apache.flink.runtime.io.network.partition.PartitionTracker
-
Releases all partitions for the given task executor ID, and stop the tracking of partitions that were released.
- stopTrackingAndReleasePartitionsFor(ResourceID) - Method in class org.apache.flink.runtime.io.network.partition.PartitionTrackerImpl
-
- stopTrackingPartitions(Collection<ResultPartitionID>) - Method in interface org.apache.flink.runtime.io.network.partition.PartitionTracker
-
Stops the tracking of the given partitions.
- stopTrackingPartitions(Collection<ResultPartitionID>) - Method in class org.apache.flink.runtime.io.network.partition.PartitionTrackerImpl
-
- stopTrackingPartitions(K) - Method in class org.apache.flink.runtime.taskexecutor.partition.PartitionTable
-
Stops the tracking of all partition for the given key.
- stopTrackingPartitions(K, Collection<ResultPartitionID>) - Method in class org.apache.flink.runtime.taskexecutor.partition.PartitionTable
-
Stops the tracking of the given set of partitions for the given key.
- stopTrackingPartitionsFor(ResourceID) - Method in interface org.apache.flink.runtime.io.network.partition.PartitionTracker
-
Stops the tracking of all partitions for the given task executor ID, without issuing any release calls.
- stopTrackingPartitionsFor(ResourceID) - Method in class org.apache.flink.runtime.io.network.partition.PartitionTrackerImpl
-
- stopWithSavepoint(JobID, String, boolean, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- stopWithSavepoint(String, boolean, Time) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
- stopWithSavepoint(String, boolean, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
-
Stops the job with a savepoint.
- stopWithSavepoint(JobID, String, boolean) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- stopWithSavepoint(String, boolean) - Method in class org.apache.flink.runtime.scheduler.LegacyScheduler
-
- stopWithSavepoint(String, boolean) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
-
- stopWithSavepoint(JobID, String, boolean, Time) - Method in interface org.apache.flink.runtime.webmonitor.RestfulGateway
-
Stops the job with a savepoint.
- StopWithSavepointHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>) - Constructor for class org.apache.flink.runtime.rest.handler.job.savepoints.SavepointHandlers.StopWithSavepointHandler
-
- StopWithSavepointRequestBody - Class in org.apache.flink.runtime.rest.messages.job.savepoints.stop
-
- StopWithSavepointRequestBody(String, boolean) - Constructor for class org.apache.flink.runtime.rest.messages.job.savepoints.stop.StopWithSavepointRequestBody
-
- StopWithSavepointTriggerHeaders - Class in org.apache.flink.runtime.rest.messages.job.savepoints.stop
-
These headers define the protocol for triggering a "stop" action.
- stopWorker(WorkerType) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
-
Stops the given worker.
- stopWorker(ResourceID) - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
-
- storageDir - Variable in class org.apache.flink.runtime.blob.AbstractBlobCache
-
Root directory for local file storage.
- store(T) - Method in class org.apache.flink.runtime.zookeeper.filesystem.FileSystemStateStorageHelper
-
- store(T) - Method in interface org.apache.flink.runtime.zookeeper.RetrievableStateStorageHelper
-
Stores the given state and returns a state handle to it.
- storeCheckpointMetadata(T, OutputStream) - Static method in class org.apache.flink.runtime.checkpoint.Checkpoints
-
- storeCheckpointMetadata(T, DataOutputStream) - Static method in class org.apache.flink.runtime.checkpoint.Checkpoints
-
- storeLocalState(long, TaskStateSnapshot) - Method in class org.apache.flink.runtime.state.NoOpTaskLocalStateStoreImpl
-
- storeLocalState(long, TaskStateSnapshot) - Method in interface org.apache.flink.runtime.state.TaskLocalStateStore
-
Stores the local state for the given checkpoint id.
- storeLocalState(long, TaskStateSnapshot) - Method in class org.apache.flink.runtime.state.TaskLocalStateStoreImpl
-
- storesLocalResourcesOn() - Method in class org.apache.flink.runtime.shuffle.NettyShuffleDescriptor
-
- storesLocalResourcesOn() - Method in interface org.apache.flink.runtime.shuffle.ShuffleDescriptor
-
Returns the location of the producing task executor if the partition occupies local resources there.
- storesLocalResourcesOn() - Method in class org.apache.flink.runtime.shuffle.UnknownShuffleDescriptor
-
- StreamCompressionDecorator - Class in org.apache.flink.runtime.state
-
Implementations of this interface decorate streams with a compression scheme.
- StreamCompressionDecorator() - Constructor for class org.apache.flink.runtime.state.StreamCompressionDecorator
-
- StreamStateHandle - Interface in org.apache.flink.runtime.state
-
A
StateObject
that represents state that was written to a stream.
- StringifiedAccumulatorResult - Class in org.apache.flink.runtime.accumulators
-
Container class that transports the result of an accumulator as set of strings.
- StringifiedAccumulatorResult(String, String, String) - Constructor for class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
-
- stringifyAccumulatorResults(Map<String, OptionalFailure<Accumulator<?, ?>>>) - Static method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
-
Flatten a map of accumulator names to Accumulator instances into an array of StringifiedAccumulatorResult values.
- stub - Variable in class org.apache.flink.runtime.operators.BatchTask
-
The instantiated user code of this task's main operator (driver).
- subComponents() - Method in class org.apache.flink.runtime.metrics.groups.ComponentMetricGroup
-
Gets all component metric groups that are contained in this component metric group.
- subComponents() - Method in class org.apache.flink.runtime.metrics.groups.JobManagerJobMetricGroup
-
- subComponents() - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
-
- subComponents() - Method in class org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
-
- subComponents() - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
-
- subComponents() - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
-
- subComponents() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- submitJob(JobGraph, Time) - Method in class org.apache.flink.runtime.dispatcher.Dispatcher
-
- submitJob(JobGraph, Time) - Method in interface org.apache.flink.runtime.dispatcher.DispatcherGateway
-
Submit a job to the dispatcher.
- submitJob(JobGraph, Time) - Method in class org.apache.flink.runtime.dispatcher.MiniDispatcher
-
- submitJob(JobGraph) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
-
- submitTask(TaskDeploymentDescriptor, Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
-
Submit a task to the task manager.
- submitTask(TaskDeploymentDescriptor, Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
-
- submitTask(TaskDeploymentDescriptor, JobMasterId, Time) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
-
- submitTask(TaskDeploymentDescriptor, JobMasterId, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
-
- SubmittedJobGraph - Class in org.apache.flink.runtime.jobmanager
-
- SubmittedJobGraph(JobGraph) - 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
-
- subpartitions - Variable in class org.apache.flink.runtime.io.network.partition.ResultPartition
-
The subpartitions of this partition.
- subscribe(EventListener<TaskEvent>, Class<? extends TaskEvent>) - Method in class org.apache.flink.runtime.io.network.api.TaskEventHandler
-
- subscribeToEvent(ResultPartitionID, EventListener<TaskEvent>, Class<? extends TaskEvent>) - Method in class org.apache.flink.runtime.io.network.TaskEventDispatcher
-
Subscribes a listener to this dispatcher for events on a partition.
- substituteDeprecatedConfigKey(Configuration, String, String) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Sets the value of a new config key to the value of a deprecated config key.
- substituteDeprecatedConfigPrefix(Configuration, String, String) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
-
Sets the value of a new config key to the value of a deprecated config key.
- SubtaskAccumulatorsInfo(int, int, String, Collection<UserAccumulator>) - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo
-
- SubtaskAttemptMessageParameters - Class in org.apache.flink.runtime.rest.messages.job
-
The type Subtask attempt message parameters.
- SubtaskAttemptMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskAttemptMessageParameters
-
- subtaskAttemptPathParameter - Variable in class org.apache.flink.runtime.rest.messages.job.SubtaskAttemptMessageParameters
-
- SubtaskAttemptPathParameter - Class in org.apache.flink.runtime.rest.messages.job
-
Path parameter identifying subtask attempt.
- SubtaskAttemptPathParameter() - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskAttemptPathParameter
-
Instantiates a new Subtask attempt path parameter.
- SubtaskBackPressureInfo(int, JobVertexBackPressureInfo.VertexBackPressureLevel, double) - Constructor for class org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.SubtaskBackPressureInfo
-
- subtaskBaseDirectory(long) - Method in interface org.apache.flink.runtime.state.LocalRecoveryDirectoryProvider
-
Returns the local state directory for the owning subtask the given checkpoint id w.r.t.
- subtaskBaseDirectory(long) - Method in class org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
-
- SubtaskCheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Checkpoint statistics for a subtask.
- SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Checkpoint statistics for a completed subtask checkpoint.
- SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointAlignment - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Alignment statistics of the checkpoint.
- SubtaskCheckpointStatistics.CompletedSubtaskCheckpointStatistics.CheckpointDuration - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Duration of the checkpoint.
- SubtaskCheckpointStatistics.PendingSubtaskCheckpointStatistics - Class in org.apache.flink.runtime.rest.messages.checkpoints
-
Checkpoint statistics for a pending subtask checkpoint.
- SubtaskCurrentAttemptDetailsHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Request handler providing details about a single task execution attempt.
- SubtaskCurrentAttemptDetailsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, SubtaskExecutionAttemptDetailsInfo, SubtaskMessageParameters>, ExecutionGraphCache, Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.SubtaskCurrentAttemptDetailsHandler
-
- SubtaskCurrentAttemptDetailsHeaders - Class in org.apache.flink.runtime.rest.messages.job
-
- SubtaskCurrentAttemptDetailsHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskCurrentAttemptDetailsHeaders
-
- SubtaskExecutionAttemptAccumulatorsHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Request handler for the subtask execution attempt accumulators.
- SubtaskExecutionAttemptAccumulatorsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, SubtaskExecutionAttemptAccumulatorsInfo, SubtaskAttemptMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.SubtaskExecutionAttemptAccumulatorsHandler
-
Instantiates a new Abstract job vertex handler.
- SubtaskExecutionAttemptAccumulatorsHeaders - Class in org.apache.flink.runtime.rest.messages.job
-
- SubtaskExecutionAttemptAccumulatorsHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsHeaders
-
- SubtaskExecutionAttemptAccumulatorsInfo - Class in org.apache.flink.runtime.rest.messages.job
-
- SubtaskExecutionAttemptAccumulatorsInfo(int, int, String, Collection<UserAccumulator>) - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptAccumulatorsInfo
-
- SubtaskExecutionAttemptDetailsHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Handler of specific sub task execution attempt.
- SubtaskExecutionAttemptDetailsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, SubtaskExecutionAttemptDetailsInfo, SubtaskAttemptMessageParameters>, ExecutionGraphCache, Executor, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.SubtaskExecutionAttemptDetailsHandler
-
Instantiates a new subtask execution attempt details handler.
- SubtaskExecutionAttemptDetailsHeaders - Class in org.apache.flink.runtime.rest.messages.job
-
- SubtaskExecutionAttemptDetailsHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsHeaders
-
- SubtaskExecutionAttemptDetailsInfo - Class in org.apache.flink.runtime.rest.messages.job
-
The sub task execution attempt response.
- SubtaskExecutionAttemptDetailsInfo(int, ExecutionState, int, String, long, long, long, IOMetricsInfo) - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskExecutionAttemptDetailsInfo
-
- subtaskIndex - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
-
- subtaskIndex - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
-
- subtaskIndex - Variable in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- subtaskIndex() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- subtaskIndexPathParameter - Variable in class org.apache.flink.runtime.rest.messages.job.SubtaskMessageParameters
-
- SubtaskIndexPathParameter - Class in org.apache.flink.runtime.rest.messages
-
Path parameter specifying the index of a subtask.
- SubtaskIndexPathParameter() - Constructor for class org.apache.flink.runtime.rest.messages.SubtaskIndexPathParameter
-
- SubtaskMessageParameters - Class in org.apache.flink.runtime.rest.messages.job
-
Message parameters for subtask REST handlers.
- SubtaskMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtaskMessageParameters
-
- SubtaskMetricsHandler - Class in org.apache.flink.runtime.rest.handler.job.metrics
-
Handler that returns subtask metrics.
- SubtaskMetricsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MetricFetcher) - Constructor for class org.apache.flink.runtime.rest.handler.job.metrics.SubtaskMetricsHandler
-
- SubtaskMetricsHeaders - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
- SubtaskMetricsMessageParameters - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
- SubtaskMetricsMessageParameters() - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.SubtaskMetricsMessageParameters
-
- SubtasksAllAccumulatorsHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Request handler for the subtasks all accumulators.
- SubtasksAllAccumulatorsHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, SubtasksAllAccumulatorsInfo, JobVertexMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.SubtasksAllAccumulatorsHandler
-
- SubtasksAllAccumulatorsHeaders - Class in org.apache.flink.runtime.rest.messages
-
- SubtasksAllAccumulatorsInfo - Class in org.apache.flink.runtime.rest.messages.job
-
- SubtasksAllAccumulatorsInfo(JobVertexID, int, Collection<SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo>) - Constructor for class org.apache.flink.runtime.rest.messages.job.SubtasksAllAccumulatorsInfo
-
- SubtasksAllAccumulatorsInfo.SubtaskAccumulatorsInfo - Class in org.apache.flink.runtime.rest.messages.job
-
Detailed information about subtask accumulators.
- SubtasksFilterQueryParameter - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
- subtaskSpecificCheckpointDirectory(long) - Method in interface org.apache.flink.runtime.state.LocalRecoveryDirectoryProvider
-
Returns the local state directory for the specific operator subtask and the given checkpoint id w.r.t.
- subtaskSpecificCheckpointDirectory(long) - Method in class org.apache.flink.runtime.state.LocalRecoveryDirectoryProviderImpl
-
- SubtaskState - Class in org.apache.flink.runtime.checkpoint
-
Container for the chained state of one parallel subtask of an operator/task.
- SubtaskState(ChainedStateHandle<OperatorStateHandle>, ChainedStateHandle<OperatorStateHandle>, KeyedStateHandle, KeyedStateHandle) - Constructor for class org.apache.flink.runtime.checkpoint.SubtaskState
-
- SubtaskStateStats - Class in org.apache.flink.runtime.checkpoint
-
Statistics for a single subtask that is part of a checkpoint.
- SubtasksTimesHandler - Class in org.apache.flink.runtime.rest.handler.job
-
Request handler for the subtasks times info.
- SubtasksTimesHandler(GatewayRetriever<? extends RestfulGateway>, Time, Map<String, String>, MessageHeaders<EmptyRequestBody, SubtasksTimesInfo, JobVertexMessageParameters>, ExecutionGraphCache, Executor) - Constructor for class org.apache.flink.runtime.rest.handler.job.SubtasksTimesHandler
-
- SubtasksTimesHeaders - Class in org.apache.flink.runtime.rest.messages
-
- SubtasksTimesHeaders() - Constructor for class org.apache.flink.runtime.rest.messages.SubtasksTimesHeaders
-
- SubtasksTimesInfo - Class in org.apache.flink.runtime.rest.messages
-
- SubtasksTimesInfo(String, String, long, List<SubtasksTimesInfo.SubtaskTimeInfo>) - Constructor for class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo
-
- SubtasksTimesInfo.SubtaskTimeInfo - Class in org.apache.flink.runtime.rest.messages
-
Nested class to encapsulate the sub task times info.
- SubtaskTimeInfo(int, String, long, Map<ExecutionState, Long>) - Constructor for class org.apache.flink.runtime.rest.messages.SubtasksTimesInfo.SubtaskTimeInfo
-
- subtract(ResourceProfile) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
-
Subtracts another piece of resource profile from this one.
- Success() - Constructor for class org.apache.flink.runtime.registration.RegistrationResponse.Success
-
- SUFFIX_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
-
- Summary(MinMaxAvgStatistics, MinMaxAvgStatistics, MinMaxAvgStatistics) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.CheckpointingStatistics.Summary
-
- Summary(MinMaxAvgStatistics, MinMaxAvgStatistics, TaskCheckpointStatisticsWithSubtaskDetails.CheckpointDuration, TaskCheckpointStatisticsWithSubtaskDetails.CheckpointAlignment) - Constructor for class org.apache.flink.runtime.rest.messages.checkpoints.TaskCheckpointStatisticsWithSubtaskDetails.Summary
-
- SuperstepBarrier - Class in org.apache.flink.runtime.iterative.concurrent
-
A resettable one-shot latch.
- SuperstepBarrier(ClassLoader) - Constructor for class org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
-
- SuperstepKickoffLatch - Class in org.apache.flink.runtime.iterative.concurrent
-
Latch used to wait for the previous superstep to complete.
- SuperstepKickoffLatch() - Constructor for class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
-
- SuperstepKickoffLatchBroker - Class in org.apache.flink.runtime.iterative.concurrent
-
- supplyAsync(SupplierWithException<T, ?>, Executor) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
-
Returns a future which is completed with the result of the SupplierWithException
.
- supportsAsynchronousSnapshots() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
-
- supportsAsynchronousSnapshots() - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
-
- supportsHighlyAvailableStorage() - Method in interface org.apache.flink.runtime.state.CheckpointStorageCoordinatorView
-
Checks whether this backend supports highly available storage of data.
- supportsHighlyAvailableStorage() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStorage
-
- supportsHighlyAvailableStorage() - Method in class org.apache.flink.runtime.state.memory.MemoryBackendCheckpointStorage
-
- SuppressRestartsException - Exception in org.apache.flink.runtime.execution
-
Exception thrown in order to suppress job restarts.
- SuppressRestartsException(Throwable) - Constructor for exception org.apache.flink.runtime.execution.SuppressRestartsException
-
- suspend() - Method in class org.apache.flink.runtime.executiongraph.Execution
-
- suspend(Throwable) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
-
Suspends the current ExecutionGraph.
- suspend() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- suspend() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
-
- suspend(Exception) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
-
Suspending job, all the running tasks will be cancelled, and communication with other components
will be disposed.
- suspend(Exception) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterService
-
Suspend the JobMaster service.
- suspend() - Method in interface org.apache.flink.runtime.jobmaster.slotpool.SlotPool
-
- suspend() - Method in class org.apache.flink.runtime.jobmaster.slotpool.SlotPoolImpl
-
Suspends this pool, meaning it has lost its authority to accept and distribute slots.
- suspend() - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
-
Suspends the component.
- suspend() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerImpl
-
Suspends the component.
- suspend(Throwable) - Method in class org.apache.flink.runtime.scheduler.LegacyScheduler
-
- suspend(Throwable) - Method in interface org.apache.flink.runtime.scheduler.SchedulerNG
-
- swap(int, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- swap(int, int, int, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
-
- swap(int, int) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
-
Swap items at the given addresses.
- swap(int, int, int, int) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
-
Swap records at the given addresses.
- swap(int, int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- swap(int, int, int, int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
-
- switchBuffers() - Method in class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
-
- sync() - Method in class org.apache.flink.runtime.state.DuplicatingCheckpointOutputStream
-
- sync() - Method in class org.apache.flink.runtime.state.filesystem.FileBasedStateOutputStream
-
- sync() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointMetadataOutputStream
-
- sync() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
-
- sync() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
-
- SyncEventHandler - Class in org.apache.flink.runtime.iterative.task
-
Listener for
WorkerDoneEvent
which also aggregates all aggregators
from iteration tasks and signals the end of the superstep.
- SyncEventHandler(int, Map<String, Aggregator<?>>, ClassLoader) - Constructor for class org.apache.flink.runtime.iterative.task.SyncEventHandler
-
- SynchronousBufferFileReader - Class in org.apache.flink.runtime.io.disk.iomanager
-
- SynchronousBufferFileReader(FileIOChannel.ID, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.SynchronousBufferFileReader
-
- SynchronousChainedCombineDriver<IN,OUT> - Class in org.apache.flink.runtime.operators.chaining
-
The chained variant of the combine driver which is also implemented in GroupReduceCombineDriver.
- SynchronousChainedCombineDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
-
- SynchronousFileIOChannel - Class in org.apache.flink.runtime.io.disk.iomanager
-
A base class for synchronous readers and writers.
- SynchronousFileIOChannel(FileIOChannel.ID, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.SynchronousFileIOChannel
-
- SystemClock - Class in org.apache.flink.runtime.util.clock
-
A clock that returns the time of the system / process.
- SystemResourcesCounter - Class in org.apache.flink.runtime.metrics.util
-
Daemon thread probing system resources.
- SystemResourcesCounter(Time) - Constructor for class org.apache.flink.runtime.metrics.util.SystemResourcesCounter
-
- SystemResourcesMetricsInitializer - Class in org.apache.flink.runtime.metrics.util
-
Utility class to initialize system resource metrics.
- SystemResourcesMetricsInitializer() - Constructor for class org.apache.flink.runtime.metrics.util.SystemResourcesMetricsInitializer
-
- validateAndNormalizeUri(URI) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
-
Checks and normalizes the given URI.
- validateClassLoadable(ClassNotFoundException, ClassLoader) - Static method in class org.apache.flink.runtime.util.ClassLoaderUtil
-
Checks, whether the class that was not found in the given exception, can be resolved through
the given class loader.
- validateRunsInMainThread() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
-
Validates that the method call happens in the RPC endpoint's main thread.
- value - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.GaugeDump
-
- VALUE_NOT_SET - Static variable in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
-
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointFailureReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointRetentionPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.PendingCheckpoint.TaskAcknowledgeResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.client.ClientUtils
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.clusterframework.ApplicationStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.clusterframework.types.TaskManagerSlot.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.dispatcher.DefaultJobManagerRunnerFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.dispatcher.SessionDispatcherFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.dispatcher.VoidHistoryServerArchivist
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.entrypoint.ClusterEntrypoint.ExecutionMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.execution.ExecutionState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders.ResolveOrder
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils.AddressResolution
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.highavailability.RunningJobsRegistry.JobSchedulingStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.io.network.api.serialization.RecordSerializer.SerializationResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.io.network.buffer.BufferListener.NotificationResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobgraph.DistributionPattern
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobgraph.JobStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobgraph.ScheduleMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmanager.HighAvailabilityMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmanager.JobManagerMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmanager.scheduler.Locality
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmanager.scheduler.LocationPreferenceConstraint
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmaster.factories.UnregisteredJobManagerJobMetricGroupFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmaster.slotpool.LocationPreferenceSlotSelectionStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.jobmaster.slotpool.PreviousAllocationSlotSelectionStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.metrics.groups.AbstractMetricGroup.ChildType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.minicluster.RpcServiceSharing
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.operators.DamBehavior
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.operators.DriverStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.operators.shipping.ShipStrategyType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.operators.util.LocalStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.resourcemanager.StandaloneResourceManagerFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.handler.legacy.backpressure.VoidBackPressureStatsTracker
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.handler.legacy.metrics.VoidMetricFetcher
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.HttpMethodWrapper
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.JobRestEndpointFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter.AggregationMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.MessageParameter.MessageParameterRequisiteness
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.queue.QueueStatus.Id
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter.TerminationMode
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.SessionRestEndpointFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.util.RestConstants
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rest.versioning.RestAPIVersion
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils.AkkaProtocol
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rpc.akka.ControlMessages
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.rpc.messages.HandshakeSuccessMessage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.scheduler.strategy.SchedulingResultPartition.ResultPartitionState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.shuffle.NettyShuffleDescriptor.LocalExecutionPartitionConnectionInfo
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.shuffle.NettyShuffleMaster
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.shuffle.ShuffleServiceLoader
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.state.CheckpointedStateScope
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.BackendStateType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.CommonOptionsKeys
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.CommonSerializerKeys
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshotReadersWriters.StateTypeHint
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.state.OperatorStateHandle.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.state.StateSnapshotTransformer.CollectionStateSnapshotTransformer.TransformStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.taskexecutor.FileType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.throwable.ThrowableType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.util.ZooKeeperUtils.ZkClientACLMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.webmonitor.history.HistoryServerUtils
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.runtime.webmonitor.WebMonitorExtension.EmptyWebMonitorExtension
-
Returns the enum constant of this type with the specified name.
- valueOrNull(Object) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
-
- values() - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointFailureReason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointRetentionPolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.checkpoint.PendingCheckpoint.TaskAcknowledgeResult
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.client.ClientUtils
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.clusterframework.ApplicationStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.clusterframework.types.TaskManagerSlot.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.dispatcher.DefaultJobManagerRunnerFactory
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.dispatcher.SessionDispatcherFactory
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.dispatcher.VoidHistoryServerArchivist
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.entrypoint.ClusterEntrypoint.ExecutionMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.execution.ExecutionState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoaders.ResolveOrder
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils.AddressResolution
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.highavailability.RunningJobsRegistry.JobSchedulingStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.io.network.api.serialization.RecordSerializer.SerializationResult
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.io.network.buffer.BufferListener.NotificationResult
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.io.network.partition.BoundedBlockingSubpartitionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobgraph.DistributionPattern
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobgraph.JobStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobgraph.ScheduleMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmanager.HighAvailabilityMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmanager.JobManagerMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmanager.scheduler.Locality
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmanager.scheduler.LocationPreferenceConstraint
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmaster.factories.UnregisteredJobManagerJobMetricGroupFactory
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.flink.runtime.jobmaster.slotpool.DualKeyLinkedMap
-
- values() - Static method in enum org.apache.flink.runtime.jobmaster.slotpool.LocationPreferenceSlotSelectionStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.jobmaster.slotpool.PreviousAllocationSlotSelectionStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.metrics.groups.AbstractMetricGroup.ChildType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.minicluster.RpcServiceSharing
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.operators.DamBehavior
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.operators.DriverStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.operators.shipping.ShipStrategyType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.operators.util.LocalStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.resourcemanager.StandaloneResourceManagerFactory
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.handler.legacy.backpressure.VoidBackPressureStatsTracker
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.handler.legacy.metrics.VoidMetricFetcher
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.HttpMethodWrapper
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.JobRestEndpointFactory
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.messages.checkpoints.CheckpointConfigInfo.ProcessingMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.messages.job.metrics.MetricsAggregationParameter.AggregationMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.messages.JobVertexBackPressureInfo.VertexBackPressureStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.messages.MessageParameter.MessageParameterRequisiteness
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.messages.queue.QueueStatus.Id
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.messages.TerminationModeQueryParameter.TerminationMode
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.SessionRestEndpointFactory
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.util.RestConstants
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rest.versioning.RestAPIVersion
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils.AkkaProtocol
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rpc.akka.ControlMessages
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.rpc.messages.HandshakeSuccessMessage
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.scheduler.strategy.SchedulingResultPartition.ResultPartitionState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.shuffle.NettyShuffleDescriptor.LocalExecutionPartitionConnectionInfo
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.shuffle.NettyShuffleMaster
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.shuffle.ShuffleServiceLoader
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.state.CheckpointedStateScope
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.BackendStateType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.CommonOptionsKeys
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshot.CommonSerializerKeys
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.state.metainfo.StateMetaInfoSnapshotReadersWriters.StateTypeHint
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.state.OperatorStateHandle.Mode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.state.StateSnapshotTransformer.CollectionStateSnapshotTransformer.TransformStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.taskexecutor.FileType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.throwable.ThrowableType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.util.ZooKeeperUtils.ZkClientACLMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.webmonitor.history.HistoryServerUtils
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.runtime.webmonitor.WebMonitorExtension.EmptyWebMonitorExtension
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- valueSerializer - Variable in class org.apache.flink.runtime.state.heap.AbstractHeapState
-
- variables - Variable in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
-
The map containing all variables and their associated values, lazily computed.
- verifyEmpty() - Method in class org.apache.flink.runtime.memory.MemoryManager
-
Checks if the memory manager all memory available.
- verifyEndOfSuperstepState() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
-
- version() - Method in class org.apache.flink.runtime.checkpoint.MasterState
-
- VERSION - Static variable in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
-
The savepoint version.
- VERSION - Static variable in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
-
The savepoint version.
- VERSION - Static variable in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
-
- VERSION - Static variable in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
-
- VERTEX_TASK_FIELD_ID - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo
-
- VERTEX_TASK_FIELD_NAME - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo
-
- VERTEX_TASK_FIELD_NOW - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo
-
- VERTEX_TASK_FIELD_TASK_MANAGERS - Static variable in class org.apache.flink.runtime.rest.messages.JobVertexTaskManagersInfo
-
- vertexFinished(ExecutionVertexID) - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.partitionrelease.NotReleasingPartitionReleaseStrategy
-
- vertexFinished(ExecutionVertexID) - Method in interface org.apache.flink.runtime.executiongraph.failover.flip1.partitionrelease.PartitionReleaseStrategy
-
Calling this method informs the strategy that a vertex finished.
- vertexFinished(ExecutionVertexID) - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.partitionrelease.RegionPartitionReleaseStrategy
-
- vertexID - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
-
- vertexID - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
-
- vertexId - Variable in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- vertexId() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
-
- VertexTaskDetail(int, ExecutionState, int, String, long, long, long, IOMetricsInfo) - Constructor for class org.apache.flink.runtime.rest.messages.JobVertexDetailsInfo.VertexTaskDetail
-
- vertexUnfinished(ExecutionVertexID) - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.partitionrelease.NotReleasingPartitionReleaseStrategy
-
- vertexUnfinished(ExecutionVertexID) - Method in interface org.apache.flink.runtime.executiongraph.failover.flip1.partitionrelease.PartitionReleaseStrategy
-
Calling this method informs the strategy that a vertex is no longer in finished state, e.g.,
when a vertex is re-executed.
- vertexUnfinished(ExecutionVertexID) - Method in class org.apache.flink.runtime.executiongraph.failover.flip1.partitionrelease.RegionPartitionReleaseStrategy
-
- ViewUpdater - Class in org.apache.flink.runtime.metrics
-
The ViewUpdater is responsible for updating all metrics that implement the View
interface.
- ViewUpdater(ScheduledExecutorService) - Constructor for class org.apache.flink.runtime.metrics.ViewUpdater
-
- VoidBackPressureStatsTracker - Enum in org.apache.flink.runtime.rest.handler.legacy.backpressure
-
- VoidBlobStore - Class in org.apache.flink.runtime.blob
-
A blob store doing nothing.
- VoidBlobStore() - Constructor for class org.apache.flink.runtime.blob.VoidBlobStore
-
- VoidBlobWriter - Class in org.apache.flink.runtime.blob
-
BlobWriter which does not support writing BLOBs to a store.
- VoidBlobWriter() - Constructor for class org.apache.flink.runtime.blob.VoidBlobWriter
-
- VoidHistoryServerArchivist - Enum in org.apache.flink.runtime.dispatcher
-
- VoidMetricFetcher - Enum in org.apache.flink.runtime.rest.handler.legacy.metrics
-
- VoidNamespace - Class in org.apache.flink.runtime.state
-
Singleton placeholder class for state without a namespace.
- VoidNamespaceSerializer - Class in org.apache.flink.runtime.state
-
- VoidNamespaceSerializer() - Constructor for class org.apache.flink.runtime.state.VoidNamespaceSerializer
-
- VoidNamespaceSerializer.VoidNamespaceSerializerSnapshot - Class in org.apache.flink.runtime.state
-
Serializer configuration snapshot for compatibility and format evolution.
- VoidNamespaceSerializerSnapshot() - Constructor for class org.apache.flink.runtime.state.VoidNamespaceSerializer.VoidNamespaceSerializerSnapshot
-
- VoidNamespaceTypeInfo - Class in org.apache.flink.runtime.state
-
- VoidNamespaceTypeInfo() - Constructor for class org.apache.flink.runtime.state.VoidNamespaceTypeInfo
-